Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- abort() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- abort(Object) - Method in class org.jgroups.blocks.DistributedLockManager
-
Abort phase for the lock acquisition or release.
- abort(Object) - Method in interface org.jgroups.blocks.TwoPhaseVotingListener
-
This is unconditional abort of the previous voting on the decree.
- ABORT_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- ABOVE - Static variable in class org.jgroups.stack.ProtocolStack
- ack(long) - Method in class org.jgroups.stack.AckSenderWindow
-
Removes all messages less than or equal to seqno from
msgs
, and cancels their retransmission. - ack(long, Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
An ACK has been received from
sender
. - ack(Object) - Method in class org.jgroups.util.AckCollector
- ACK - Static variable in class org.jgroups.mux.ServiceInfo
- ACK - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
- ACK - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
- AckCollector - Class in org.jgroups.util
- AckCollector() - Constructor for class org.jgroups.util.AckCollector
- AckCollector(ViewId, List<Object>) - Constructor for class org.jgroups.util.AckCollector
- AckMcastReceiverWindow - Class in org.jgroups.stack
-
Keeps track of messages received from various senders.
- AckMcastReceiverWindow() - Constructor for class org.jgroups.stack.AckMcastReceiverWindow
- AckMcastSenderWindow - Class in org.jgroups.stack
-
Keeps track of ACKs from receivers for each message.
- AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
-
Create and start the retransmitter
- AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand, Interval) - Constructor for class org.jgroups.stack.AckMcastSenderWindow
-
Create and start the retransmitter
- AckMcastSenderWindow(AckMcastSenderWindow.RetransmitCommand, Interval, 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.RetransmitCommand - Interface in org.jgroups.stack
-
Called by retransmitter thread whenever a message needs to be re-sent to a destination.
- AckReceiverWindow - Class in org.jgroups.stack
-
Counterpart of AckSenderWindow.
- AckReceiverWindow(long) - Constructor for class org.jgroups.stack.AckReceiverWindow
- AckSenderWindow - Class in org.jgroups.stack
-
ACK-based sliding window for a sender.
- AckSenderWindow(AckSenderWindow.RetransmitCommand) - Constructor for class org.jgroups.stack.AckSenderWindow
-
Creates a new instance.
- AckSenderWindow(AckSenderWindow.RetransmitCommand, Interval) - Constructor for class org.jgroups.stack.AckSenderWindow
- AckSenderWindow(AckSenderWindow.RetransmitCommand, Interval, TimeScheduler) - Constructor for class org.jgroups.stack.AckSenderWindow
- AckSenderWindow(AckSenderWindow.RetransmitCommand, Interval, TimeScheduler, Address) - Constructor for class org.jgroups.stack.AckSenderWindow
- AckSenderWindow.RetransmitCommand - Interface in org.jgroups.stack
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.applets.DrawApplet
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.DistributedHashtableDemo
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.DistributedQueueDemo
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Draw
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Draw2Channels
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.DrawRepl
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.Gossip
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.QuoteClient
- actionPerformed(ActionEvent) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- 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(int, Object) - Method in class org.jgroups.util.UnmodifiableVector
- add(long, long) - Method in class org.jgroups.stack.Retransmitter
-
Add the given range [first_seqno, last_seqno] in the list of entries eligible for retransmission.
- add(long, Message) - Method in class org.jgroups.stack.AckReceiverWindow
-
Adds a new message.
- add(long, Message) - Method in class org.jgroups.stack.AckSenderWindow
-
Adds a new message to the retransmission table.
- add(long, Message) - Method in class org.jgroups.stack.NakReceiverWindow
-
Adds a message according to its seqno (sequence number).
- add(long, Message, Vector) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Adds a new message to the hash table.
- add(short, Class) - Method in class org.jgroups.conf.ClassConfigurator
-
Method to register a user-defined header with jg-magic-map at runtime
- add(Object) - Method in class org.jgroups.blocks.DistributedQueue
-
Add the speficied element at the bottom of the queue
- add(Object) - Method in class org.jgroups.util.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.SizeBoundedQueue
- add(Object) - Method in class org.jgroups.util.UnmodifiableVector
- add(Object, long) - Method in class org.jgroups.stack.AckMcastReceiverWindow
-
Records the sender/seqno pair in the message table
- add(Runnable) - Method in class org.jgroups.util.Scheduler
- add(String) - Method in class org.jgroups.blocks.DistributedTree
- add(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
- add(String, Serializable, int) - Method in class org.jgroups.blocks.DistributedTree
- add(Collection<Address>) - Method in class org.jgroups.Membership
-
Adds a list of members to this membership
- add(K) - Method in class org.jgroups.util.AgeOutCache
- add(Address) - Method in class org.jgroups.Membership
-
Adds a new member to this membership.
- add(Address, long) - Method in class org.jgroups.util.SeqnoTable
- add(Address, long, long) - Method in class org.jgroups.util.MutableDigest
- add(Address, long, long, long) - Method in class org.jgroups.util.MutableDigest
- add(Address, T) - Method in class org.jgroups.util.ResponseCollector
- add(ProtocolData) - Method in class org.jgroups.conf.XmlConfigurator
- add(Digest) - Method in class org.jgroups.util.MutableDigest
- add(T) - Method in class org.jgroups.util.BoundedList
-
Adds an element at the tail.
- addAll(int, Collection) - Method in class org.jgroups.util.UnmodifiableVector
- addAll(Collection) - Method in class org.jgroups.blocks.DistributedQueue
-
Add the speficied collection to the top of the queue.
- addAll(Collection) - Method in class org.jgroups.util.Queue
- addAll(Collection) - Method in class org.jgroups.util.SizeBoundedQueue
- addAll(Collection) - Method in class org.jgroups.util.UnmodifiableVector
- addAll(List<Object>) - Method in class org.jgroups.util.Queue
- addAtHead(Object) - Method in class org.jgroups.blocks.DistributedQueue
-
Add the speficied element at the top of the queue
- addAtHead(Object) - Method in class org.jgroups.util.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.
- addChannelListener(ChannelListener) - Method in class org.jgroups.blocks.RpcDispatcher
-
Add a new channel listener to be notified on the channel's state change.
- addChannelListener(ChannelListener) - Method in class org.jgroups.Channel
-
Allows to be notified when a channel event such as connect, disconnect or close occurs.
- addChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
- addConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
- addDigest(Digest) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- addDistributedTreeListener(DistributedTree.DistributedTreeListener) - Method in class org.jgroups.blocks.DistributedTree
- addElement(Object) - Method in class org.jgroups.util.UnmodifiableVector
- addGossipRouter(IpAddress) - Method in class org.jgroups.stack.GossipClient
-
Adds a GossipRouter to be accessed.
- addIgnoreMember(Address) - Method in class org.jgroups.protocols.DISCARD
-
Messages from this sender will get dropped
- additional_data - Variable in class org.jgroups.JChannel
-
Provides storage for arbitrary objects.
- additionalChannelListeners - Variable in class org.jgroups.blocks.RpcDispatcher
- addListener(TwoPhaseVotingListener) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
-
Wraps actual listener with the VoteChannelListener and adds to the voteChannel
- addMember(Address) - Method in class org.jgroups.debug.Simulator
- addMember(Address, Simulator) - Method in class org.jgroups.debug.Simulator
- addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MembershipListenerAdapter
-
Add membership listener to this adapter.
- addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- addMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.VotingAdapter
- addMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageListenerAdapter
-
Add message listener to this adapter.
- addNode(Object) - Method in class org.jgroups.demos.Topology
- addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.GraphPanel
- addNode(String, Address, int, int) - Method in class org.jgroups.demos.wb.Whiteboard
- addNotifier(DistributedHashtable.Notification) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- addNotifier(DistributedQueue.Notification) - Method in class org.jgroups.blocks.DistributedQueue
- addNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
- addNotifier(ReplicatedHashtable.Notification) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- addNotReceived(Address) - Method in class org.jgroups.util.RspList
- addPanel(String, JPanel) - Method in class org.jgroups.demos.TotalTokenDemo
- addPayload(String, Object) - Method in class org.jgroups.View
-
Adds a key and value to the view.
- addPrio(Runnable) - Method in class org.jgroups.util.Scheduler
- addr - Variable in class org.jgroups.demos.wb.Node
- addReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
- address - Variable in class org.jgroups.util.DefaultThreadFactory
- Address - Interface in org.jgroups
-
Abstract address.
- addRsp(Address, Object) - Method in class org.jgroups.util.RspList
- addStateTransferListener(ReplicatedHashtable.StateTransferListener) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- addSuspect(Address) - Method in class org.jgroups.util.RspList
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.Broadcaster
-
Adds a suspected member.
- addSuspectedMember(Address) - Method in class org.jgroups.protocols.FD.BroadcastTask
- addToSeenList(Address) - Method in class org.jgroups.protocols.pbcast.Gossip
- addViewListener(DistributedTree.ViewListener) - Method in class org.jgroups.blocks.DistributedTree
- addVote(boolean) - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
- addVoteListener(VotingListener) - Method in class org.jgroups.blocks.VotingAdapter
-
Adds voting listener.
- adjustNodes(Vector) - Method in class org.jgroups.demos.wb.GraphPanel
- afterExecute(Runnable, Throwable) - Method in class org.jgroups.util.ThreadManagerThreadPoolExecutor
-
Invokes
ThreadDecorator.threadReleased(Thread)
on the current thread. - afterExecute(Runnable, Throwable) - Method in class org.jgroups.util.TimeScheduler
- AgeOutCache<K> - Class in org.jgroups.util
-
Cache which removes its elements after a certain time
- AgeOutCache(ScheduledExecutorService, long) - Constructor for class org.jgroups.util.AgeOutCache
- AgeOutCache(ScheduledExecutorService, long, AgeOutCache.Handler) - Constructor for class org.jgroups.util.AgeOutCache
- AgeOutCache.Handler<K> - Interface in org.jgroups.util
- all(Collection, Object) - Static method in class org.jgroups.util.Util
-
Returns true if all elements of c match obj
- arg - Variable in class org.jgroups.protocols.PingHeader
- args - Variable in class org.jgroups.blocks.MethodCall
-
The arguments of the method.
- array2String(boolean[]) - Static method in class org.jgroups.util.Util
- array2String(int[]) - Static method in class org.jgroups.util.Util
- array2String(long[]) - Static method in class org.jgroups.util.Util
- array2String(short[]) - Static method in class org.jgroups.util.Util
- array2String(Object[]) - Static method in class org.jgroups.util.Util
- assignTask(Runnable) - Method in class org.jgroups.util.ReusableThread
-
Assigns a task to the thread.
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.Protocol
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.BARRIER
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.Discovery
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FC
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FD_ALL
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FD_SOCK
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FD
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FRAG
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.FRAG2
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.MERGE2
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.MPING
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.PARTITION
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.PING
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.SEQUENCER
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.SFC
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.STATS
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCP_NIO
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCP
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCPGOSSIP
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TCPPING
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.TP
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.UDP
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.UNICAST
- attachProtocol(Protocol) - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- ATTR_INHERIT - Static variable in class org.jgroups.conf.XmlConfigurator
- ATTR_NAME - Static variable in class org.jgroups.conf.XmlConfigurator
- ATTR_VALUE - Static variable in class org.jgroups.conf.XmlConfigurator
- AUTH - Class in org.jgroups.protocols
-
The AUTH protocol adds a layer of authentication to JGroups
- AUTH() - Constructor for class org.jgroups.protocols.AUTH
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.AuthToken
-
This method should be implemented to perform the actual authentication of joining members.
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.FixedMembershipToken
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.MD5Token
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.SimpleToken
- authenticate(AuthToken, Message) - Method in class org.jgroups.auth.X509Token
- AuthHeader - Class in org.jgroups.protocols
-
AuthHeader is a holder object for the token that is passed from the joiner to the coordinator
- AuthHeader() - Constructor for class org.jgroups.protocols.AuthHeader
- AuthToken - Class in org.jgroups.auth
-
Abstract AuthToken class used by implementations of AUTH, e.g.
- AuthToken() - Constructor for class org.jgroups.auth.AuthToken
- AUTO_GETSTATE - Static variable in class org.jgroups.Channel
- AUTO_RECONNECT - Static variable in class org.jgroups.Channel
- AUTOCONF - Class in org.jgroups.protocols
-
Senses the network configuration when it is initialized (in init()) and sends a CONFIG event up and down the stack.
- AUTOCONF() - Constructor for class org.jgroups.protocols.AUTOCONF
- available() - Method in class org.jgroups.util.ExposedByteArrayInputStream
- available() - Method in class org.jgroups.util.ReusableThread
B
- BARRIER - Class in org.jgroups.jmx.protocols
-
JMX wrapper for BARRIER protocol.
- BARRIER - Class in org.jgroups.protocols
-
All messages up the stack have to go through a barrier (read lock, RL).
- BARRIER() - Constructor for class org.jgroups.jmx.protocols.BARRIER
- BARRIER() - Constructor for class org.jgroups.protocols.BARRIER
- BARRIER(Protocol) - Constructor for class org.jgroups.jmx.protocols.BARRIER
- BARRIERMBean - Interface in org.jgroups.jmx.protocols
-
JMX interface for BARRIER protocol.
- baseName - Variable in class org.jgroups.util.DefaultThreadFactory
- BasicConnectionTable - Class in org.jgroups.blocks
-
Shared class for TCP connection tables.
- BasicConnectionTable() - Constructor for class org.jgroups.blocks.BasicConnectionTable
- BasicConnectionTable.ConnectionListener - Interface in org.jgroups.blocks
-
Used to be notified about connection establishment and teardown.
- BasicConnectionTable.Receiver - Interface in org.jgroups.blocks
-
Used for message reception.
- BasicTCP - Class in org.jgroups.protocols
-
Shared base class for tcpip protocols
- BasicTCP() - Constructor for class org.jgroups.protocols.BasicTCP
- bcast_task - Variable in class org.jgroups.protocols.FD
-
Transmits SUSPECT message until view change or UNSUSPECT is received
- BECOME_SERVER - Static variable in class org.jgroups.Event
- becomeClient() - Method in class org.jgroups.protocols.pbcast.GMS
- becomeCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
- becomeParticipant() - Method in class org.jgroups.protocols.pbcast.GMS
- BELOW - Static variable in class org.jgroups.stack.ProtocolStack
- bind_addr - Variable in class org.jgroups.protocols.TP
-
The interface (NIC) which should be used by this transport
- BIND_ADDR - Static variable in class org.jgroups.Global
- BIND_ADDR_OLD - Static variable in class org.jgroups.Global
- BIND_INTERFACE - Static variable in class org.jgroups.Global
- block() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Block sending and receiving of messages until ViewAccepted is called
- block() - Method in class org.jgroups.blocks.DistributedLockManager
- block() - Method in class org.jgroups.blocks.DistributedQueue
-
Block sending and receiving of messages until ViewAccepted is called
- block() - Method in class org.jgroups.blocks.DistributedTree
-
Block sending and receiving of messages until ViewAccepted is called
- block() - Method in class org.jgroups.blocks.MembershipListenerAdapter
-
Notify membership listeners to temporarily stop sending messages into a channel.
- block() - Method in class org.jgroups.blocks.NotificationBus
- block() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Block sending and receiving of messages until ViewAccepted is called
- block() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.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.ChatCore
- block() - Method in class org.jgroups.demos.Draw
- block() - Method in class org.jgroups.demos.QuoteClient
- block() - Method in class org.jgroups.demos.QuoteServer
- block() - Method in class org.jgroups.demos.Topology
- block() - Method in class org.jgroups.demos.wb.Whiteboard
- block() - Method in class org.jgroups.ExtendedReceiverAdapter
- block() - Method in interface org.jgroups.MembershipListener
-
Called (usually by the FLUSH protocol), as an indication that the member should stop sending messages.
- block() - Method in class org.jgroups.ReceiverAdapter
- BLOCK - Static variable in class org.jgroups.Channel
- BLOCK - Static variable in class org.jgroups.Event
- BlockEvent - Class in org.jgroups
-
Trivial object that represents a block event.
- BlockEvent() - Constructor for class org.jgroups.BlockEvent
- blockOk() - Method in class org.jgroups.Channel
-
Called to acknowledge a block() (callback in
MembershipListener
orBlockEvent
received from call toReceive
). - blockOk() - Method in class org.jgroups.JChannel
-
Called to acknowledge a block() (callback in
MembershipListener
orBlockEvent
received from call toreceive()
). - blockOk() - Method in class org.jgroups.jmx.JChannel
- blockOk() - Method in interface org.jgroups.jmx.JChannelMBean
- BoundedList<T> - Class in org.jgroups.util
-
A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.
- BoundedList() - Constructor for class org.jgroups.util.BoundedList
- BoundedList(int) - Constructor for class org.jgroups.util.BoundedList
- Broadcaster() - Constructor for class org.jgroups.protocols.FD.Broadcaster
- BSH - Class in org.jgroups.protocols
-
Beanshell (www.beanshell.org) interpreter class.
- BSH() - Constructor for class org.jgroups.protocols.BSH
- BSH.BshHeader - Class in org.jgroups.protocols
- BshHeader() - Constructor for class org.jgroups.protocols.BSH.BshHeader
- BshHeader(int) - Constructor for class org.jgroups.protocols.BSH.BshHeader
- Buffer - Class in org.jgroups.util
-
Buffer with an offset and length.
- Buffer(byte[], int, int) - Constructor for class org.jgroups.util.Buffer
- BYTE_SIZE - Static variable in class org.jgroups.Global
- byteBufferToMessage(byte[], int, int) - Static method in class org.jgroups.util.Util
- byteBufferToMessageList(byte[], int, int) - Static method in class org.jgroups.util.Util
C
- call_stack - Variable in class org.jgroups.blocks.RequestCorrelator
-
This field is used only if deadlock detection is enabled.
- 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, MethodCall, int, long, boolean) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, String, Object[], Class[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, String, Object[], Class[], int, long, boolean) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, String, Object[], Class[], int, long, boolean, RspFilter) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, String, Object[], String[], int, long) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, String, Object[], String[], int, long, boolean) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, MethodCall, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, MethodCall, int, long, boolean) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, MethodCall, int, long, boolean, boolean) - Method in class org.jgroups.blocks.RpcDispatcher
- callRemoteMethods(Vector, MethodCall, int, long, boolean, boolean, RspFilter) - Method in class org.jgroups.blocks.RpcDispatcher
- callStack - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
Stack<Address>.
- canBeProcessedTogether(GmsImpl.Request) - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
-
Specifies whether this request can be processed with other request simultaneously
- CANCEL_MERGE - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- CannotConnectException - Exception Class in org.jgroups.persistence
- CannotConnectException(Exception, String) - Constructor for exception class org.jgroups.persistence.CannotConnectException
- CannotConnectException(Throwable, String) - Constructor for exception class org.jgroups.persistence.CannotConnectException
- CannotCreateSchemaException - Exception Class in org.jgroups.persistence
- CannotCreateSchemaException(Throwable, String) - Constructor for exception class org.jgroups.persistence.CannotCreateSchemaException
- CannotPersistException - Exception Class in org.jgroups.persistence
- CannotPersistException(Throwable, String) - Constructor for exception class org.jgroups.persistence.CannotPersistException
- CannotRemoveException - Exception Class in org.jgroups.persistence
- CannotRemoveException(Throwable, String) - Constructor for exception class org.jgroups.persistence.CannotRemoveException
- CannotRetrieveException - Exception Class in org.jgroups.persistence
- CannotRetrieveException(Throwable, String) - Constructor for exception class org.jgroups.persistence.CannotRetrieveException
- capacity() - Method in class org.jgroups.util.Headers
- capacity() - Method in class org.jgroups.util.UnmodifiableVector
- 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.MessageDispatcher
- castMessage(Vector, Message, int, long) - Method in class org.jgroups.blocks.RpcDispatcher
- castMessage(Vector, Message, int, long, boolean) - Method in class org.jgroups.blocks.MessageDispatcher
-
Cast a message to all members, and wait for
mode
responses. - castMessage(Vector, Message, int, long, boolean, RspFilter) - Method in class org.jgroups.blocks.MessageDispatcher
- castViewChangeWithDest(View, Digest, JoinRsp, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Broadcasts the new view and digest, and waits for acks from all members in the list given as argument.
- CAUSAL - Class in org.jgroups.protocols
-
Implements casual ordering layer using vector clocks.
- CAUSAL() - Constructor for class org.jgroups.protocols.CAUSAL
-
Default constructor.
- CAUSAL.CausalHeader - Class in org.jgroups.protocols
- CAUSAL.CausalNewViewHeader - Class in org.jgroups.protocols
- CAUSAL.MissingIndexesMessage - Class in org.jgroups.protocols
- CausalDemo - Class in org.jgroups.demos
-
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
- CausalHeader() - Constructor for class org.jgroups.protocols.CAUSAL.CausalHeader
-
used for externalization
- CausalHeader(TransportedVectorTime) - Constructor for class org.jgroups.protocols.CAUSAL.CausalHeader
- CausalNewViewHeader() - Constructor for class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
-
Used for externalization.
- CausalNewViewHeader(ViewId, int, boolean) - Constructor for class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- CERT_ALIAS - Static variable in class org.jgroups.auth.X509Token
- CERT_PASSWORD - Static variable in class org.jgroups.auth.X509Token
- channel - Variable in class org.jgroups.blocks.DistributedQueue
- channel - Variable in class org.jgroups.blocks.DistributedTree
- channel - Variable in class org.jgroups.blocks.MessageDispatcher
- Channel - Class in org.jgroups
-
A channel represents a group communication endpoint (like BSD datagram sockets).
- Channel() - Constructor for class org.jgroups.Channel
- channel_listeners - Variable in class org.jgroups.Channel
- CHANNEL_LOCAL_ADDR_TIMEOUT - Static variable in class org.jgroups.Global
- channel_name - Variable in class org.jgroups.protocols.TP
-
The name of the group to which this member is connected
- channel_name - Variable in class org.jgroups.protocols.TpHeader
- channel_name - Variable in class org.jgroups.protocols.TunnelHeader
- channel_name - Variable in class org.jgroups.protocols.UdpHeader
- channelClosed(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- channelClosed(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
- channelClosed(Channel) - Method in interface org.jgroups.ChannelListener
- channelClosed(Channel) - Method in class org.jgroups.ChannelListenerAdapter
- channelClosed(Channel) - Method in class org.jgroups.demos.Draw
- channelClosed(Channel) - Method in class org.jgroups.demos.Gossip
- ChannelClosedException - Exception Class in org.jgroups
-
Thrown if an operation is attemped on a closed channel.
- ChannelClosedException() - Constructor for exception class org.jgroups.ChannelClosedException
- ChannelClosedException(String) - Constructor for exception class org.jgroups.ChannelClosedException
- channelConnected(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- channelConnected(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
- channelConnected(Channel) - Method in interface org.jgroups.ChannelListener
- channelConnected(Channel) - Method in class org.jgroups.ChannelListenerAdapter
- channelConnected(Channel) - Method in class org.jgroups.demos.Draw
- channelConnected(Channel) - Method in class org.jgroups.demos.Gossip
- channelDisconnected(Channel) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- channelDisconnected(Channel) - Method in class org.jgroups.blocks.RpcDispatcher
- channelDisconnected(Channel) - Method in interface org.jgroups.ChannelListener
- channelDisconnected(Channel) - Method in class org.jgroups.ChannelListenerAdapter
- channelDisconnected(Channel) - Method in class org.jgroups.demos.Draw
- channelDisconnected(Channel) - Method in class org.jgroups.demos.Gossip
- ChannelException - Exception Class in org.jgroups
-
This class represents the super class for all exception types thrown by JGroups.
- ChannelException() - Constructor for exception class org.jgroups.ChannelException
- ChannelException(String) - Constructor for exception class org.jgroups.ChannelException
- ChannelException(String, Throwable) - Constructor for exception class org.jgroups.ChannelException
- ChannelFactory - Interface in org.jgroups
-
A channel factory that removes hardwiring of calls to create JGroups channels.
- ChannelListener - Interface in org.jgroups
-
Allows a listener to be notified when important channel events occur.
- ChannelListenerAdapter - Class in org.jgroups
-
Class which implements
ChannelListener
- ChannelListenerAdapter() - Constructor for class org.jgroups.ChannelListenerAdapter
- ChannelNotConnectedException - Exception Class in org.jgroups
-
Thrown if an operation is attemped on an unconnected channel.
- ChannelNotConnectedException() - Constructor for exception class org.jgroups.ChannelNotConnectedException
- ChannelNotConnectedException(String) - Constructor for exception class org.jgroups.ChannelNotConnectedException
- channelReconnected(Address) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- channelReconnected(Address) - Method in class org.jgroups.blocks.RpcDispatcher
- channelReconnected(Address) - Method in interface org.jgroups.ChannelListener
- channelReconnected(Address) - Method in class org.jgroups.ChannelListenerAdapter
- channelReconnected(Address) - Method in class org.jgroups.demos.Draw
- channelReconnected(Address) - Method in class org.jgroups.demos.Gossip
- channelShunned() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- channelShunned() - Method in class org.jgroups.blocks.RpcDispatcher
- channelShunned() - Method in interface org.jgroups.ChannelListener
- channelShunned() - Method in class org.jgroups.ChannelListenerAdapter
- channelShunned() - Method in class org.jgroups.demos.Draw
- channelShunned() - Method in class org.jgroups.demos.Gossip
- Chat - Class in org.jgroups.demos
- Chat(String) - Constructor for class org.jgroups.demos.Chat
- ChatCore - Class in org.jgroups.demos
- ChatCore(String) - Constructor for class org.jgroups.demos.ChatCore
- checkBufferSize(String, long) - Static method in class org.jgroups.util.Util
-
Verifies that val is invalid input: '<'= max memory
- checkClosed() - Method in class org.jgroups.JChannel
-
health check
throws a ChannelClosed exception if the channel is closed - checkClosedOrNotConnected() - Method in class org.jgroups.JChannel
- checkForLinux() - Static method in class org.jgroups.util.Util
- checkForSolaris() - Static method in class org.jgroups.util.Util
- checkForWindows() - Static method in class org.jgroups.util.Util
- checkResult(RspList, Object) - Method in class org.jgroups.blocks.DistributedQueue
- checkSelfInclusion(Vector<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Returns true if local_addr is member of mbrs, else false
- CIPHER_TYPE - Static variable in class org.jgroups.auth.X509Token
- ClassConfigurator - Class in org.jgroups.conf
-
This class will be replaced with the class that read info from the magic number configurator that reads info from the xml file.
- ClassConfigurator() - Constructor for class org.jgroups.conf.ClassConfigurator
- ClassMap - Class in org.jgroups.conf
-
Maintains mapping between magic number and class
- ClassMap(String, short) - Constructor for class org.jgroups.conf.ClassMap
- clear() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Clears this hashtable so that it contains no keys
- clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Removes all of the mappings from this map.
- clear() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.Clears this hashtable so that it contains no keys
- clear() - Method in class org.jgroups.Membership
-
removes all the members from this membership
- clear() - Method in class org.jgroups.persistence.DBPersistenceManager
-
Clears the key-cache as well as all entries
- clear() - Method in class org.jgroups.persistence.FilePersistenceManager
-
Clears the complete NV state from the DB
- clear() - Method in interface org.jgroups.persistence.PersistenceManager
-
Clears the complete NV state from the DB
- clear() - Method in class org.jgroups.util.MutableDigest
- clear() - Method in class org.jgroups.util.Queue
-
Removes all elements from the queue.
- clear() - Method in class org.jgroups.util.RspList
- clear() - Method in class org.jgroups.util.SeqnoTable
- clear() - Method in class org.jgroups.util.SizeBoundedQueue
- clear() - Method in class org.jgroups.util.UnmodifiableVector
- clearChannelListeners() - Method in class org.jgroups.Channel
- clearConfigurations() - Method in class org.jgroups.JChannelFactory
-
Removes all configurations
- clearConfigurations() - Method in class org.jgroups.jmx.JChannelFactory
- clearConfigurations() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- clearFlag(byte) - Method in class org.jgroups.Message
- clearPanel() - Method in class org.jgroups.demos.applets.DrawApplet
- 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
- clearStableMessages() - Method in class org.jgroups.stack.AckMcastSenderWindow
- ClientGmsImpl - Class in org.jgroups.protocols.pbcast
-
Client part of GMS.
- ClientGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ClientGmsImpl
- clone() - Method in class org.jgroups.blocks.ReplicatedTree.Node
- 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.protocols.JMS.JMSAddress
-
Clone the object.
- clone() - Method in class org.jgroups.stack.IpAddress
- clone() - Method in class org.jgroups.util.UnmodifiableVector
- clone() - Method in class org.jgroups.View
-
creates a copy of this view
- clone() - Method in class org.jgroups.ViewId
-
Cloneable interface Returns a new ViewID object containing the same address and lamport timestamp as this view
- close() - Method in class org.jgroups.Channel
-
Destroys the channel and its associated resources (e.g., the protocol stack).
- close() - Method in class org.jgroups.demos.ChatCore
- close() - Method in class org.jgroups.JChannel
-
Destroys the channel.
- close() - Method in class org.jgroups.jmx.JChannel
- close() - Method in interface org.jgroups.jmx.JChannelMBean
- close() - Method in class org.jgroups.mux.Multiplexer
- close() - Method in class org.jgroups.mux.MuxChannel
- close(boolean) - Method in class org.jgroups.util.Queue
-
Marks the queues as closed.
- close(InputStream) - Static method in class org.jgroups.util.Util
- close(OutputStream) - Static method in class org.jgroups.util.Util
- close(DatagramSocket) - Static method in class org.jgroups.util.Util
- close(Socket) - Static method in class org.jgroups.util.Util
- close(Channel) - Static method in class org.jgroups.util.Util
- close(Channel...) - Static method in class org.jgroups.util.Util
- CLOSE_BARRIER - Static variable in class org.jgroups.Event
- closeAll() - Method in class org.jgroups.mux.Multiplexer
- closed - Variable in class org.jgroups.JChannel
- 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.
- closeMessageQueue(boolean) - Method in class org.jgroups.JChannel
- closer - Variable in class org.jgroups.JChannel
-
Thread responsible for closing a channel and potentially reconnecting to it (e.g., when shunned).
- clusterName - Variable in class org.jgroups.util.DefaultThreadFactory
- collectionToByteBuffer(Collection) - Static method in class org.jgroups.util.Util
- colorPanel(int, int, int) - Method in class org.jgroups.demos.Gossip
- Command - Interface in org.jgroups.util
-
The Command patttern (see Gamma et al.).
- commit() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
- commit() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- commit(Object) - Method in class org.jgroups.blocks.DistributedLockManager
-
Commit phase for the lock acquisition or release.
- commit(Object) - Method in 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
-
Deprecated.
- compareTo(Object) - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Compare this object to
o
. - compareTo(Object) - Method in class org.jgroups.stack.IpAddress
-
implements the java.lang.Comparable interface
- compareTo(Object) - Method in class org.jgroups.ViewId
-
Establishes an order between 2 ViewIds.
- compareToUnique(Object) - Method in class org.jgroups.stack.IpAddress
-
Deprecated.Use
IpAddress.compareTo(org.jgroups.Address)
instead - componentHidden(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- componentMoved(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- componentResized(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- componentShown(ComponentEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- COMPRESS - Class in org.jgroups.protocols
-
Compresses the payload of a message.
- COMPRESS() - Constructor for class org.jgroups.protocols.COMPRESS
- COMPRESS.CompressHeader - Class in org.jgroups.protocols
- CompressHeader() - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
- CompressHeader(int) - Constructor for class org.jgroups.protocols.COMPRESS.CompressHeader
- computeFragOffsets(byte[], int) - Static method in class org.jgroups.util.Util
- computeFragOffsets(int, int, int) - Static method in class org.jgroups.util.Util
-
Given a buffer and a fragmentation size, compute a list of fragmentation offset/length pairs, and return them in a list.
- concurrent_processing - 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).
- CONFIG - Static variable in class org.jgroups.Event
- Configurator - Class in org.jgroups.stack
-
The task if this class is to setup and configure the protocol stack.
- Configurator() - Constructor for class org.jgroups.stack.Configurator
- Configurator.ProtocolConfiguration - Class in org.jgroups.stack
-
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
- ConfiguratorFactory - Class in org.jgroups.conf
-
The ConfigurationFactory is a factory that returns a protocol stack configurator.
- ConfiguratorFactory() - Constructor for class org.jgroups.conf.ConfiguratorFactory
- conn_expire_time - Variable in class org.jgroups.protocols.BasicTCP
- connect() - Method in class org.jgroups.demos.TotalTokenDemo
- connect(String) - Method in class org.jgroups.Channel
-
Connects the channel to a group.
- connect(String) - Method in class org.jgroups.JChannel
-
Connects the channel to a group.
- connect(String) - Method in class org.jgroups.jmx.JChannel
- connect(String) - Method in interface org.jgroups.jmx.JChannelMBean
- connect(String) - Method in class org.jgroups.mux.MuxChannel
- connect(String) - Method in class org.jgroups.stack.RouterStub
-
Register this process with the router under
groupname
. - connect(String, Address, String, long) - Method in class org.jgroups.Channel
-
Connects the channel to a group and fetches the state
- connect(String, Address, String, long) - Method in class org.jgroups.JChannel
-
Connects this channel to a group and gets a state from a specified state provider.
- connect(String, Address, String, long) - Method in class org.jgroups.mux.MuxChannel
- CONNECT - Static variable in class org.jgroups.Event
- CONNECT - Static variable in class org.jgroups.stack.GossipRouter
- CONNECT_WITH_STATE_TRANSFER - Static variable in class org.jgroups.Event
- connected - Variable in class org.jgroups.JChannel
- connectionClosed(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
- connectionOpened(Address) - Method in interface org.jgroups.blocks.BasicConnectionTable.ConnectionListener
- connectionStatusChange(int) - Method in interface org.jgroups.stack.RouterStub.ConnectionListener
- ConnectionTable - Class in org.jgroups.blocks
-
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(InetAddress, int) - Constructor for class org.jgroups.blocks.ConnectionTable
- ConnectionTable(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int) - Constructor for class org.jgroups.blocks.ConnectionTable
- ConnectionTable(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTable
- ConnectionTable(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long, PortsManager) - Constructor for class org.jgroups.blocks.ConnectionTable
-
ConnectionTable including a connection reaper.
- ConnectionTable(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, PortsManager) - Constructor for class org.jgroups.blocks.ConnectionTable
-
Create a ConnectionTable
- ConnectionTableNIO - Class in org.jgroups.blocks
-
Manages incoming and outgoing TCP connections.
- ConnectionTableNIO(int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, long, long, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, PortsManager, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO(BasicConnectionTable.Receiver, InetAddress, InetAddress, int, int, PortsManager, long, long, boolean) - Constructor for class org.jgroups.blocks.ConnectionTableNIO
- ConnectionTableNIO.MyFuture - Class in org.jgroups.blocks
- ConnectionTableNIO.SelectorWriteHandler - Class in org.jgroups.blocks
- ConnectionTableNIO.WriteRequest - Class in org.jgroups.blocks
- contains(Object) - Method in class org.jgroups.util.SizeBoundedQueue
- contains(Object) - Method in class org.jgroups.util.UnmodifiableVector
- 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.util.Digest
- containsAll(Collection) - Method in class org.jgroups.util.SizeBoundedQueue
- containsAll(Collection) - Method in class org.jgroups.util.UnmodifiableVector
- containsKey(Object) - Method in class org.jgroups.util.RspList
- containsMember(Address) - Method in class org.jgroups.View
-
returns true, if this view contains a certain member
- containsValue(Object) - Method in class org.jgroups.util.RspList
- contentsCleared() - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
-
Deprecated.
- contentsCleared() - Method in interface org.jgroups.blocks.DistributedQueue.Notification
- contentsCleared() - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- contentsCleared() - Method in class org.jgroups.demos.DistributedHashtableDemo
- contentsCleared() - Method in class org.jgroups.demos.DistributedQueueDemo
- contentsCleared() - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- contentsSet(Collection) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
- contentsSet(Collection) - Method in class org.jgroups.demos.DistributedQueueDemo
- contentsSet(Map) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
-
Deprecated.
- contentsSet(Map) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
-
Deprecated.
- contentsSet(Map) - Method in class org.jgroups.demos.DistributedHashtableDemo
- contentsSet(Map) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- contentsSet(Map<K, V>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- ContextObjectInputStream - Class in org.jgroups.util
-
ObjectInputStream which sets a contact classloader for reading bytes into objects.
- ContextObjectInputStream(InputStream) - Constructor for class org.jgroups.util.ContextObjectInputStream
-
Creates a new instance of MarshalledValueOutputStream
- coord_addr - Variable in class org.jgroups.protocols.PingRsp
- CoordAnnouncement() - Constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
- CoordAnnouncement(Address) - Constructor for class org.jgroups.protocols.MERGE3.CoordAnnouncement
- CoordGmsImpl - Class in org.jgroups.protocols.pbcast
-
Coordinator role of the Group MemberShip (GMS) protocol.
- CoordGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.CoordGmsImpl
- coordinatorChosen() - Method in class org.jgroups.demos.Topology
- copy() - Method in class org.jgroups.Membership
-
returns a copy of this membership
- copy() - Method in class org.jgroups.Message
- 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.ExponentialInterval
-
We don't need to copy as we don't have any state
- copy() - Method in interface org.jgroups.stack.Interval
-
Returns a copy of the state.
- copy() - Method in class org.jgroups.stack.StateTransferInfo
- copy() - Method in class org.jgroups.stack.StaticInterval
- copy() - Method in class org.jgroups.util.Buffer
- copy() - Method in class org.jgroups.util.Digest
- copy() - Method in class org.jgroups.util.Headers
- copy() - Method in class org.jgroups.ViewId
-
Old Copy method, deprecated because it is substituted by clone()
- copy(boolean) - Method in class org.jgroups.Message
-
Create a copy of the message.
- copy_multicast_msgs - Variable in class org.jgroups.protocols.DUPL
- copy_unicast_msgs - Variable in class org.jgroups.protocols.DUPL
- copyInto(Object[]) - Method in class org.jgroups.util.UnmodifiableVector
- corr - Variable in class org.jgroups.blocks.GroupRequest
- corr - Variable in class org.jgroups.blocks.MessageDispatcher
- correlatorStarted() - Method in class org.jgroups.blocks.MessageDispatcher
- correlatorStarted() - Method in class org.jgroups.blocks.RpcDispatcher
- corrName - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
The unique name of the associated RequestCorrelator
- counter - Variable in class org.jgroups.util.DefaultThreadFactory
- crash() - Static method in class org.jgroups.util.Util
- create() - Method in class org.jgroups.JChannelFactory
- create() - Method in class org.jgroups.jmx.JChannel
- create() - Method in class org.jgroups.jmx.JChannelFactory
- create() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- create() - Method in interface org.jgroups.jmx.JChannelMBean
- create() - Method in class org.jgroups.jmx.Protocol
- create() - Method in interface org.jgroups.jmx.ProtocolMBean
- create() - Method in class org.jgroups.stack.GossipRouter
-
JBoss MBean lifecycle operation.
- createChannel() - Method in interface org.jgroups.ChannelFactory
-
Create a new channel with the properties defined in the factory
- createChannel() - Method in class org.jgroups.JChannelFactory
-
Creates a
JChannel
implementation of theChannel
interface using the protocol stack configuration information specfied during construction of an instance of this factory.
- createChannel(Object) - Method in interface org.jgroups.ChannelFactory
- createChannel(Object) - Method in class org.jgroups.JChannelFactory
-
Deprecated.
JChannel
's conversion to type-specific construction, and the subsequent deprecation of itsJChannel(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(String) - Method in interface org.jgroups.ChannelFactory
- createChannel(String) - Method in class org.jgroups.JChannelFactory
- createDaemons - Variable in class org.jgroups.util.DefaultThreadFactory
- createDatagramSocket(InetAddress, int) - Static method in class org.jgroups.util.Util
-
Creates a DatagramSocket bound to addr.
- createDatagramSocketWithBindPort() - Method in class org.jgroups.protocols.UDP
-
Creates a DatagramSocket when bind_port > 0.
- createEphemeralDatagramSocket() - Method in class org.jgroups.protocols.UDP
-
Creates a DatagramSocket with a random port.
- createLocalAddress() - Method in class org.jgroups.protocols.UDP
- 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.
- createMonitor() - Method in class org.jgroups.protocols.FD_ICMP
- createMonitor() - Method in class org.jgroups.protocols.FD_PING
- createMulticastSocket(int) - Static method in class org.jgroups.util.Util
- createMulticastSocket(InetAddress, int, Log) - Static method in class org.jgroups.util.Util
- createMultiplexerChannel(String, String) - Method in interface org.jgroups.ChannelFactory
-
Creates an implementation of the Channel using a given stack name and registering it under a given identity.
- createMultiplexerChannel(String, String) - Method in class org.jgroups.JChannelFactory
- createMultiplexerChannel(String, String) - Method in class org.jgroups.jmx.JChannelFactory
- createMultiplexerChannel(String, String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- createMultiplexerChannel(String, String, boolean, String) - Method in interface org.jgroups.ChannelFactory
-
Creates an implementation of the Channel using a given stack name and registering it under a given identity.
- createMultiplexerChannel(String, String, boolean, String) - Method in class org.jgroups.JChannelFactory
- createMultiplexerChannel(String, String, boolean, String) - Method in class org.jgroups.jmx.JChannelFactory
- createMultiplexerChannel(String, String, boolean, String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- createMuxChannel(String, String) - Method in class org.jgroups.mux.Multiplexer
- createProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Creates a new protocol given the protocol specification.
- createProtocol(String, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
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
- createServerSocket(int, int) - Method in class org.jgroups.blocks.ConnectionTable
-
Finds first available port starting at start_port and returns server socket.
- createServerSocket(int, int) - Method in class org.jgroups.blocks.ConnectionTableNIO
-
Finds first available port starting at start_port and returns server socket.
- createServerSocket(InetAddress, int) - Static method in class org.jgroups.util.Util
- createSocket(InetAddress, InetAddress, int, long) - Method in class org.jgroups.util.TimedWriter
-
Tries to create a socket to remote_peer:remote_port.
- createThreadPool() - Method in class org.jgroups.mux.Multiplexer
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) - Static method in class org.jgroups.protocols.TP
- createThreadPool(int, int, long, String, BlockingQueue<Runnable>, ThreadFactory) - Method in class org.jgroups.stack.GossipRouter
- createView(Address, long, Address...) - Static method in class org.jgroups.util.Util
- CREDIT_REQUEST - Static variable in class org.jgroups.protocols.FC.FcHeader
- CREDIT_REQUEST - Static variable in class org.jgroups.protocols.SFC.Header
- cvs - Static variable in class org.jgroups.Version
D
- DATA - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
- DBPersistenceManager - Class in org.jgroups.persistence
-
Class will be utilized
- DBPersistenceManager(InputStream) - Constructor for class org.jgroups.persistence.DBPersistenceManager
-
Duplicate constructor allowing inputstream
- DBPersistenceManager(String) - Constructor for class org.jgroups.persistence.DBPersistenceManager
-
Default construct
- deadlock_detection - Variable in class org.jgroups.blocks.MessageDispatcher
- deadlock_detection - Variable in class org.jgroups.blocks.RequestCorrelator
-
Whether or not to perform deadlock detection for synchronous (potentially recursive) group method invocations.
- debug - Static variable in class org.jgroups.Global
-
Allows for conditional compilation; e.g., if(log.isTraceEnabled()) if(log.isInfoEnabled()) log.info(...) would be removed from the code (if recompiled) when this flag is set to false.
- decode(short) - Static method in class org.jgroups.Version
- DEFAULT_CONNECTION_FACTORY - Static variable in class org.jgroups.protocols.JMS
- DEFAULT_PROTOCOL_STACK - Static variable in class org.jgroups.JChannel
-
The default protocol stack used by the default constructor.
- default_thread_factory - Variable in class org.jgroups.stack.GossipRouter
- DefaultThreadFactory - Class in org.jgroups.util
-
Thread factory mainly responsible for naming of threads.
- DefaultThreadFactory(ThreadGroup, String, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
- DefaultThreadFactory(ThreadGroup, String, boolean, boolean) - Constructor for class org.jgroups.util.DefaultThreadFactory
- defragmentBuffer(byte[][]) - Static method in class org.jgroups.util.Util
-
Concatenates smaller fragments into entire buffers.
- DELAY - Class in org.jgroups.protocols
-
Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n where n is determined by the user).
- DELAY() - Constructor for class org.jgroups.protocols.DELAY
- DELAY_JOIN_REQ - Class in org.jgroups.protocols
-
Discards 2 JOIN-REQs then accepts 1, then discards 2 more and so on
- DELAY_JOIN_REQ() - Constructor for class org.jgroups.protocols.DELAY_JOIN_REQ
- deleteFile() - Method in class org.jgroups.util.PortsManager
-
Deletes the underlying file.
- description - Static variable in class org.jgroups.Version
- dest_addr - Variable in class org.jgroups.Message
- dest_mbrs - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
Contains a list of members who should receive the request (others will drop).
- DEST_PROPERTY - Static variable in class org.jgroups.protocols.JMS
- destroy() - Method in class org.jgroups.demos.applets.DrawApplet
- destroy() - Method in class org.jgroups.demos.wb.Whiteboard
- destroy() - Method in class org.jgroups.JChannelFactory
- destroy() - Method in class org.jgroups.jmx.JChannel
- destroy() - Method in class org.jgroups.jmx.JChannelFactory
- destroy() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- destroy() - Method in interface org.jgroups.jmx.JChannelMBean
- destroy() - Method in class org.jgroups.jmx.Protocol
- destroy() - Method in interface org.jgroups.jmx.ProtocolMBean
- destroy() - Method in class org.jgroups.protocols.BARRIER
- destroy() - Method in class org.jgroups.protocols.BSH
- destroy() - Method in class org.jgroups.protocols.COMPRESS
- destroy() - Method in class org.jgroups.protocols.LOOPBACK
- destroy() - Method in class org.jgroups.protocols.TCPGOSSIP
- destroy() - Method in class org.jgroups.protocols.TP
- destroy() - Method in class org.jgroups.stack.GossipClient
- 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
- DESTROY_INTERPRETER - Static variable in class org.jgroups.protocols.BSH.BshHeader
- destroyInterpreter() - Method in class org.jgroups.protocols.BSH
- destroyProtocolStack(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
- determineCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
- determineLeftMembers(Vector<Address>, Vector<Address>) - Static method in class org.jgroups.util.Util
-
Returns all members that left between 2 views.
- difference(Digest) - Method in class org.jgroups.util.Digest
- Digest - Class in org.jgroups.util
-
A message digest, which is used by the PBCAST layer for gossiping (also used by NAKACK for keeping track of current seqnos for all members).
- Digest() - Constructor for class org.jgroups.util.Digest
-
Used for externalization
- Digest(int) - Constructor for class org.jgroups.util.Digest
- Digest(Map<Address, Digest.Entry>) - Constructor for class org.jgroups.util.Digest
-
Creates a new digest from an existing map by copying the keys and values from map
- Digest(Address, long, long) - Constructor for class org.jgroups.util.Digest
- Digest(Address, long, long, long) - Constructor for class org.jgroups.util.Digest
- Digest(Digest) - Constructor for class org.jgroups.util.Digest
- Digest.Entry - Class in org.jgroups.util
-
Class keeping track of the lowest and highest sequence numbers delivered, and the highest sequence numbers received, per member.
- DirectExecutor - Class in org.jgroups.util
- DirectExecutor() - Constructor for class org.jgroups.util.DirectExecutor
- DISCARD - Class in org.jgroups.protocols
-
Discards up or down messages based on a percentage; e.g., setting property 'up' to 0.1 causes 10% of all up messages to be discarded.
- DISCARD() - Constructor for class org.jgroups.protocols.DISCARD
- discard_incompatible_packets - Variable in class org.jgroups.protocols.TP
-
Discard packets with a different version.
- DISCARD_PAYLOAD - Class in org.jgroups.protocols
-
Discards a message whose sequence number (in the payload, as a Long) matches seqno 2 times, before passing it up.
- DISCARD_PAYLOAD() - Constructor for class org.jgroups.protocols.DISCARD_PAYLOAD
- DISCARD.DiscardHeader - Class in org.jgroups.protocols
- DiscardHeader() - Constructor for class org.jgroups.protocols.DISCARD.DiscardHeader
- DiscardHeader(Set<Address>) - Constructor for class org.jgroups.protocols.DISCARD.DiscardHeader
- 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.demos.ChatCore
- disconnect() - Method in class org.jgroups.demos.TotalTokenDemo
- disconnect() - Method in class org.jgroups.JChannel
-
Disconnects the channel if it is connected.
- disconnect() - Method in class org.jgroups.jmx.JChannel
- disconnect() - Method in interface org.jgroups.jmx.JChannelMBean
- disconnect() - Method in class org.jgroups.mux.MuxChannel
- disconnect() - Method in class org.jgroups.stack.RouterStub
- DISCONNECT - Static variable in class org.jgroups.Event
- DISCONNECT - Static variable in class org.jgroups.stack.GossipRouter
- Discovery - Class in org.jgroups.jmx.protocols
- Discovery - Class in org.jgroups.protocols
-
The Discovery protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
- Discovery() - Constructor for class org.jgroups.jmx.protocols.Discovery
- Discovery() - Constructor for class org.jgroups.protocols.Discovery
- Discovery(Protocol) - Constructor for class org.jgroups.jmx.protocols.Discovery
- discovery_reception - Variable in class org.jgroups.protocols.PING
- DiscoveryMBean - Interface in org.jgroups.jmx.protocols
- disp - Variable in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- disp - Variable in class org.jgroups.blocks.DistributedQueue
- disp - Variable in class org.jgroups.blocks.DistributedTree
- disp - Variable in class org.jgroups.blocks.ReplicatedHashMap
- disp - Variable in class org.jgroups.demos.wb.Whiteboard
- displayMessage(String, String) - Method in class org.jgroups.demos.wb.Whiteboard
- DistributedHashtable - Class in org.jgroups.blocks
-
Deprecated.Use
ReplicatedHashMap
instead - DistributedHashtable(String, ChannelFactory, String, boolean, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Creates a DisttributedHashtable.
- DistributedHashtable(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Creates a DistributedHashtable
- DistributedHashtable(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- DistributedHashtable(PullPushAdapter, Serializable, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
- DistributedHashtable(Channel, boolean, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- DistributedHashtable(Channel, long) - Constructor for class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- DistributedHashtable.Notification - Interface in org.jgroups.blocks
-
Deprecated.
- DistributedHashtableDemo - Class in org.jgroups.demos
-
Uses the DistributedHashtable building block.
- DistributedHashtableDemo() - Constructor for class org.jgroups.demos.DistributedHashtableDemo
- DistributedLockManager - Class in org.jgroups.blocks
-
Distributed lock manager is responsible for maintaining the lock information consistent on all participating nodes.
- DistributedLockManager(TwoPhaseVotingAdapter, Object) - Constructor for class org.jgroups.blocks.DistributedLockManager
-
Constructor for the DistributedLockManager_cl object.
- DistributedLockManager(VotingAdapter, Object) - Constructor for class org.jgroups.blocks.DistributedLockManager
-
Create instance of this class.
- DistributedLockManager.AcquireLockDecree - Class in org.jgroups.blocks
-
This class represents the lock to be released.
- DistributedLockManager.LockDecree - Class in org.jgroups.blocks
-
This class represents the lock
- DistributedLockManager.MultiLockDecree - Class in org.jgroups.blocks
-
This class represents the lock that has to be marked as multilocked
- DistributedLockManager.ReleaseLockDecree - Class in org.jgroups.blocks
-
This class represents the lock to be released.
- DistributedQueue - Class in org.jgroups.blocks
-
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(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.DistributedQueue
-
Uses a user-provided PullPushAdapter to create the dispatcher rather than a Channel.
- DistributedQueue(JChannel) - Constructor for class org.jgroups.blocks.DistributedQueue
- DistributedQueue.Notification - Interface in org.jgroups.blocks
- DistributedQueueDemo - Class in org.jgroups.demos
-
Uses the DistributedQueue building block.
- DistributedQueueDemo() - Constructor for class org.jgroups.demos.DistributedQueueDemo
- DistributedTree - Class in org.jgroups.blocks
-
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 in org.jgroups.blocks
- DistributedTree.ViewListener - Interface in org.jgroups.blocks
- DistributedTreeDemo - Class in org.jgroups.demos
-
Demo showing the DistributedTree class.
- DistributedTreeDemo(boolean) - Constructor for class org.jgroups.demos.DistributedTreeDemo
- done - Variable in class org.jgroups.blocks.GroupRequest
- done() - Method in class org.jgroups.protocols.PERF_TP
- done() - Method in class org.jgroups.util.ReusableThread
- done(long) - Method in class org.jgroups.blocks.MessageDispatcher
- done(long) - Method in class org.jgroups.blocks.RequestCorrelator
-
Used to signal that a certain request may be garbage collected as all responses have been received.
- done(Address, K) - Method in class org.jgroups.util.FIFOMessageQueue
- doubleWrite(byte[], int, int, OutputStream) - Static method in class org.jgroups.util.Util
-
Makes sure that we detect when a peer connection is in the closed state (not closed while we send data, but before we send data).
- doubleWrite(byte[], OutputStream) - Static method in class org.jgroups.util.Util
-
Makes sure that we detect when a peer connection is in the closed state (not closed while we send data, but before we send data).
- down(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) - Method in class org.jgroups.jmx.JChannel
- down(Event) - Method in interface org.jgroups.jmx.JChannelMBean
-
Deprecated.
- down(Event) - Method in class org.jgroups.mux.MuxChannel
- down(Event) - Method in class org.jgroups.protocols.AUTH
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.protocols.BARRIER
- down(Event) - Method in class org.jgroups.protocols.CAUSAL
-
Process a downward event.
- 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.Discovery
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.protocols.DUMMY_TP
-
Caller by the layer above this layer.
- down(Event) - Method in class org.jgroups.protocols.DUPL
- down(Event) - Method in class org.jgroups.protocols.ENCRYPT
- down(Event) - Method in class org.jgroups.protocols.EXAMPLE
- down(Event) - Method in class org.jgroups.protocols.FC
- down(Event) - Method in class org.jgroups.protocols.FD_ALL
- down(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
- down(Event) - Method in class org.jgroups.protocols.FD_SOCK
- down(Event) - Method in class org.jgroups.protocols.FD
- down(Event) - Method in class org.jgroups.protocols.FRAG
-
Fragment a packet if larger than frag_size (add a header).
- down(Event) - Method in class org.jgroups.protocols.FRAG2
-
Fragment a packet if larger than frag_size (add a header).
- down(Event) - Method in class org.jgroups.protocols.HDRS
- down(Event) - Method in class org.jgroups.protocols.HTOTAL
- down(Event) - Method in class org.jgroups.protocols.JMS
-
Called by the protocol above this.
- down(Event) - Method in class org.jgroups.protocols.LOOPBACK
-
Caller by the layer above this layer.
- down(Event) - Method in class org.jgroups.protocols.MERGE2
- down(Event) - Method in class org.jgroups.protocols.MERGE3
- down(Event) - Method in class org.jgroups.protocols.MERGEFAST
- down(Event) - Method in class org.jgroups.protocols.PARTITION
- down(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
- down(Event) - Method in class org.jgroups.protocols.pbcast.GMS
-
This method is overridden to avoid hanging on getDigest(): when a JOIN is received, the coordinator needs to retrieve the digest from the NAKACK layer.
- down(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Callback.
- down(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
- down(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- down(Event) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- 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.SEQUENCER
- down(Event) - Method in class org.jgroups.protocols.SFC
- down(Event) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- 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.STATS
- down(Event) - Method in class org.jgroups.protocols.TP
-
Caller by the layer above this layer.
- down(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- down(Event) - Method in class org.jgroups.protocols.TRACE
- down(Event) - Method in class org.jgroups.protocols.UNICAST
- down(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- down(Event) - Method in class org.jgroups.protocols.VIEW_SYNC
- down(Event) - Method in class org.jgroups.stack.Protocol
-
An event is to be sent down the stack.
- down(Event) - Method in class org.jgroups.stack.ProtocolStack
- down_prot - Variable in class org.jgroups.stack.Protocol
- downcall(Event) - Method in class org.jgroups.Channel
-
Can be used instead of down() when a return value is expected.
- downcall(Event) - Method in class org.jgroups.JChannel
- downcall(Event) - Method in class org.jgroups.mux.MuxChannel
- downThreadEnabled() - Method in class org.jgroups.stack.Protocol
-
Deprecated.down thread was removed
- drainTo(Collection) - Method in class org.jgroups.util.SizeBoundedQueue
- drainTo(Collection, int) - Method in class org.jgroups.util.SizeBoundedQueue
- Draw - Class in org.jgroups.demos
-
Shared whiteboard, each new instance joins the same group.
- Draw(String, boolean, boolean, boolean, long, boolean, boolean) - Constructor for class org.jgroups.demos.Draw
- Draw(Channel) - Constructor for class org.jgroups.demos.Draw
- Draw(Channel, boolean, long) - Constructor for class org.jgroups.demos.Draw
- Draw2Channels - Class in org.jgroups.demos
-
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 in org.jgroups.demos.applets
- DrawApplet() - Constructor for class org.jgroups.demos.applets.DrawApplet
- DrawCommand - Class in org.jgroups.demos
-
Encapsulates information about a draw command.
- DrawCommand() - Constructor for class org.jgroups.demos.DrawCommand
- DrawMultiplexer - Class in org.jgroups.demos
- DrawMultiplexer() - Constructor for class org.jgroups.demos.DrawMultiplexer
- drawNode(Graphics, int, int, String, int) - Method in class org.jgroups.demos.Topology
- DrawRepl - Class in org.jgroups.demos
-
Replicates the whiteboard demo by intercepting central AWT event queue and mcasting events to all members.
- DrawRepl() - Constructor for class org.jgroups.demos.DrawRepl
- drawTopology(Graphics) - Method in class org.jgroups.demos.Topology
- DUMMY - Static variable in class org.jgroups.Global
- DUMMY_TP - Class in org.jgroups.protocols
-
Dummy transport, returns a fake local address and responds to CONNECT.
- DUMMY_TP() - Constructor for class org.jgroups.protocols.DUMMY_TP
- dump() - Static method in class org.jgroups.debug.Profiler
- DUMP - Static variable in class org.jgroups.stack.GossipRouter
- dumpChannels() - Method in class org.jgroups.JChannelFactory
- dumpChannels() - Method in class org.jgroups.jmx.JChannelFactory
- dumpChannels() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- dumpChannelStats() - Method in class org.jgroups.JChannel
- dumpConfiguration() - Method in class org.jgroups.JChannelFactory
- dumpConfiguration() - Method in class org.jgroups.jmx.JChannelFactory
- dumpConfiguration() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- dumpHist() - Method in class org.jgroups.demos.ChatCore
- dumpHistory() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- dumpHistory() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- dumpQueue() - Method in class org.jgroups.Channel
- dumpQueue() - Method in class org.jgroups.JChannel
- dumpQueue() - Method in class org.jgroups.jmx.JChannel
- dumpQueue() - Method in interface org.jgroups.jmx.JChannelMBean
- dumpQueue(Queue) - Static method in class org.jgroups.util.Util
-
Debugging method used to dump the content of a protocol queue in a condensed form.
- dumpRoutingTable() - Method in class org.jgroups.stack.GossipRouter
- dumpStack(boolean) - Static method in class org.jgroups.util.Util
- dumpStats() - Method in class org.jgroups.Channel
-
Returns a map of statistics of the various protocols and of the channel itself.
- dumpStats() - Method in class org.jgroups.debug.Simulator
- dumpStats() - Method in class org.jgroups.JChannel
-
Returns a map of statistics of the various protocols and of the channel itself.
- dumpStats() - Method in class org.jgroups.jmx.JChannel
- dumpStats() - Method in interface org.jgroups.jmx.JChannelMBean
- dumpStats() - Method in class org.jgroups.jmx.Protocol
- dumpStats() - Method in interface org.jgroups.jmx.ProtocolMBean
- dumpStats() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- dumpStats() - Method in class org.jgroups.jmx.protocols.SFC
- dumpStats() - Method in class org.jgroups.mux.MuxChannel
- dumpStats() - Method in class org.jgroups.protocols.DISCARD
- dumpStats() - Method in class org.jgroups.protocols.FC
- dumpStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
- dumpStats() - Method in class org.jgroups.protocols.SEQUENCER
- dumpStats() - Method in class org.jgroups.protocols.SFC
- dumpStats() - Method in class org.jgroups.protocols.TP
- dumpStats() - Method in class org.jgroups.protocols.UNICAST
- dumpStats() - Method in class org.jgroups.stack.Protocol
- dumpStats() - Method in class org.jgroups.stack.ProtocolStack
- dumpStats() - Method in class org.jgroups.util.OutgoingBufferPool
- dumpStats(String) - Method in class org.jgroups.JChannel
- dumpStats(String) - Method in class org.jgroups.stack.ProtocolStack
- dumpTaskQueue() - Method in class org.jgroups.util.TimeScheduler
- dumpThreads() - Static method in class org.jgroups.util.Util
- dumpTimerQueue() - Method in class org.jgroups.JChannel
- dumpTimerQueue() - Method in class org.jgroups.jmx.JChannel
- dumpTimerQueue() - Method in interface org.jgroups.jmx.JChannelMBean
- dumpTimerQueue() - Method in class org.jgroups.stack.ProtocolStack
-
Deprecated.Use
TP.getTimer()
instead to fetch the timer from the transport and then invoke the method on it - dumpViewHandlerHistory() - Method in class org.jgroups.protocols.pbcast.GMS
- dumpViewHandlerQueue() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- dumpViewHandlerQueue() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- dumpViewHandlerQueue() - Method in class org.jgroups.protocols.pbcast.GMS
- DUPL - Class in org.jgroups.protocols
-
Duplicates outgoing or incoming messages by copying them
- DUPL() - Constructor for class org.jgroups.protocols.DUPL
- DUPL(boolean, boolean, int, int) - Constructor for class org.jgroups.protocols.DUPL
- dx - Variable in class org.jgroups.demos.wb.Node
- dy - Variable in class org.jgroups.demos.wb.Node
E
- element() - Method in class org.jgroups.util.SizeBoundedQueue
- elementAt(int) - Method in class org.jgroups.Membership
-
Returns the component at the specified index
- elementAt(int) - Method in class org.jgroups.util.RspList
-
Deprecated.Use
RspList.entrySet()
orRspList.values()
instead - elementAt(int) - Method in class org.jgroups.util.UnmodifiableVector
- elements() - Method in class org.jgroups.util.UnmodifiableVector
- 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
- EMPTY_DIGEST - Static variable in class org.jgroups.util.Digest
- enableStats(boolean) - Method in class org.jgroups.JChannel
- enableStats(boolean) - Method in class org.jgroups.stack.Protocol
- encode(int, int, int) - Static method in class org.jgroups.Version
-
Method copied from http://www.jboss.com/index.html?module=bbinvalid input: '&op'=viewtopicinvalid input: '&t'=77231
- ENCRYPT - Class in org.jgroups.protocols
-
ENCRYPT layer.
- ENCRYPT - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- ENCRYPT() - Constructor for class org.jgroups.protocols.ENCRYPT
- ENCRYPT.EncryptHeader - Class in org.jgroups.protocols
- EncryptHeader() - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
- EncryptHeader(short) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
- EncryptHeader(short, String) - Constructor for class org.jgroups.protocols.ENCRYPT.EncryptHeader
- end_port - Variable in class org.jgroups.protocols.BasicTCP
- ensureCapacity(int) - Method in class org.jgroups.util.UnmodifiableVector
- Entry() - Constructor for class org.jgroups.debug.Profiler.Entry
- Entry() - Constructor for class org.jgroups.util.Digest.Entry
- Entry(long, long) - Constructor for class org.jgroups.util.Digest.Entry
- Entry(long, long, long) - Constructor for class org.jgroups.util.Digest.Entry
- Entry(Digest.Entry) - Constructor for class org.jgroups.util.Digest.Entry
- entryAdd(Object) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
- entryAdd(Object) - Method in class org.jgroups.demos.DistributedQueueDemo
- entryRemoved(Serializable) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- entryRemoved(Object) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
-
Deprecated.
- entryRemoved(Object) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
- entryRemoved(Object) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
-
Deprecated.
- entryRemoved(Object) - Method in class org.jgroups.demos.DistributedHashtableDemo
- entryRemoved(Object) - Method in class org.jgroups.demos.DistributedQueueDemo
- entryRemoved(K) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- entrySet() - Method in class org.jgroups.util.RspList
- entrySet(Serializable, Serializable) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- entrySet(Object, Object) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
-
Deprecated.
- entrySet(Object, Object) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
-
Deprecated.
- entrySet(Object, Object) - Method in class org.jgroups.demos.DistributedHashtableDemo
- entrySet(K, V) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- equals(Object) - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
- equals(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
- equals(Object) - Method in class org.jgroups.conf.ClassMap
- equals(Object) - Method in class org.jgroups.conf.ProtocolData
- equals(Object) - Method in class org.jgroups.conf.ProtocolParameter
- equals(Object) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- equals(Object) - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Test is this object is equal to
obj
. - equals(Object) - Method in class org.jgroups.protocols.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.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- equals(Object) - Method in class org.jgroups.protocols.PingRsp
- equals(Object) - Method in class org.jgroups.protocols.TransportedVectorTime
-
Checks if this TransportedVectorTimeis equal to the specified TransportedVectorTime.
- equals(Object) - Method in class org.jgroups.stack.IpAddress
- equals(Object) - Method in class org.jgroups.util.Digest.Entry
- equals(Object) - Method in class org.jgroups.util.Digest
- equals(Object) - Method in class org.jgroups.util.Rsp
- equals(Object) - Method in class org.jgroups.util.UnmodifiableVector
- equals(Object) - Method in class org.jgroups.View
- equals(Object) - Method in class org.jgroups.ViewId
- Event - Class in org.jgroups
-
Used for inter-stack and intra-stack communication.
- Event(int) - Constructor for class org.jgroups.Event
- Event(int, Object) - Constructor for class org.jgroups.Event
- EXAMPLE - Class in org.jgroups.protocols
-
Example of a protocol layer.
- EXAMPLE() - Constructor for class org.jgroups.protocols.EXAMPLE
- execute() - Method in class org.jgroups.blocks.GroupRequest
- execute() - Method in interface org.jgroups.util.Command
- execute(boolean) - Method in class org.jgroups.blocks.GroupRequest
-
Sends the message.
- execute(Runnable) - Method in class org.jgroups.util.DirectExecutor
- exists(String) - Method in class org.jgroups.blocks.DistributedTree
- exists(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Checks whether a given node exists in the tree
- EXIT - Static variable in class org.jgroups.Event
- ExitEvent - Class in org.jgroups
-
Trivial object that represents an exit event.
- ExitEvent() - Constructor for class org.jgroups.ExitEvent
- expected_mbrs - Variable in class org.jgroups.blocks.GroupRequest
- expired(K) - Method in interface org.jgroups.util.AgeOutCache.Handler
- expired(Address) - Method in class org.jgroups.protocols.UNICAST
-
Called by AgeOutCache, to removed expired connections
- EXPIRY_TIME - Static variable in class org.jgroups.stack.GossipRouter
- ExponentialInterval - Class in org.jgroups.stack
- ExponentialInterval() - Constructor for class org.jgroups.stack.ExponentialInterval
- ExponentialInterval(long) - Constructor for class org.jgroups.stack.ExponentialInterval
- ExposedBufferedInputStream - Class in org.jgroups.util
- ExposedBufferedInputStream(InputStream) - Constructor for class org.jgroups.util.ExposedBufferedInputStream
-
Creates a
BufferedInputStream
and saves its argument, the input streamin
, for later use. - ExposedBufferedInputStream(InputStream, int) - Constructor for class org.jgroups.util.ExposedBufferedInputStream
-
Creates a
BufferedInputStream
with the specified buffer size, and saves its argument, the input streamin
, for later use. - ExposedBufferedOutputStream - Class in org.jgroups.util
- ExposedBufferedOutputStream(OutputStream) - Constructor for class org.jgroups.util.ExposedBufferedOutputStream
-
Creates a new buffered output stream to write data to the specified underlying output stream.
- ExposedBufferedOutputStream(OutputStream, int) - Constructor for class org.jgroups.util.ExposedBufferedOutputStream
-
Creates a new buffered output stream to write data to the specified underlying output stream with the specified buffer size.
- ExposedByteArrayInputStream - Class in org.jgroups.util
- ExposedByteArrayInputStream(byte[]) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
-
Creates a
ByteArrayInputStream
so that it usesbuf
as its buffer array. - ExposedByteArrayInputStream(byte[], int, int) - Constructor for class org.jgroups.util.ExposedByteArrayInputStream
-
Creates
ByteArrayInputStream
that usesbuf
as its buffer array. - ExposedByteArrayOutputStream - Class in org.jgroups.util
-
Extends ByteArrayOutputStream, but exposes the internal buffer.
- ExposedByteArrayOutputStream() - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
- ExposedByteArrayOutputStream(int) - Constructor for class org.jgroups.util.ExposedByteArrayOutputStream
- ExposedDataOutputStream - Class in org.jgroups.util
- ExposedDataOutputStream(OutputStream) - Constructor for class org.jgroups.util.ExposedDataOutputStream
-
Creates a new data output stream to write data to the specified underlying output stream.
- ExtendedMembershipListener - Interface in org.jgroups
- ExtendedMessageListener - Interface in org.jgroups
-
ExtendedMessageListener
has additional callbacks for: partial state transfer - http://jira.jboss.com/jira/browse/JGRP-118 streaming state transfer - http://jira.jboss.com/jira/browse/JGRP-89 - ExtendedReceiver - Interface in org.jgroups
-
Extends Receiver, plus the partial state transfer methods.
- ExtendedReceiverAdapter - Class in org.jgroups
- ExtendedReceiverAdapter() - Constructor for class org.jgroups.ExtendedReceiverAdapter
- external_addr - Variable in class org.jgroups.protocols.BasicTCP
F
- failed_mbrs - Variable in class org.jgroups.protocols.FlushRsp
- FailureVoteResult(String) - Constructor for class org.jgroups.blocks.VotingAdapter.FailureVoteResult
- FC - Class in org.jgroups.jmx.protocols
- FC - Class in org.jgroups.protocols
-
Simple flow control protocol based on a credit system.
- FC() - Constructor for class org.jgroups.jmx.protocols.FC
- FC() - Constructor for class org.jgroups.protocols.FC
- FC(Protocol) - Constructor for class org.jgroups.jmx.protocols.FC
- FC.FcHeader - Class in org.jgroups.protocols
- FcHeader() - Constructor for class org.jgroups.protocols.FC.FcHeader
- FcHeader(byte) - Constructor for class org.jgroups.protocols.FC.FcHeader
- FCMBean - Interface in org.jgroups.jmx.protocols
- FD - Class in org.jgroups.jmx.protocols
- FD - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD() - Constructor for class org.jgroups.jmx.protocols.FD
- FD() - Constructor for class org.jgroups.protocols.FD
- FD(Protocol) - Constructor for class org.jgroups.jmx.protocols.FD
- FD_ALL - Class in org.jgroups.jmx.protocols
- FD_ALL - Class in org.jgroups.protocols
-
Failure detection based on simple heartbeat protocol.
- FD_ALL() - Constructor for class org.jgroups.jmx.protocols.FD_ALL
- FD_ALL() - Constructor for class org.jgroups.protocols.FD_ALL
- FD_ALL(Protocol) - Constructor for class org.jgroups.jmx.protocols.FD_ALL
- FD_ALL.Header - Class in org.jgroups.protocols
- FD_ALLMBean - Interface in org.jgroups.jmx.protocols
- FD_ICMP - Class in org.jgroups.protocols
-
Protocol which uses InetAddress.isReachable() to check whether a given host is up or not, taking 1 argument; the host name of the host to be pinged.
- FD_ICMP() - Constructor for class org.jgroups.protocols.FD_ICMP
- FD_ICMP.PingMonitor - Class in org.jgroups.protocols
-
Runs InetAddress.isReachable().
- FD_PING - Class in org.jgroups.protocols
-
Protocol which uses an executable (e.g.
- FD_PING() - Constructor for class org.jgroups.protocols.FD_PING
- FD_PING.Pinger - Class in org.jgroups.protocols
- FD_PING.PingMonitor - Class in org.jgroups.protocols
-
Executes the ping command.
- FD_SIMPLE - Class in org.jgroups.protocols
-
Simple failure detection protocol.
- FD_SIMPLE() - Constructor for class org.jgroups.protocols.FD_SIMPLE
- FD_SIMPLE.FdHeader - Class in org.jgroups.protocols
- FD_SOCK - Class in org.jgroups.jmx.protocols
- FD_SOCK - Class in org.jgroups.protocols
-
Failure detection protocol based on sockets.
- FD_SOCK() - Constructor for class org.jgroups.jmx.protocols.FD_SOCK
- FD_SOCK() - Constructor for class org.jgroups.protocols.FD_SOCK
- FD_SOCK(Protocol) - Constructor for class org.jgroups.jmx.protocols.FD_SOCK
- FD_SOCK.FdHeader - Class in org.jgroups.protocols
- FD_SOCKMBean - Interface in org.jgroups.jmx.protocols
- FD.Broadcaster - Class in org.jgroups.protocols
-
Task that periodically broadcasts a list of suspected members to the group.
- FD.BroadcastTask - Class in org.jgroups.protocols
- FD.FdHeader - Class in org.jgroups.protocols
- FD.Monitor - Class in org.jgroups.protocols
- FdHeader() - Constructor for class org.jgroups.protocols.FD_SIMPLE.FdHeader
- FdHeader() - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader() - Constructor for class org.jgroups.protocols.FD.FdHeader
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader(byte) - Constructor for class org.jgroups.protocols.FD.FdHeader
- FdHeader(byte, Map<Address, IpAddress>) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader(byte, Set<Address>) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader(byte, Vector<Address>, Address) - Constructor for class org.jgroups.protocols.FD.FdHeader
- FdHeader(byte, Address) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FdHeader(byte, Address, IpAddress) - Constructor for class org.jgroups.protocols.FD_SOCK.FdHeader
- FDMBean - Interface in org.jgroups.jmx.protocols
- fetchState(long) - Method in class org.jgroups.blocks.ReplicatedTree
-
Fetch the group state from the current coordinator.
- FIFOMessageQueue<K,
V> - Class in org.jgroups.util -
Blocking queue which can only process 1 message per service concurrently, establishing FIFO order per sender.
- FIFOMessageQueue() - Constructor for class org.jgroups.util.FIFOMessageQueue
- fileExists(String) - Static method in class org.jgroups.util.Util
- FilePersistenceManager - Class in org.jgroups.persistence
- FilePersistenceManager(String) - Constructor for class org.jgroups.persistence.FilePersistenceManager
-
Default constructor
- filterLoadedValues(Map) - Method in class org.jgroups.persistence.FilePersistenceManager
-
Turns the values into Floats to enable
DistributedHashtableDemo
to work. - FIND_INITIAL_MBRS - Static variable in class org.jgroups.Event
- findComponent(Container, String) - Method in class org.jgroups.demos.DrawRepl
- findInitialMembers() - Method in class org.jgroups.jmx.protocols.Discovery
- findInitialMembers() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- findInitialMembers(Promise<JoinRsp>) - Method in class org.jgroups.protocols.Discovery
-
Finds the initial membership: sends a GET_MBRS_REQ to all members, waits 'timeout' ms or until 'num_initial_members' have been retrieved
- findInitialMembersAsString() - Method in class org.jgroups.jmx.protocols.Discovery
- findInitialMembersAsString() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- findInitialMembersAsString() - Method in class org.jgroups.protocols.Discovery
- findMethod(short) - Method in interface org.jgroups.blocks.MethodLookup
- findProtocol(Class<?>) - Method in class org.jgroups.stack.ProtocolStack
- findProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Returns a given protocol or null if not found
- findProtocol(Protocol) - Static method in class org.jgroups.jmx.JmxConfigurator
- findProtocol(Protocol, String) - Static method in class org.jgroups.stack.Configurator
- firstElement() - Method in class org.jgroups.util.UnmodifiableVector
- fixed - Variable in class org.jgroups.demos.wb.Node
- FixedMembershipToken - Class in org.jgroups.auth
-
The FixedMemberShipToken object predefines a list of IP addresses and Ports that can join the group.
- FixedMembershipToken() - Constructor for class org.jgroups.auth.FixedMembershipToken
- FLUSH - Class in org.jgroups.jmx.protocols.pbcast
- FLUSH - Class in org.jgroups.protocols.pbcast
-
Flush, as it name implies, forces group members to flush their pending messages while blocking them to send any additional messages.
- FLUSH() - Constructor for class org.jgroups.jmx.protocols.pbcast.FLUSH
- FLUSH() - Constructor for class org.jgroups.protocols.pbcast.FLUSH
- FLUSH(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.FLUSH
- FLUSH_BYPASS - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSH_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSH_NOT_COMPLETED - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSH_RECONCILE - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSH_RECONCILE_OK - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSH.FlushHeader - Class in org.jgroups.protocols.pbcast
- flushEvents() - Method in class org.jgroups.stack.ProtocolStack
-
Deprecated.
- FlushHeader() - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FlushHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FlushHeader(byte, long) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FlushHeader(byte, long, Collection<Address>) - Constructor for class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- FLUSHMBean - Interface in org.jgroups.jmx.protocols.pbcast
- FlushRsp - Class in org.jgroups.protocols
- FlushRsp() - Constructor for class org.jgroups.protocols.FlushRsp
- FlushRsp(boolean, Vector, Vector) - Constructor for class org.jgroups.protocols.FlushRsp
- flushSupported() - Method in class org.jgroups.Channel
- flushSupported() - Method in class org.jgroups.JChannel
- focusGained(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- focusLost(FocusEvent) - Method in class org.jgroups.demos.wb.Whiteboard
- FRAG - Class in org.jgroups.jmx.protocols
- FRAG - Class in org.jgroups.protocols
-
Fragmentation layer.
- FRAG() - Constructor for class org.jgroups.jmx.protocols.FRAG
- FRAG() - Constructor for class org.jgroups.protocols.FRAG
- FRAG(Protocol) - Constructor for class org.jgroups.jmx.protocols.FRAG
- frag_id - Variable in class org.jgroups.protocols.FragHeader
- FRAG2 - Class in org.jgroups.jmx.protocols
- FRAG2 - Class in org.jgroups.protocols
-
Fragmentation layer.
- FRAG2() - Constructor for class org.jgroups.jmx.protocols.FRAG2
- FRAG2() - Constructor for class org.jgroups.protocols.FRAG2
- FRAG2(Protocol) - Constructor for class org.jgroups.jmx.protocols.FRAG2
- FRAG2MBean - Interface in org.jgroups.jmx.protocols
- FragHeader - Class in org.jgroups.protocols
- FragHeader() - Constructor for class org.jgroups.protocols.FragHeader
- FragHeader(long, int, int) - Constructor for class org.jgroups.protocols.FragHeader
- FRAGMBean - Interface in org.jgroups.jmx.protocols
- fragmentBuffer(byte[], int) - Static method in class org.jgroups.util.Util
- fragmentBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
-
Fragments a byte buffer into smaller fragments of (max.) frag_size.
G
- generateList(Collection, String) - Static method in class org.jgroups.util.Util
- generateLocalAddress() - Method in class org.jgroups.protocols.JMS
-
Generate random local address.
- get(int) - Method in class org.jgroups.util.UnmodifiableVector
- get(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Returns the message from xmit_table
- get(short) - Method in class org.jgroups.conf.ClassConfigurator
-
Returns a class for a magic number.
- get(Object) - Method in class org.jgroups.blocks.MethodCall
- get(Object) - Method in class org.jgroups.util.RspList
-
Returns the Rsp associated with address key
- get(String) - Method in class org.jgroups.blocks.DistributedTree
- get(String) - Method in class org.jgroups.conf.ClassConfigurator
-
Loads and returns the class from the class name
- 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(Address) - Method in class org.jgroups.util.Digest
-
Returns the Entry for the given sender.
- 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_CACHE - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- GET_CACHE_RSP - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- GET_DIGEST - Static variable in class org.jgroups.Event
- GET_DIGEST_EVT - Static variable in class org.jgroups.Event
- GET_DIGEST_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GET_DIGEST_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GET_FIRST - Static variable in class org.jgroups.blocks.GroupRequest
-
return only first response
- 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_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_RSP - Static variable in class org.jgroups.stack.GossipRouter
- 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
- getAcksReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
- getAcksReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getAcksSent() - Method in class org.jgroups.jmx.protocols.UNICAST
- getAcksSent() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getAdditionalData() - Method in class org.jgroups.stack.IpAddress
-
Returns the additional_data.
- 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.stack.GossipData
- getAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
- getAgeOutCacheSize() - Method in class org.jgroups.jmx.protocols.UNICAST
- getAgeOutCacheSize() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getAgeOutCacheSize() - Method in class org.jgroups.protocols.UNICAST
- getAllAvailableInterfaces() - Static method in class org.jgroups.util.Util
- getAllStates(Vector, long) - Method in class org.jgroups.Channel
-
Deprecated.Not really needed - we always want to get the state from a single member
- getAllStates(Vector, long) - Method in class org.jgroups.JChannel
-
Deprecated.Not really needed - we always want to get the state from a single member, use
JChannel.getState(org.jgroups.Address, long)
instead - getAllStocks() - Method in class org.jgroups.demos.QuoteServer
- getApplicationIds() - Method in class org.jgroups.mux.Multiplexer
-
Deprecated.Use ${link #getServiceIds()} instead
- getArg() - Method in class org.jgroups.Event
- getArg() - Method in class org.jgroups.SetStateEvent
- getArg() - Method in class org.jgroups.StreamingGetStateEvent
-
Returns OutputStream used for writing of a state.
- getArg() - Method in class org.jgroups.StreamingSetStateEvent
-
Returns InputStream used for reading of a state.
- getArgs() - Method in class org.jgroups.blocks.MethodCall
-
returns an ordered list of arguments used for the method invokation
- getAssociatedMessage() - Method in class org.jgroups.protocols.TransportedVectorTime
-
Returns a message associated with this vector timestamp.
- getAsymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
- getAsymCipher() - Method in class org.jgroups.protocols.ENCRYPT
- getAsymInit() - Method in class org.jgroups.protocols.ENCRYPT
- getAsymProvider() - Method in class org.jgroups.protocols.ENCRYPT
- getAutoGetState() - Method in class org.jgroups.jmx.JChannel
- getAutoGetState() - Method in interface org.jgroups.jmx.JChannelMBean
- getAutoReconnect() - Method in class org.jgroups.jmx.JChannel
- getAutoReconnect() - Method in interface org.jgroups.jmx.JChannelMBean
- getAverageBlockingTime() - Method in class org.jgroups.jmx.protocols.SFC
- getAverageBlockingTime() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getAverageBlockingTime() - Method in class org.jgroups.protocols.SFC
- getAverageFlushDuration() - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- getAverageFlushDuration() - Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
- getAverageFlushDuration() - Method in class org.jgroups.protocols.pbcast.FLUSH
- getAverageLossRate() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getAverageLossRate() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getAverageLossRate() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getAverageSendInterval() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getAverageSendInterval() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getAverageSendInterval() - Method in class org.jgroups.protocols.VIEW_SYNC
- getAverageSmoothedLossRate() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getAverageSmoothedLossRate() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getAverageSmoothedLossRate() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getAverageStateSize() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- getAverageStateSize() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
- getAverageStateSize() - Method in class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- getAverageStateSize() - Method in interface org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFERMBean
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- getAverageStateSize() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- getAverageTimeBlocked() - Method in class org.jgroups.jmx.protocols.FC
- getAverageTimeBlocked() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getAverageTimeBlocked() - Method in class org.jgroups.protocols.FC
- getBacklog() - Method in class org.jgroups.stack.GossipRouter
- getBindAddr() - Method in class org.jgroups.jmx.protocols.MPING
- getBindAddr() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getBindAddr() - Method in class org.jgroups.jmx.protocols.TCP
- getBindAddr() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getBindAddr() - Method in class org.jgroups.protocols.MPING
- getBindAddress() - Method in class org.jgroups.jmx.protocols.TP
- getBindAddress() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getBindAddress() - Method in class org.jgroups.protocols.TP
- getBindAddress() - Method in class org.jgroups.stack.GossipRouter
- getBindAddress(Properties) - Static method in class org.jgroups.util.Util
-
Returns the address of the interface to use defined by bind_addr and bind_interface
- getBindPort() - Method in class org.jgroups.protocols.TP
- getBindToAllInterfaces() - Method in class org.jgroups.protocols.TP
-
Deprecated.Use
TP.isReceiveOnAllInterfaces()
instead - getBlockings() - Method in class org.jgroups.jmx.protocols.FC
- getBlockings() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getBlockings() - Method in class org.jgroups.jmx.protocols.SFC
- getBlockings() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getBlockings() - Method in class org.jgroups.protocols.SFC
- getBottom() - Method in class org.jgroups.debug.ProtocolTester
- getBottommostProtocol(Protocol) - Static method in class org.jgroups.stack.Configurator
- getBroadcast() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getBroadcast() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getBroadcast() - Method in class org.jgroups.protocols.SEQUENCER
- getBuf() - Method in class org.jgroups.util.Buffer
- getBuffer() - Method in class org.jgroups.Message
-
Returns a copy of the buffer if offset and length are used, otherwise a reference.
- getBytes() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getBytes() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
- getBytesReceived() - Method in class org.jgroups.jmx.protocols.TP
- getBytesReceived() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getBytesReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
- getBytesReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getBytesSent() - Method in class org.jgroups.jmx.protocols.SFC
- getBytesSent() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getBytesSent() - Method in class org.jgroups.jmx.protocols.TP
- getBytesSent() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getBytesSent() - Method in class org.jgroups.jmx.protocols.UNICAST
- getBytesSent() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getBytesSent() - Method in class org.jgroups.protocols.SFC
- getCache() - Method in interface org.jgroups.blocks.NotificationBus.Consumer
-
Called on the coordinator to obtains its cache
- getCache() - Method in class org.jgroups.blocks.NotificationBus
- getCache() - Method in class org.jgroups.demos.NotificationBusDemo
- getCacheFromCoordinator(long, int) - Method in class org.jgroups.blocks.NotificationBus
-
Determines the coordinator and asks it for its cache.
- getCacheFromMember(Address, long, int) - Method in class org.jgroups.blocks.NotificationBus
-
Determines the coordinator and asks it for its cache.
- getCaller() - Method in class org.jgroups.blocks.GroupRequest
- getCapacity() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
- getChannel() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getChannel() - Method in class org.jgroups.blocks.DistributedQueue
- getChannel() - Method in class org.jgroups.blocks.DistributedTree
-
Returns the Channel the DistributedTree is connected to
- getChannel() - Method in class org.jgroups.blocks.MessageDispatcher
-
Offers access to the underlying Channel.
- getChannel() - Method in class org.jgroups.blocks.NotificationBus
-
Answers the Channel.
- getChannel() - Method in class org.jgroups.blocks.ReplicatedHashMap
- getChannel() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- getChannel() - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns the Channel the DistributedTree is connected to
- getChannel() - Method in class org.jgroups.demos.TotalTokenDemo
- getChannel() - Method in class org.jgroups.jmx.JChannel
- getChannel() - Method in interface org.jgroups.jmx.JChannelMBean
- getChannel() - Method in class org.jgroups.mux.MuxChannel
-
This should never be used (just for testing) !
- getChannel() - Method in class org.jgroups.stack.ProtocolStack
- getChannelName() - Method in class org.jgroups.Channel
-
Deprecated.Use
Channel.getClusterName()
instead - getChannelName() - Method in class org.jgroups.JChannel
-
Deprecated.Use
JChannel.getClusterName()
instead - getChannelName() - Method in class org.jgroups.jmx.protocols.TP
- getChannelName() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getChannelName() - Method in class org.jgroups.mux.MuxChannel
- getChannelName() - Method in class org.jgroups.protocols.TP
- getChildrenNames(String) - Method in class org.jgroups.blocks.DistributedTree
-
Returns all children of a Node as strings
- getChildrenNames(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns all children of a given node
- getClassForMap() - Method in class org.jgroups.conf.ClassMap
-
Returns the Class object for this class
- getClassName() - Method in class org.jgroups.conf.ClassMap
- getClassName() - Method in class org.jgroups.conf.ProtocolData
- getClusterName() - Method in class org.jgroups.blocks.ReplicatedHashMap
- getClusterName() - Method in class org.jgroups.Channel
-
Returns the cluster name of the group of which the channel is a member.
- getClusterName() - Method in class org.jgroups.JChannel
- getClusterName() - Method in class org.jgroups.jmx.JChannel
- getClusterName() - Method in interface org.jgroups.jmx.JChannelMBean
- getClusterName() - Method in class org.jgroups.mux.MuxChannel
- getClusterView() - Method in class org.jgroups.mux.MuxChannel
-
Returns the JGroups view of a cluster, e.g.
- getConcurrentProcessing() - Method in class org.jgroups.blocks.MessageDispatcher
- getConcurrentProcessing() - Method in class org.jgroups.util.Scheduler
- getCond() - Method in class org.jgroups.util.Promise
- getConfig(String) - Method in class org.jgroups.JChannelFactory
-
Returns the stack configuration as a string (to be fed into new JChannel()).
- getConfig(String) - Method in class org.jgroups.jmx.JChannelFactory
- getConfig(String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- getConfigStream(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
- getConfigStream(Object) - Static method in class org.jgroups.conf.ConfiguratorFactory
- getConfigStream(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a JGroups XML configuration InputStream based on the provided properties string.
- getConfigStream(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
- getConnectionTable(long, long, InetAddress, InetAddress, int, int, PortsManager) - Method in class org.jgroups.protocols.TCP_NIO
- getConnectionTable(long, long, InetAddress, InetAddress, int, int, PortsManager) - Method in class org.jgroups.protocols.TCP
- getConnExpireTime() - Method in class org.jgroups.jmx.protocols.TCP
- getConnExpireTime() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getConnExpireTime() - Method in class org.jgroups.protocols.BasicTCP
- getConsensusStr(int) - Static method in class org.jgroups.blocks.VotingAdapter
-
Convert consensus type into string representation.
- getContents() - Method in class org.jgroups.blocks.DistributedQueue
- getCoordAddress() - Method in class org.jgroups.protocols.PingRsp
- getCoordAddress() - Method in class org.jgroups.ViewId
-
returns the address of the member that issued this view
- getCoordinator() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getCoordinator() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
- 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
- getCreditRequestsReceived() - Method in class org.jgroups.jmx.protocols.FC
- getCreditRequestsReceived() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getCreditRequestsReceived() - Method in class org.jgroups.jmx.protocols.SFC
- getCreditRequestsReceived() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getCreditRequestsReceived() - Method in class org.jgroups.protocols.SFC
- getCreditRequestsSent() - Method in class org.jgroups.jmx.protocols.FC
- getCreditRequestsSent() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getCreditRequestsSent() - Method in class org.jgroups.jmx.protocols.SFC
- getCreditRequestsSent() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getCreditRequestsSent() - Method in class org.jgroups.protocols.SFC
- getCreditResponsesReceived() - Method in class org.jgroups.jmx.protocols.FC
- getCreditResponsesReceived() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getCreditResponsesSent() - Method in class org.jgroups.jmx.protocols.FC
- getCreditResponsesSent() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getCredits() - Method in class org.jgroups.jmx.protocols.SFC
- getCredits() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getCredits() - Method in class org.jgroups.protocols.SFC
- getCurrentNumTries() - Method in class org.jgroups.jmx.protocols.FD
- getCurrentNumTries() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getCurrentNumTries() - Method in class org.jgroups.protocols.FD
- getDeadlockDetection() - Method in class org.jgroups.blocks.MessageDispatcher
- getDecree() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- getDefaultThreadPool() - Method in class org.jgroups.protocols.TP
- getDefaultThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
- getDefaultThreadPoolThreadFactory() - Method in class org.jgroups.stack.GossipRouter
- getDelay() - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
- getDescription() - Method in class org.jgroups.conf.ProtocolData
- getDesiredAverageGossip() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getDesiredAverageGossip() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getDesiredAverageGossip() - Method in class org.jgroups.protocols.pbcast.STABLE
- getDesKey() - Method in class org.jgroups.protocols.ENCRYPT
- getDest() - Method in class org.jgroups.Message
- getDigest() - Method in class org.jgroups.protocols.pbcast.GMS
-
Sends down a GET_DIGEST event and waits for the GET_DIGEST_OK response, or timeout, whichever occurs first
- getDigest() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- getDigest() - Method in class org.jgroups.protocols.pbcast.MergeData
- getDigest() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Returns a message digest: for each member P the lowest, highest delivered and highest received seqno is added
- getDigest() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- getDigest() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- getDiscoveryRequestsSent() - Method in class org.jgroups.jmx.protocols.Discovery
- getDiscoveryRequestsSent() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- getDomain() - Method in class org.jgroups.JChannelFactory
- getDomain() - Method in class org.jgroups.jmx.JChannelFactory
- getDomain() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- getDownDiscardRate() - Method in class org.jgroups.protocols.DISCARD
- getDownProtocol() - Method in class org.jgroups.stack.Protocol
- getDropDownMulticasts() - Method in class org.jgroups.protocols.DISCARD
- getDropDownUnicasts() - Method in class org.jgroups.protocols.DISCARD
- getEndPort() - Method in class org.jgroups.jmx.protocols.TCP
- getEndPort() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getEndPort() - Method in class org.jgroups.protocols.BasicTCP
- getExpiryTime() - Method in class org.jgroups.stack.GossipRouter
- getExpiryTime() - Method in class org.jgroups.util.PortsManager
- getFailReason() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- getFirst() - Method in class org.jgroups.util.Queue
-
Returns the first element.
- getFirst() - Method in class org.jgroups.util.RspList
-
Returns the first value in the response set.
- getFirstNonLoopbackAddress() - Static method in class org.jgroups.util.Util
- getFirstNonLoopbackIPv6Address() - Static method in class org.jgroups.util.Util
- getFlags() - Method in class org.jgroups.Message
- getForwarded() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getForwarded() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getForwarded() - Method in class org.jgroups.protocols.SEQUENCER
- getFragSize() - Method in class org.jgroups.jmx.protocols.FRAG
- getFragSize() - Method in class org.jgroups.jmx.protocols.FRAG2
- getFragSize() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getFragSize() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- getFragSize() - Method in class org.jgroups.protocols.FRAG
- getFragSize() - Method in class org.jgroups.protocols.FRAG2
- getGcLag() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getGcLag() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getGcLag() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getGlobalThreadGroup() - Static method in class org.jgroups.util.Util
- getGossipPort() - Method in class org.jgroups.protocols.PING
- getGossipRefresh() - Method in class org.jgroups.protocols.PING
- getGossipRequestTimeout() - Method in class org.jgroups.stack.GossipRouter
-
Deprecated.
- 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
-
Deprecated.
- getGroupName() - Method in class org.jgroups.blocks.DistributedTree
-
Returns the name of the group that the DistributedTree is connected to
- getGroupName() - Method in class org.jgroups.blocks.ReplicatedTree
-
Returns the name of the group that the DistributedTree is connected to
- getGroupName() - Method in class org.jgroups.demos.Draw
- getGroupName() - Method in class org.jgroups.jmx.JChannel
- getGroupName() - Method in interface org.jgroups.jmx.JChannelMBean
- getHandler() - Method in class org.jgroups.util.AgeOutCache
- getHeader(String) - Method in class org.jgroups.Message
- getHeader(String) - Method in class org.jgroups.util.Headers
-
Returns the header associated with key
- getHeaders() - Method in class org.jgroups.Message
-
Returns a reference to the headers hashmap, which is immutable.
- getHeaders() - Method in class org.jgroups.util.Headers
- getHeartbeatsReceived() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getHeartbeatsReceived() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getHeartbeatsReceived() - Method in class org.jgroups.protocols.FD_ALL
- getHeartbeatsSent() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getHeartbeatsSent() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getHeartbeatsSent() - Method in class org.jgroups.protocols.FD_ALL
- getHighest() - Method in class org.jgroups.util.Digest.Entry
-
Return the max of the highest delivered or highest received seqno
- getHighestDelivered() - Method in class org.jgroups.stack.NakReceiverWindow
-
Returns the highest sequence number of a message consumed by the application (by
remove()
). - getHighestDeliveredSeqno() - Method in class org.jgroups.util.Digest.Entry
- getHighestReceived() - Method in class org.jgroups.stack.NakReceiverWindow
-
Returns the highest sequence number received so far (which may be higher than the highest seqno delivered so far; e.g., for 1,2,3,5,6 it would be 6.
- getHighestReceived(Address) - Method in class org.jgroups.util.SeqnoTable
- getHighestReceivedSeqno() - Method in class org.jgroups.util.Digest.Entry
- getHostname() - Static method in class org.jgroups.util.Util
- getId() - Method in class org.jgroups.blocks.MethodCall
- getId() - Method in class org.jgroups.mux.MuxChannel
- getId() - Method in class org.jgroups.mux.MuxHeader
- getId() - Method in class org.jgroups.ViewId
-
returns the lamport time of the view
- getIdentifier() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- getImpl() - Method in class org.jgroups.protocols.pbcast.GMS
- getIncomingKeepAliveTime() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingKeepAliveTime() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingKeepAliveTime() - Method in class org.jgroups.protocols.TP
- getIncomingMaxPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingMaxPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingMaxPoolSize() - Method in class org.jgroups.protocols.TP
- getIncomingMaxQueueSize() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingMaxQueueSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingMaxQueueSize() - Method in class org.jgroups.protocols.TP
- getIncomingMessages() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingMessages() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingMessages() - Method in class org.jgroups.protocols.TP
- getIncomingMinPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingMinPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingMinPoolSize() - Method in class org.jgroups.protocols.TP
- getIncomingPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingPoolSize() - Method in class org.jgroups.protocols.TP
- getIncomingQueueSize() - Method in class org.jgroups.jmx.protocols.TP
- getIncomingQueueSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getIncomingQueueSize() - Method in class org.jgroups.protocols.TP
- getInDelay() - Method in class org.jgroups.protocols.DELAY
- getInFlightThreadsCount() - Method in class org.jgroups.jmx.protocols.BARRIER
- getInFlightThreadsCount() - Method in interface org.jgroups.jmx.protocols.BARRIERMBean
-
Returns the current count of in-flight threads.
- getInfo() - Method in class org.jgroups.Channel
- getInfo() - Method in class org.jgroups.JChannel
- getInfo() - Method in class org.jgroups.protocols.BasicTCP
- getInfo() - Method in class org.jgroups.protocols.LOOPBACK
- getInfo() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- getInfo() - Method in class org.jgroups.protocols.TP
- getInfo() - Method in class org.jgroups.protocols.TUNNEL
- getInfo() - Method in class org.jgroups.protocols.UDP
- getInitialHosts() - Method in class org.jgroups.protocols.TCPPING
-
Returns the list of initial hosts as configured by the user via XML.
- getInitialMembers() - Method in class org.jgroups.jmx.protocols.Discovery
- getInitialMembers() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- getInputStream() - Method in class org.jgroups.stack.RouterStub
- getInstance() - Static method in class org.jgroups.conf.ClassConfigurator
- 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
- getInstance(boolean) - Static method in class org.jgroups.conf.ClassConfigurator
- getInstance(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
- getInstance(URL) - Static method in class org.jgroups.conf.XmlConfigurator
- getInstance(Element) - Static method in class org.jgroups.conf.XmlConfigurator
- getInstanceOldFormat(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
- getInstanceOldFormat(URL) - Static method in class org.jgroups.conf.XmlConfigurator
- getInterval() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getInterval() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getInterval() - Method in class org.jgroups.protocols.FD_ALL
- getIpAddress() - Method in class org.jgroups.stack.IpAddress
- getJavaVersion() - Static method in class org.jgroups.util.Util
- getJoinRetryTimeout() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getJoinRetryTimeout() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getJoinRetryTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
-
Deprecated.
- getJoinTimeout() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getJoinTimeout() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getJoinTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
- getKey() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
-
Returns the key that should be used for Map lookup.
- getKeys(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Gets the keys of the
data
map. - getKeyServerAddr() - Method in class org.jgroups.protocols.ENCRYPT
- getKeyStoreName() - Method in class org.jgroups.protocols.ENCRYPT
- getKpair() - Method in class org.jgroups.protocols.ENCRYPT
- getLast() - Method in class org.jgroups.util.Queue
-
Returns the last element.
- getLastViewRequestSent() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getLastViewRequestSent() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getLastViewRequestSent() - Method in class org.jgroups.protocols.VIEW_SYNC
- getLength() - Method in class org.jgroups.Message
-
Returns the number of bytes in the buffer
- getLength() - Method in class org.jgroups.util.Buffer
- getLinger() - Method in class org.jgroups.blocks.BasicConnectionTable
- getLingerTimeout() - Method in class org.jgroups.stack.GossipRouter
- getListener() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- getLocal_addr() - Method in class org.jgroups.protocols.ENCRYPT
- getLocalAddress() - Method in class org.jgroups.blocks.BasicConnectionTable
- getLocalAddress() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getLocalAddress() - Method in class org.jgroups.blocks.DistributedQueue
- getLocalAddress() - Method in class org.jgroups.blocks.DistributedTree
- getLocalAddress() - Method in class org.jgroups.blocks.NotificationBus
- getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedHashMap
- getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- getLocalAddress() - Method in class org.jgroups.blocks.ReplicatedTree
- getLocalAddress() - Method in class org.jgroups.blocks.RequestCorrelator
- getLocalAddress() - Method in class org.jgroups.Channel
-
Returns the channel's own address.
- getLocalAddress() - Method in class org.jgroups.JChannel
-
returns the local address of the channel returns null if the channel is closed
- getLocalAddress() - Method in class org.jgroups.jmx.JChannel
- getLocalAddress() - Method in interface org.jgroups.jmx.JChannelMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.FD
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.TP
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getLocalAddress() - Method in class org.jgroups.jmx.protocols.UNICAST
- getLocalAddress() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getLocalAddress() - Method in class org.jgroups.mux.MuxChannel
- getLocalAddress() - Method in class org.jgroups.protocols.FD_ALL
- getLocalAddress() - Method in class org.jgroups.protocols.FD_SOCK
- getLocalAddress() - Method in class org.jgroups.protocols.FD
- getLocalAddress() - Method in class org.jgroups.protocols.pbcast.GMS
- getLocalAddress() - Method in class org.jgroups.protocols.SEQUENCER
- getLocalAddress() - Method in class org.jgroups.protocols.TP
- getLocalAddress() - Method in class org.jgroups.protocols.UNICAST
- getLocalAddress() - Method in class org.jgroups.stack.RouterStub
- getLocalAddressAsString() - Method in class org.jgroups.JChannel
- getLocalAddressAsString() - Method in class org.jgroups.jmx.JChannel
- getLocalAddressAsString() - Method in interface org.jgroups.jmx.JChannelMBean
- getLocalTime() - Method in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- getLock() - Method in class org.jgroups.stack.AckReceiverWindow
- getLock() - Method in class org.jgroups.stack.NakReceiverWindow
- getLock() - Method in class org.jgroups.util.Promise
- getLocks() - Method in class org.jgroups.stack.ProtocolStack
- getLog() - Method in class org.jgroups.Channel
- getLog() - Method in class org.jgroups.JChannel
- getLossRate() - Method in class org.jgroups.stack.NakReceiverWindow
-
Returns the loss rate, which is defined as the number of pending retransmission requests / the total number of messages in xmit_table
- getLow() - Method in class org.jgroups.util.Digest.Entry
- getLowestMessage() - Method in class org.jgroups.stack.AckSenderWindow
-
Returns the message with the lowest seqno
- getLowestSeen() - Method in class org.jgroups.stack.NakReceiverWindow
- getLowestSeqno() - Method in class org.jgroups.stack.AckSenderWindow
- getMagicNumber() - Method in class org.jgroups.conf.ClassMap
- getMagicNumber(Class) - Method in class org.jgroups.conf.ClassConfigurator
-
Returns the magic number for the class.
- getMagicNumberFromObjectStreamClass(ObjectStreamClass) - Method in class org.jgroups.conf.ClassConfigurator
- getMarshaller() - Method in class org.jgroups.blocks.RequestCorrelator
- getMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
- getMaxBlockTime() - Method in class org.jgroups.jmx.protocols.FC
- getMaxBlockTime() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getMaxBlockTime() - Method in class org.jgroups.protocols.FC
- getMaxBundleSize() - Method in class org.jgroups.jmx.protocols.TP
- getMaxBundleSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getMaxBundleSize() - Method in class org.jgroups.protocols.TP
- getMaxBundleTimeout() - Method in class org.jgroups.jmx.protocols.TP
- getMaxBundleTimeout() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getMaxBundleTimeout() - Method in class org.jgroups.protocols.TP
- getMaxBundlingTime() - Method in class org.jgroups.protocols.pbcast.GMS
- getMaxBytes() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getMaxBytes() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getMaxBytes() - Method in class org.jgroups.protocols.pbcast.STABLE
- getMaxCloseTime() - Method in class org.jgroups.jmx.protocols.BARRIER
- getMaxCloseTime() - Method in interface org.jgroups.jmx.protocols.BARRIERMBean
-
Gets configured max_close_time value (ms).
- getMaxCloseTime() - Method in class org.jgroups.protocols.BARRIER
- getMaxCredits() - Method in class org.jgroups.jmx.protocols.FC
- getMaxCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getMaxCredits() - Method in class org.jgroups.jmx.protocols.SFC
- getMaxCredits() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getMaxCredits() - Method in class org.jgroups.protocols.FC
- getMaxCredits() - Method in class org.jgroups.protocols.SFC
- getMaxInterval() - Method in class org.jgroups.jmx.protocols.MERGE2
- getMaxInterval() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- getMaxInterval() - Method in class org.jgroups.protocols.MERGE2
- getMaxRetransmitTime() - Method in class org.jgroups.jmx.protocols.UNICAST
- getMaxRetransmitTime() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getMaxRetransmitTime() - Method in class org.jgroups.protocols.UNICAST
- getMaxTries() - Method in class org.jgroups.jmx.protocols.FD
- getMaxTries() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getMaxTries() - Method in class org.jgroups.protocols.FD
- getMaxXmitBufSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getMaxXmitBufSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getMaxXmitBufSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getMaxXmitBufSize() - Method in class org.jgroups.stack.NakReceiverWindow
- getMaxXmitSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
-
Deprecated.removed in 2.6
- getMaxXmitSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
-
Deprecated.removed in 2.6
- getMaxXmitSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.removed in 2.6
- getMBeanServer() - Static method in class org.jgroups.util.Util
- getMBeanServerName() - Method in class org.jgroups.jmx.JChannel
- getMcastAddr() - Method in class org.jgroups.jmx.protocols.MPING
- getMcastAddr() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getMcastAddr() - Method in class org.jgroups.protocols.MPING
- getMcastPort() - Method in class org.jgroups.jmx.protocols.MPING
- getMcastPort() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getMcastPort() - Method in class org.jgroups.protocols.MPING
- getMember() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- getMember() - Method in class org.jgroups.SuspectEvent
- getMembers() - Method in class org.jgroups.blocks.MessageDispatcher
-
Returns a copy of members
- getMembers() - Method in class org.jgroups.blocks.ReplicatedTree
- getMembers() - Method in class org.jgroups.blocks.VotingAdapter
- getMembers() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getMembers() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getMembers() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- getMembers() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- getMembers() - Method in class org.jgroups.jmx.protocols.FD
- getMembers() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getMembers() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getMembers() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getMembers() - Method in class org.jgroups.jmx.protocols.UNICAST
- getMembers() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getMembers() - Method in class org.jgroups.Membership
-
returns a copy (clone) of the members in this membership.
- getMembers() - Method in class org.jgroups.protocols.FD_ALL
- getMembers() - Method in class org.jgroups.protocols.FD_SOCK
- getMembers() - Method in class org.jgroups.protocols.FD
- getMembers() - Method in class org.jgroups.protocols.pbcast.GMS
- getMembers() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- getMembers() - Method in class org.jgroups.protocols.UNICAST
- getMembers() - Method in class org.jgroups.stack.GossipData
- getMembers() - Method in class org.jgroups.View
-
Returns a reference to the List of members (ordered) Do NOT change this list, hence your will invalidate the view Make a copy if you have to modify it.
- getMembers(String) - Method in class org.jgroups.stack.GossipClient
-
Returns all members of a given group
- getMembership() - Method in class org.jgroups.blocks.NotificationBus
-
Returns a reference to the real membership: don't modify.
- getMessage() - Method in class org.jgroups.demos.wb.SendDialog
- getMessageListener() - Method in class org.jgroups.blocks.MessageDispatcher
-
Gives access to the currently configured MessageListener.
- getMessagesReceived() - Method in class org.jgroups.jmx.protocols.TP
- getMessagesReceived() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getMessagesReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
- getMessagesReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getMessagesSent() - Method in class org.jgroups.jmx.protocols.TP
- getMessagesSent() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getMessagesSent() - Method in class org.jgroups.jmx.protocols.UNICAST
- getMessagesSent() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getMethod() - Method in class org.jgroups.blocks.MethodCall
- getMethodLookup() - Method in class org.jgroups.blocks.RpcDispatcher
- getMinCredits() - Method in class org.jgroups.jmx.protocols.FC
- getMinCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getMinCredits() - Method in class org.jgroups.protocols.FC
- getMinInterval() - Method in class org.jgroups.jmx.protocols.MERGE2
- getMinInterval() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- getMinInterval() - Method in class org.jgroups.protocols.MERGE2
- getMinThreshold() - Method in class org.jgroups.jmx.protocols.FC
- getMinThreshold() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getMinThreshold() - Method in class org.jgroups.protocols.FC
- getMissingCompletionIndexes() - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- getMissingMessagesReceived() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getMissingMessagesReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getMissingMessagesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getMissingTimeIndexes() - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- getMode() - Method in class org.jgroups.blocks.MethodCall
- getMultiplexer() - Method in class org.jgroups.mux.MuxChannel
- getMultiplexerConfig() - Method in class org.jgroups.JChannelFactory
- getMultiplexerConfig() - Method in class org.jgroups.jmx.JChannelFactory
- getMultiplexerConfig() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- getName() - Method in class org.jgroups.auth.AuthToken
-
Used to return the full package and class name of the implementation.
- getName() - Method in class org.jgroups.auth.FixedMembershipToken
- getName() - Method in class org.jgroups.auth.MD5Token
- getName() - Method in class org.jgroups.auth.SimpleToken
- getName() - Method in class org.jgroups.auth.X509Token
- getName() - Method in class org.jgroups.blocks.MethodCall
-
returns the name of the method to be invoked using this method call object
- getName() - Method in class org.jgroups.blocks.RpcDispatcher
- getName() - Method in class org.jgroups.conf.ProtocolParameter
- getName() - Method in class org.jgroups.conf.XmlConfigurator
- getName() - Method in class org.jgroups.jmx.Protocol
- getName() - Method in interface org.jgroups.jmx.ProtocolMBean
- getName() - Method in class org.jgroups.protocols.AUTH
- getName() - Method in class org.jgroups.protocols.AUTOCONF
- getName() - Method in class org.jgroups.protocols.BARRIER
- 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.DELAY_JOIN_REQ
- getName() - Method in class org.jgroups.protocols.DELAY
-
All protocol names have to be unique !
- getName() - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
- getName() - Method in class org.jgroups.protocols.DISCARD
-
All protocol names have to be unique !
- getName() - Method in class org.jgroups.protocols.DUMMY_TP
- getName() - Method in class org.jgroups.protocols.DUPL
- getName() - Method in class org.jgroups.protocols.ENCRYPT
- 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_ALL
- getName() - Method in class org.jgroups.protocols.FD_ICMP
- getName() - Method in class org.jgroups.protocols.FD_PING
- 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.FD
- getName() - Method in class org.jgroups.protocols.FRAG
- getName() - Method in class org.jgroups.protocols.FRAG2
- getName() - Method in class org.jgroups.protocols.HDRS
- getName() - Method in class org.jgroups.protocols.HTOTAL
- getName() - Method in class org.jgroups.protocols.JMS
-
Get the name of the protocol.
- getName() - Method in class org.jgroups.protocols.LOOPBACK
- getName() - Method in class org.jgroups.protocols.MERGE2
- getName() - Method in class org.jgroups.protocols.MERGE3
- getName() - Method in class org.jgroups.protocols.MERGEFAST
- getName() - Method in class org.jgroups.protocols.MPING
- getName() - Method in class org.jgroups.protocols.PARTITION
- getName() - Method in class org.jgroups.protocols.pbcast.FLUSH
- 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.STABLE
- getName() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
-
All protocol names have to be unique !
- getName() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- getName() - Method in class org.jgroups.protocols.PERF_TP
- getName() - Method in class org.jgroups.protocols.PING
- getName() - Method in class org.jgroups.protocols.SEQUENCER
- getName() - Method in class org.jgroups.protocols.SFC
- getName() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- 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.STATS
- getName() - Method in class org.jgroups.protocols.TCP_NIO
- getName() - Method in class org.jgroups.protocols.TCP
- getName() - Method in class org.jgroups.protocols.TCPGOSSIP
- getName() - Method in class org.jgroups.protocols.TCPPING
- getName() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- 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.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_SYNC
- getName() - Method in class org.jgroups.stack.Protocol
- getName() - Method in class org.jgroups.stack.ProtocolStack
- getNegativeVotes() - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
- GetNetworkInterfaces - Class in org.jgroups.util
-
Lists all network interfaces on a system
- GetNetworkInterfaces() - Constructor for class org.jgroups.util.GetNetworkInterfaces
- getNewViewId() - Method in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- getNext(String) - Method in class org.jgroups.demos.CausalDemo
- getNextAvailablePort(int) - Method in class org.jgroups.util.PortsManager
-
Loads the file, weeds out expired ports, returns the next available port and saves the new port in the file
- getNextToReceive(Address) - Method in class org.jgroups.util.SeqnoTable
- getNextView(Collection<Address>, Collection<Address>, Collection<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
-
Computes the next view.
- getNotSeenList() - Method in class org.jgroups.protocols.pbcast.Gossip
- getNumAcksReceived() - Method in class org.jgroups.protocols.UNICAST
- getNumAcksSent() - Method in class org.jgroups.protocols.UNICAST
- getNumberOfBlockings() - Method in class org.jgroups.protocols.FC
- getNumberOfConnectionCreations() - Static method in class org.jgroups.blocks.BasicConnectionTable
- getNumberOfCreditRequestsReceived() - Method in class org.jgroups.protocols.FC
- getNumberOfCreditRequestsSent() - Method in class org.jgroups.protocols.FC
- getNumberOfCreditResponsesReceived() - Method in class org.jgroups.protocols.FC
- getNumberOfCreditResponsesSent() - Method in class org.jgroups.protocols.FC
- getNumberOfDiscoveryRequestsSent() - Method in class org.jgroups.protocols.Discovery
- getNumberOfFlushes() - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- getNumberOfFlushes() - Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
- getNumberOfFlushes() - Method in class org.jgroups.protocols.pbcast.FLUSH
- getNumberOfHeartbeatsSent() - Method in class org.jgroups.jmx.protocols.FD
- getNumberOfHeartbeatsSent() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getNumberOfHeartbeatsSent() - Method in class org.jgroups.protocols.FD
- getNumberOfInFlightThreads() - Method in class org.jgroups.protocols.BARRIER
- getNumberOfMessagesInReceiveWindows() - Method in class org.jgroups.jmx.protocols.UNICAST
- getNumberOfMessagesInReceiveWindows() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getNumberOfMessagesInReceiveWindows() - Method in class org.jgroups.protocols.UNICAST
- getNumberOfReceivedFragments() - Method in class org.jgroups.jmx.protocols.FRAG
- getNumberOfReceivedFragments() - Method in class org.jgroups.jmx.protocols.FRAG2
- getNumberOfReceivedFragments() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getNumberOfReceivedFragments() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG
- getNumberOfReceivedFragments() - Method in class org.jgroups.protocols.FRAG2
- getNumberOfReceivedMessages() - Method in class org.jgroups.jmx.protocols.FRAG
- getNumberOfReceivedMessages() - Method in class org.jgroups.jmx.protocols.FRAG2
- getNumberOfReceivedMessages() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getNumberOfReceivedMessages() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG
- getNumberOfReceivedMessages() - Method in class org.jgroups.protocols.FRAG2
- getNumberOfResponsesExpected(long) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Returns the number of members for a given entry for which acks have to be received
- getNumberOfResponsesReceived(long) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Returns the number of members for a given entry for which acks have been received
- getNumberOfRetransmitRequestsReceived() - Method in class org.jgroups.protocols.UNICAST
- getNumberOfSentFragments() - Method in class org.jgroups.jmx.protocols.FRAG
- getNumberOfSentFragments() - Method in class org.jgroups.jmx.protocols.FRAG2
- getNumberOfSentFragments() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getNumberOfSentFragments() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG
- getNumberOfSentFragments() - Method in class org.jgroups.protocols.FRAG2
- getNumberOfSentMessages() - Method in class org.jgroups.jmx.protocols.FRAG
- getNumberOfSentMessages() - Method in class org.jgroups.jmx.protocols.FRAG2
- getNumberOfSentMessages() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getNumberOfSentMessages() - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG
- getNumberOfSentMessages() - Method in class org.jgroups.protocols.FRAG2
- getNumberOfStateBytesSent() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- getNumberOfStateBytesSent() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
- getNumberOfStateBytesSent() - Method in class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- getNumberOfStateBytesSent() - Method in interface org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFERMBean
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- getNumberOfStateBytesSent() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- getNumberOfStateRequests() - Method in class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- getNumberOfStateRequests() - Method in interface org.jgroups.jmx.protocols.pbcast.STATE_TRANSFERMBean
- getNumberOfStateRequests() - Method in class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- getNumberOfStateRequests() - Method in interface org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFERMBean
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- getNumberOfStateRequests() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- getNumberOfTasksInTimer() - Method in class org.jgroups.JChannel
- getNumberOfTasksInTimer() - Method in class org.jgroups.jmx.JChannel
- getNumberOfTasksInTimer() - Method in interface org.jgroups.jmx.JChannelMBean
- getNumberOfUnackedMessages() - Method in class org.jgroups.protocols.UNICAST
-
The number of messages in all Entry.sent_msgs tables (haven't received an ACK yet)
- getNumberOfViews() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getNumberOfViews() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getNumberOfViews() - Method in class org.jgroups.protocols.pbcast.GMS
- getNumBytesReceived() - Method in class org.jgroups.protocols.TP
- getNumBytesReceived() - Method in class org.jgroups.protocols.UNICAST
- getNumBytesSent() - Method in class org.jgroups.protocols.TP
- getNumBytesSent() - Method in class org.jgroups.protocols.UNICAST
- getNumConnections() - Method in class org.jgroups.blocks.BasicConnectionTable
- getNumHeaders() - Method in class org.jgroups.Message
- getNumInitialMembers() - Method in class org.jgroups.protocols.Discovery
- getNumMembers() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getNumMembers() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getNumMembers() - Method in class org.jgroups.protocols.pbcast.GMS
- getNumMessages() - Method in class org.jgroups.Channel
-
Returns the number of messages that are waiting.
- getNumMessages() - Method in class org.jgroups.JChannel
- getNumMessages() - Method in class org.jgroups.jmx.JChannel
- getNumMessages() - Method in interface org.jgroups.jmx.JChannelMBean
- getNumMessages() - Method in class org.jgroups.protocols.PERF_TP
- getNumMessagesReceived() - Method in class org.jgroups.protocols.TP
- getNumMessagesReceived() - Method in class org.jgroups.protocols.UNICAST
- getNumMessagesSent() - Method in class org.jgroups.protocols.TP
- getNumMessagesSent() - Method in class org.jgroups.protocols.UNICAST
- getNumPingRequests() - Method in class org.jgroups.protocols.Discovery
- getNumSuspectEventsGenerated() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- getNumSuspectEventsGenerated() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- getNumSuspectEventsGenerated() - Method in class org.jgroups.jmx.protocols.FD
- getNumSuspectEventsGenerated() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD_SOCK
- getNumSuspectEventsGenerated() - Method in class org.jgroups.protocols.FD
- getNumSuspects() - Method in class org.jgroups.blocks.GroupRequest
- getNumUnackedMessages() - Method in class org.jgroups.jmx.protocols.UNICAST
- getNumUnackedMessages() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getNumViewRequestsSent() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewRequestsSent() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewRequestsSent() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewResponsesSeen() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewResponsesSeen() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewResponsesSeen() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewsAdjusted() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewsAdjusted() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewsAdjusted() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewsEqual() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewsEqual() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewsEqual() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewsLess() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewsLess() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewsLess() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewsNonLocal() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewsNonLocal() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewsNonLocal() - Method in class org.jgroups.protocols.VIEW_SYNC
- getNumViewsSent() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- getNumViewsSent() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- getNumViewsSent() - Method in class org.jgroups.protocols.VIEW_SYNC
- getObject() - Method in class org.jgroups.Message
-
Uses Java serialization to create an object from the buffer of the message.
- getObjectName() - Method in class org.jgroups.jmx.JChannel
- getObjectName() - Method in interface org.jgroups.jmx.JChannelMBean
- getObjectStreamClassFromMagicNumber(short) - Method in class org.jgroups.conf.ClassConfigurator
- getOffset() - Method in class org.jgroups.Message
-
Returns the offset into the buffer at which the data starts
- getOffset() - Method in class org.jgroups.util.Buffer
- getOOBKeepAliveTime() - Method in class org.jgroups.jmx.protocols.TP
- getOOBKeepAliveTime() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBKeepAliveTime() - Method in class org.jgroups.protocols.TP
- getOOBMaxPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getOOBMaxPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBMaxPoolSize() - Method in class org.jgroups.protocols.TP
- getOOBMaxQueueSize() - Method in class org.jgroups.jmx.protocols.TP
- getOOBMaxQueueSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBMaxQueueSize() - Method in class org.jgroups.protocols.TP
- getOOBMessages() - Method in class org.jgroups.jmx.protocols.TP
- getOOBMessages() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBMessages() - Method in class org.jgroups.protocols.TP
- getOOBMinPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getOOBMinPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBMinPoolSize() - Method in class org.jgroups.protocols.TP
- getOOBPoolSize() - Method in class org.jgroups.jmx.protocols.TP
- getOOBPoolSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBPoolSize() - Method in class org.jgroups.protocols.TP
- getOOBQueueSize() - Method in class org.jgroups.jmx.protocols.TP
- getOOBQueueSize() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getOOBQueueSize() - Method in class org.jgroups.protocols.TP
- getOOBThreadPool() - Method in class org.jgroups.protocols.TP
- getOOBThreadPoolThreadFactory() - Method in class org.jgroups.protocols.TP
- getOpenConnections() - Method in class org.jgroups.jmx.protocols.TCP
- getOpenConnections() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getOpenConnections() - Method in class org.jgroups.protocols.TCP_NIO
- getOpenConnections() - Method in class org.jgroups.protocols.TCP
- getOpt(int) - Method in class org.jgroups.Channel
-
Gets an option.
- getOpt(int) - Method in class org.jgroups.JChannel
-
returns the value of an option.
- getOriginalSender() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- getOutDelay() - Method in class org.jgroups.protocols.DELAY
- getOutputStream() - Method in class org.jgroups.util.ExposedDataOutputStream
- getOverhead() - Method in class org.jgroups.jmx.protocols.FRAG2
- getOverhead() - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- getOverhead() - Method in class org.jgroups.protocols.FRAG2
- getParameters() - Method in class org.jgroups.conf.ProtocolData
- getParametersAsArray() - Method in class org.jgroups.conf.ProtocolData
- getParameterString() - Method in class org.jgroups.conf.ProtocolParameter
- getParameterStringXml() - Method in class org.jgroups.conf.ProtocolParameter
- getPayload(String) - Method in class org.jgroups.View
- getPeerAddressReadTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
- getPendingRetransmissionRequests() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getPendingRetransmissionRequests() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getPendingRetransmissionRequests() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getPendingXmits() - Method in class org.jgroups.stack.NakReceiverWindow
- getPersistent() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getPersistent() - Method in class org.jgroups.blocks.ReplicatedHashMap
- getPingableMembers() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- getPingableMembers() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- getPingableMembers() - Method in class org.jgroups.jmx.protocols.FD
- getPingableMembers() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getPingableMembers() - Method in class org.jgroups.protocols.FD_SOCK
- getPingableMembers() - Method in class org.jgroups.protocols.FD
- getPingDest() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- getPingDest() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- getPingDest() - Method in class org.jgroups.jmx.protocols.FD
- getPingDest() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getPingDest() - Method in class org.jgroups.protocols.FD_SOCK
- getPingDest() - Method in class org.jgroups.protocols.FD
- getPingRequests() - Method in class org.jgroups.jmx.protocols.Discovery
- getPingRequests() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- getPort() - Method in class org.jgroups.stack.GossipRouter
- getPort() - Method in class org.jgroups.stack.IpAddress
- getPositiveVotes() - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
- getProcessorKeepAliveTime() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getProcessorKeepAliveTime() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getProcessorKeepAliveTime() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getProcessorKeepAliveTime() - Method in class org.jgroups.protocols.TCP_NIO
- getProcessorMaxThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getProcessorMaxThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getProcessorMaxThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getProcessorMaxThreads() - Method in class org.jgroups.protocols.TCP_NIO
- getProcessorMinThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getProcessorMinThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getProcessorMinThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getProcessorMinThreads() - Method in class org.jgroups.protocols.TCP_NIO
- getProcessorQueueSize() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getProcessorQueueSize() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getProcessorQueueSize() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getProcessorQueueSize() - Method in class org.jgroups.protocols.TCP_NIO
- getProcessorThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getProcessorThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getProcessorThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getProcessorThreads() - Method in class org.jgroups.protocols.TCP_NIO
- getProperties() - Method in class org.jgroups.JChannel
-
returns the protocol stack configuration in string format.
- getProperties() - Method in class org.jgroups.jmx.JChannel
- getProperties() - Method in interface org.jgroups.jmx.JChannelMBean
- getProperties() - Method in class org.jgroups.mux.MuxChannel
- getProperties() - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
- getProperties() - Method in class org.jgroups.stack.Protocol
- getPropertiesAsString() - Method in class org.jgroups.jmx.Protocol
- getPropertiesAsString() - Method in interface org.jgroups.jmx.ProtocolMBean
- getProperty(String[], Properties, String, boolean, String) - Static method in class org.jgroups.util.Util
-
Returns a value associated wither with one or more system properties, or found in the props map
- getProperty(Protocol, String) - Static method in class org.jgroups.util.Util
- getPropertyAsBoolean(String, boolean) - Static method in class org.jgroups.Global
- getPropertyAsInteger(String, int) - Static method in class org.jgroups.Global
- getPropertyAsLong(String, long) - Static method in class org.jgroups.Global
- getProtocolName() - Method in class org.jgroups.conf.ProtocolData
- getProtocolName() - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
- getProtocols() - Method in class org.jgroups.debug.ProtocolTester
- getProtocols() - Method in class org.jgroups.stack.ProtocolStack
-
Returns all protocols in a list, from top to bottom.
- getProtocolSpec() - Method in class org.jgroups.debug.ProtocolTester
- getProtocolStack() - Method in class org.jgroups.conf.PlainConfigurator
-
Throws a UnsupportedOperationException all the time.
- getProtocolStack() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
- getProtocolStack() - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolStack() - Method in class org.jgroups.JChannel
-
Returns the protocol stack.
- getProtocolStack() - Method in class org.jgroups.mux.MuxChannel
- getProtocolStack() - Method in class org.jgroups.stack.Protocol
- getProtocolStackString() - Method in class org.jgroups.conf.PlainConfigurator
-
returns the old style protocol string
- getProtocolStackString() - Method in interface org.jgroups.conf.ProtocolStackConfigurator
- getProtocolStackString() - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolStackString(boolean) - Method in class org.jgroups.conf.XmlConfigurator
- getProtocolString() - Method in class org.jgroups.conf.ProtocolData
- getProtocolString(boolean) - Method in class org.jgroups.conf.ProtocolData
- getProtocolStringNewXml() - Method in class org.jgroups.conf.ProtocolData
- getQuote(String) - Method in class org.jgroups.demos.QuoteServer
- getRandomSequence() - Method in class org.jgroups.demos.TotalTokenDemo.TotalPayload
- getRawBuffer() - Method in class org.jgroups.Message
-
Returns a reference to the payload (byte buffer).
- getRawBuffer() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
- getRawData() - Method in class org.jgroups.util.Headers
- getReaderThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getReaderThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getReaderThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getReaderThreads() - Method in class org.jgroups.protocols.TCP_NIO
- getReaperInterval() - Method in class org.jgroups.jmx.protocols.TCP
- getReaperInterval() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getReaperInterval() - Method in class org.jgroups.protocols.BasicTCP
- getReason() - Method in class org.jgroups.blocks.VotingAdapter.FailureVoteResult
- getReceiveBlockEvents() - Method in class org.jgroups.jmx.JChannel
- getReceiveBlockEvents() - Method in interface org.jgroups.jmx.JChannelMBean
- getReceiveBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
- getReceivedBroadcasts() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getReceivedBroadcasts() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getReceivedBroadcasts() - Method in class org.jgroups.protocols.SEQUENCER
- getReceivedBytes() - Method in class org.jgroups.JChannel
- getReceivedBytes() - Method in class org.jgroups.jmx.JChannel
- getReceivedBytes() - Method in interface org.jgroups.jmx.JChannelMBean
- getReceivedBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedBytes() - Method in class org.jgroups.protocols.STATS
- getReceivedForwards() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- getReceivedForwards() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- getReceivedForwards() - Method in class org.jgroups.protocols.SEQUENCER
- getReceivedMcastBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedMcastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedMcastBytes() - Method in class org.jgroups.protocols.STATS
- getReceivedMcastMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedMcastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedMcastMessages() - Method in class org.jgroups.protocols.STATS
- getReceivedMessages() - Method in class org.jgroups.JChannel
- getReceivedMessages() - Method in class org.jgroups.jmx.JChannel
- getReceivedMessages() - Method in interface org.jgroups.jmx.JChannelMBean
- getReceivedMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedMessages() - Method in class org.jgroups.protocols.STATS
- getReceivedTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getReceivedUnicastBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedUnicastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedUnicastBytes() - Method in class org.jgroups.protocols.STATS
- getReceivedUnicastMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getReceivedUnicastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getReceivedUnicastMessages() - Method in class org.jgroups.protocols.STATS
- getReceiveInterfaces() - Method in class org.jgroups.jmx.protocols.MPING
- getReceiveInterfaces() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getReceiveInterfaces() - Method in class org.jgroups.jmx.protocols.TP
- getReceiveInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getReceiveInterfaces() - Method in class org.jgroups.protocols.MPING
- getReceiveInterfaces() - Method in class org.jgroups.protocols.TP
- getReceiveLocalMessages() - Method in class org.jgroups.jmx.JChannel
- getReceiveLocalMessages() - Method in interface org.jgroups.jmx.JChannelMBean
- getReceiver() - Method in class org.jgroups.Channel
- getReconnectInterval() - Method in class org.jgroups.protocols.TUNNEL
- getRefreshInterval() - Method in class org.jgroups.stack.GossipClient
- getReplenishmentsReceived() - Method in class org.jgroups.jmx.protocols.SFC
- getReplenishmentsReceived() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getReplenishmentsReceived() - Method in class org.jgroups.protocols.SFC
- getReplenishmentsSent() - Method in class org.jgroups.jmx.protocols.SFC
- getReplenishmentsSent() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getReplenishmentsSent() - Method in class org.jgroups.protocols.SFC
- getRequestMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
- getRequestor() - Method in class org.jgroups.GetStateEvent
- getResourceAsStream(String, Class) - Static method in class org.jgroups.util.Util
- getResponseMarshaller() - Method in class org.jgroups.blocks.RpcDispatcher
- getResult() - Method in class org.jgroups.util.Promise
- getResult(long) - Method in class org.jgroups.util.Promise
-
Returns the result, but never throws a TimeoutException; returns null instead.
- getResults() - Method in class org.jgroups.blocks.GroupRequest
-
Returns the results as a RspList
- getResults() - Method in class org.jgroups.util.ResponseCollector
- getResults() - Method in class org.jgroups.util.RspList
-
Returns the results from non-suspected members that are not null.
- getResultWithTimeout(long) - Method in class org.jgroups.util.Promise
-
Blocks until a result is available, or timeout milliseconds have elapsed
- getRouterHost() - Method in class org.jgroups.protocols.TUNNEL
- getRouterPort() - Method in class org.jgroups.protocols.TUNNEL
- getRoutingClientReplyTimeout() - Method in class org.jgroups.stack.GossipRouter
-
Deprecated.
- getSeenList() - Method in class org.jgroups.protocols.pbcast.Gossip
- getSendBufferSize() - Method in class org.jgroups.blocks.BasicConnectionTable
- getSender() - Method in class org.jgroups.protocols.pbcast.MergeData
- getSender() - Method in class org.jgroups.util.Rsp
- getSenderIndex() - Method in class org.jgroups.protocols.TransportedVectorTime
-
Returns sender index
- getSenders() - Method in class org.jgroups.util.Digest
-
Returns an unmodifiable map, so modifications will result in exceptions
- getSenders() - Method in class org.jgroups.util.MutableDigest
- getSendInterfaces() - Method in class org.jgroups.jmx.protocols.MPING
- getSendInterfaces() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getSendInterfaces() - Method in class org.jgroups.jmx.protocols.TP
- getSendInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
- getSendInterfaces() - Method in class org.jgroups.protocols.MPING
- getSendInterfaces() - Method in class org.jgroups.protocols.TP
- getSendQueueSize() - Method in class org.jgroups.blocks.BasicConnectionTable
- getSentBytes() - Method in class org.jgroups.JChannel
- getSentBytes() - Method in class org.jgroups.jmx.JChannel
- getSentBytes() - Method in interface org.jgroups.jmx.JChannelMBean
- getSentBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getSentBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentBytes() - Method in class org.jgroups.protocols.STATS
- getSentMcastBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getSentMcastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentMcastBytes() - Method in class org.jgroups.protocols.STATS
- getSentMcastMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getSentMcastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentMcastMessages() - Method in class org.jgroups.protocols.STATS
- getSentMessages() - Method in class org.jgroups.JChannel
- getSentMessages() - Method in class org.jgroups.jmx.JChannel
- getSentMessages() - Method in interface org.jgroups.jmx.JChannelMBean
- getSentMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getSentMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentMessages() - Method in class org.jgroups.protocols.STATS
- getSentUnicastBytes() - Method in class org.jgroups.jmx.protocols.STATS
- getSentUnicastBytes() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentUnicastBytes() - Method in class org.jgroups.protocols.STATS
- getSentUnicastMessages() - Method in class org.jgroups.jmx.protocols.STATS
- getSentUnicastMessages() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- getSentUnicastMessages() - Method in class org.jgroups.protocols.STATS
- getSeqno() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- getServer() - Method in class org.jgroups.JChannelFactory
- getServerObject() - Method in class org.jgroups.blocks.RpcDispatcher
- getServerPubKey() - Method in class org.jgroups.protocols.ENCRYPT
- getServiceAckTimeout() - Method in class org.jgroups.mux.Multiplexer
- getServiceIds() - Method in class org.jgroups.mux.Multiplexer
- getServicesResponseTimeout() - Method in class org.jgroups.mux.Multiplexer
- getSingletonName() - Method in class org.jgroups.protocols.TP
- getSingletonTransports() - Static method in class org.jgroups.stack.ProtocolStack
- getSmoothedAverageRetransmissionTime(Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Returns the smoothed average retransmission time for a given sender
- getSmoothedLossRate() - Method in class org.jgroups.stack.NakReceiverWindow
- getSocketConnectionTimeout() - Method in class org.jgroups.blocks.BasicConnectionTable
- getSocketConnectionTimeout() - Method in class org.jgroups.stack.GossipClient
- getSocketReadTimeout() - Method in class org.jgroups.stack.GossipClient
- getSocketReadTimeout() - Method in class org.jgroups.stack.GossipRouter
- getSrc() - Method in class org.jgroups.Message
- getStabilityReceived() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getStabilityReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getStabilityReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
- getStabilitySent() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getStabilitySent() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getStabilitySent() - Method in class org.jgroups.protocols.pbcast.STABLE
- getStableMessages() - Method in class org.jgroups.stack.AckMcastSenderWindow
- getStableReceived() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getStableReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getStableReceived() - Method in class org.jgroups.protocols.pbcast.STABLE
- getStableSent() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- getStableSent() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- getStableSent() - Method in class org.jgroups.protocols.pbcast.STABLE
- getStackConfigurator(File) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the XML configuration provided by the specified File.
- getStackConfigurator(Object) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Deprecated.Used by the JChannel(Object) constructor which has been deprecated.
- getStackConfigurator(String) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the provided properties string.
- getStackConfigurator(URL) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Returns a protocol stack configurator based on the XML configuration provided at the specified URL.
- 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.
- getStackName() - Method in class org.jgroups.mux.MuxChannel
- getStackTrace(Throwable) - Static method in class org.jgroups.util.Util
- getStartFlushTimeout() - Method in class org.jgroups.protocols.pbcast.FLUSH
- getStartPort() - Method in class org.jgroups.jmx.protocols.TCP
- getStartPort() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- getStartPort() - Method in class org.jgroups.protocols.BasicTCP
- getState() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- 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.ReplicatedHashMap
- getState() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- getState() - Method in class org.jgroups.blocks.ReplicatedTree
-
Return a copy of the current cache (tree)
- getState() - Method in class org.jgroups.blocks.VotingAdapter
-
Get the channel state.
- getState() - Method in class org.jgroups.demos.ChatCore
- getState() - Method in class org.jgroups.demos.Draw
- getState() - Method in class org.jgroups.demos.QuoteServer
- getState() - Method in class org.jgroups.demos.wb.GraphPanel
- getState() - Method in class org.jgroups.demos.wb.Whiteboard
- getState() - Method in class org.jgroups.ExtendedReceiverAdapter
- getState() - Method in interface org.jgroups.MessageListener
-
Answers the group state; e.g., when joining.
- getState() - Method in class org.jgroups.ReceiverAdapter
- getState(OutputStream) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getState(OutputStream) - Method in class org.jgroups.blocks.MessageListenerAdapter
- getState(OutputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
- getState(OutputStream) - Method in class org.jgroups.demos.Draw
- getState(OutputStream) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to write a state through a provided OutputStream.
- getState(OutputStream) - Method in class org.jgroups.ExtendedReceiverAdapter
- getState(String) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getState(String) - Method in class org.jgroups.blocks.MessageListenerAdapter
- getState(String) - Method in class org.jgroups.blocks.ReplicatedHashMap
- getState(String) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to provide a partial state as a byte array
- getState(String) - Method in class org.jgroups.ExtendedReceiverAdapter
- getState(String, OutputStream) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- getState(String, OutputStream) - Method in class org.jgroups.blocks.MessageListenerAdapter
- getState(String, OutputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
- getState(String, OutputStream) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to write a partial state through a provided OutputStream.
- getState(String, OutputStream) - Method in class org.jgroups.ExtendedReceiverAdapter
- getState(Address, long) - Method in class org.jgroups.Channel
-
Retrieve the state of the group.
- getState(Address, long) - Method in class org.jgroups.JChannel
-
Retrieves a full state from the target member.
- getState(Address, long) - Method in class org.jgroups.jmx.JChannel
- getState(Address, long) - Method in interface org.jgroups.jmx.JChannelMBean
- getState(Address, String, long) - Method in class org.jgroups.Channel
-
Fetches a partial state identified by state_id.
- getState(Address, String, long) - Method in class org.jgroups.JChannel
-
Retrieves a substate (or partial state) indicated by state_id from the target member.
- getState(Address, String, long, boolean) - Method in class org.jgroups.JChannel
-
Retrieves a substate (or partial state) indicated by state_id from the target member.
- getState(Address, String, long, boolean) - Method in class org.jgroups.mux.MuxChannel
- getState(Address, String, long, Callable<Boolean>) - Method in class org.jgroups.JChannel
-
Retrieves a substate (or partial state) indicated by state_id from the target member.
- GetStateEvent - Class in org.jgroups
-
Represents a GetState event.
- GetStateEvent(Object, String) - Constructor for class org.jgroups.GetStateEvent
- getStateId() - Method in class org.jgroups.GetStateEvent
- getStateId() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- getStateId() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- getStateId() - Method in class org.jgroups.SetStateEvent
- getStateId() - Method in class org.jgroups.StreamingGetStateEvent
-
Returns id of the partial state if partial state was requested.
- getStateId() - Method in class org.jgroups.StreamingSetStateEvent
-
Returns id of the partial state if partial state was requested.
- getStatsEnabled() - Method in class org.jgroups.jmx.JChannel
- getStatsEnabled() - Method in interface org.jgroups.jmx.JChannelMBean
- getStatsEnabled() - Method in class org.jgroups.jmx.Protocol
- getStatsEnabled() - Method in interface org.jgroups.jmx.ProtocolMBean
- getSubgroups() - Method in class org.jgroups.MergeView
- getSuspectedMembers() - Method in class org.jgroups.util.RspList
- getSuspectEventsSent() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getSuspectEventsSent() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getSuspectEventsSent() - Method in class org.jgroups.protocols.FD_ALL
- getSuspects() - Method in class org.jgroups.blocks.GroupRequest
-
Returns the list of suspected members.
- getSuspended() - Method in class org.jgroups.jmx.protocols.MERGE2
- getSuspended() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- getSuspended() - Method in class org.jgroups.protocols.MERGE2
- getSymAlgorithm() - Method in class org.jgroups.protocols.ENCRYPT
- getSymDecodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
- getSymEncodingCipher() - Method in class org.jgroups.protocols.ENCRYPT
- getSymInit() - Method in class org.jgroups.protocols.ENCRYPT
- getSymProvider() - Static method in class org.jgroups.protocols.ENCRYPT
- getTcpNodelay() - Method in class org.jgroups.blocks.BasicConnectionTable
- getThread() - Method in class org.jgroups.protocols.UDP.UcastReceiver
- getThread() - Method in class org.jgroups.util.ThreadPool
- getThreadDecorator() - Method in class org.jgroups.util.DefaultThreadFactory
- getThreadDecorator() - Method in interface org.jgroups.util.ThreadManager
-
Gets the ThreadDecorator associated with this manager.
- getThreadDecorator() - Method in class org.jgroups.util.ThreadManagerThreadPoolExecutor
- getThreadDecorator() - Method in class org.jgroups.util.TimeScheduler
- getThreadFactory() - Method in class org.jgroups.blocks.BasicConnectionTable
- getThreadFactory() - Method in class org.jgroups.protocols.TP
- getThreadFactory() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- getThreadFactory() - Method in class org.jgroups.stack.Protocol
-
Supposed to be overwritten by subclasses.
- getThreadFactory() - Method in class org.jgroups.stack.ProtocolStack
-
Deprecated.Use
Protocol.getThreadFactory()
instead - getThreadNamingPattern() - Method in class org.jgroups.protocols.TP
- getThreadPoolKeepAliveTime() - Method in class org.jgroups.stack.GossipRouter
- getThreadPoolMaxThreads() - Method in class org.jgroups.stack.GossipRouter
- getThreadPoolMinThreads() - Method in class org.jgroups.stack.GossipRouter
- getThreadPoolQueueMaxSize() - Method in class org.jgroups.stack.GossipRouter
- getThreadPoolRejectionPolicy() - Method in class org.jgroups.stack.GossipRouter
- getTimeout() - Method in class org.jgroups.blocks.ReplicatedHashMap
-
The timeout (in milliseconds) for blocking updates
- getTimeout() - Method in class org.jgroups.jmx.protocols.Discovery
- getTimeout() - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- getTimeout() - Method in class org.jgroups.jmx.protocols.FD_ALL
- getTimeout() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- getTimeout() - Method in class org.jgroups.jmx.protocols.FD
- getTimeout() - Method in interface org.jgroups.jmx.protocols.FDMBean
- getTimeout() - Method in class org.jgroups.protocols.Discovery
- getTimeout() - Method in class org.jgroups.protocols.FD_ALL
- getTimeout() - Method in class org.jgroups.protocols.FD
- getTimeout() - Method in class org.jgroups.util.AgeOutCache
- getTimer() - Method in class org.jgroups.protocols.TP
- getTimerThreadFactory() - Method in class org.jgroups.protocols.TP
- getTimerThreadFactory() - Static method in class org.jgroups.stack.ProtocolStack
-
Deprecated.
- getTimerThreads() - Method in class org.jgroups.JChannel
- getTimerThreads() - Method in class org.jgroups.jmx.JChannel
- getTimerThreads() - Method in interface org.jgroups.jmx.JChannelMBean
- getTimerThreads() - Method in class org.jgroups.stack.ProtocolStack
-
Deprecated.Use
TP.getTimer()
to fetch the timer and call getCorePoolSize() directly - getToken() - Method in class org.jgroups.protocols.AuthHeader
-
Used to get the token from the AuthHeader
- getTop() - Method in class org.jgroups.debug.ProtocolTester
- getTotalAverageRetransmissionTime() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getTotalAverageSmoothedRetransmissionTime() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getTotalAvgSmoothedXmitTime() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getTotalAvgSmoothedXmitTime() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getTotalAvgXmitTime() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getTotalAvgXmitTime() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getTotalBlockingTime() - Method in class org.jgroups.jmx.protocols.SFC
- getTotalBlockingTime() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- getTotalBlockingTime() - Method in class org.jgroups.protocols.SFC
- getTotalTime() - Method in class org.jgroups.protocols.PERF_TP
- getTotalTimeBlocked() - Method in class org.jgroups.jmx.protocols.FC
- getTotalTimeBlocked() - Method in interface org.jgroups.jmx.protocols.FCMBean
- getTotalTimeBlocked() - Method in class org.jgroups.protocols.FC
- getTotalTimeInFlush() - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- getTotalTimeInFlush() - Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
- getTotalTimeInFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
- getTransport() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- getTransport() - Method in class org.jgroups.stack.Protocol
- getTransport() - Method in class org.jgroups.stack.ProtocolStack
-
Returns the bottom most protocol
- getTTL() - Method in class org.jgroups.jmx.protocols.MPING
- getTTL() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- getTTL() - Method in class org.jgroups.protocols.MPING
- getType() - Method in class org.jgroups.Event
- getType() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- getType() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- getType() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
- getType() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- getType() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- getType() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- getType() - Method in class org.jgroups.stack.GossipData
- getUnackedMessages() - Method in class org.jgroups.jmx.protocols.UNICAST
- getUnackedMessages() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getUnackedMessages() - Method in class org.jgroups.protocols.UNICAST
- getUpDiscardRate() - Method in class org.jgroups.protocols.DISCARD
- getUpProtocol() - Method in class org.jgroups.stack.Protocol
- getUpProtocols() - Method in class org.jgroups.protocols.TP
- getUserName() - Method in class org.jgroups.demos.wb.UserInfoDialog
- getUseSendQueues() - Method in class org.jgroups.blocks.BasicConnectionTable
- getVal1() - Method in class org.jgroups.util.Triple
- getVal1() - Method in class org.jgroups.util.Tuple
- getVal2() - Method in class org.jgroups.util.Triple
- getVal2() - Method in class org.jgroups.util.Tuple
- getVal3() - Method in class org.jgroups.util.Triple
- getValue() - Method in class org.jgroups.conf.ProtocolParameter
- getValue() - Method in class org.jgroups.util.Rsp
- getValue(Object) - Method in class org.jgroups.util.RspList
-
Returns the value associated with address key
- getValues() - Method in class org.jgroups.protocols.TransportedVectorTime
-
Returns vector values
- getVectorTime() - Method in class org.jgroups.protocols.CAUSAL.CausalHeader
-
Returns a vector timestamp carreid by this header
- getVersion() - Method in class org.jgroups.jmx.JChannel
- getVersion() - Method in interface org.jgroups.jmx.JChannelMBean
- getVersion() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- getVid() - Method in class org.jgroups.View
-
returns the view ID of this view if this view was created with the empty constructur, null will be returned
- getView() - Method in class org.jgroups.Channel
-
Gets the current view.
- getView() - Method in class org.jgroups.JChannel
-
Returns the current view.
- getView() - Method in class org.jgroups.jmx.JChannel
- getView() - Method in interface org.jgroups.jmx.JChannelMBean
- getView() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getView() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getView() - Method in class org.jgroups.mux.MuxChannel
-
Returns the service view, ie.
- getView() - Method in class org.jgroups.protocols.pbcast.GMS
- getView() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- getView() - Method in class org.jgroups.protocols.pbcast.MergeData
- getView() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- getViewAckCollectionTimeout() - Method in class org.jgroups.protocols.pbcast.GMS
- getViewAsString() - Method in class org.jgroups.jmx.JChannel
- getViewAsString() - Method in interface org.jgroups.jmx.JChannelMBean
- getViewHandlerQueue() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- getViewHandlerQueue() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- getVoteChannel() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
- getWriterThreads() - Method in class org.jgroups.blocks.ConnectionTableNIO
- getWriterThreads() - Method in class org.jgroups.jmx.protocols.TCP_NIO
- getWriterThreads() - Method in interface org.jgroups.jmx.protocols.TCP_NIOMBean
- getWriterThreads() - Method in class org.jgroups.protocols.TCP_NIO
- getXmitRequestsReceived() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getXmitRequestsReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getXmitRequestsReceived() - Method in class org.jgroups.jmx.protocols.UNICAST
- getXmitRequestsReceived() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- getXmitRequestsReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getXmitRequestsSent() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getXmitRequestsSent() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getXmitRequestsSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getXmitResponsesReceived() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getXmitResponsesReceived() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getXmitResponsesReceived() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getXmitResponsesSent() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getXmitResponsesSent() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getXmitResponsesSent() - Method in class org.jgroups.protocols.pbcast.NAKACK
- getXmitTableSize() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- getXmitTableSize() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- getXmitTableSize() - Method in class org.jgroups.protocols.pbcast.NAKACK
- Global - Class in org.jgroups
-
Globals used by JGroups packages.
- Global() - Constructor for class org.jgroups.Global
- global_thread_factory - Variable in class org.jgroups.protocols.TP
-
Used by all threads created by JGroups outside of the thread pools
- gms - Variable in class org.jgroups.protocols.pbcast.GmsImpl
- GMS - Class in org.jgroups.jmx.protocols.pbcast
- GMS - Class in org.jgroups.protocols.pbcast
-
Group membership protocol.
- GMS() - Constructor for class org.jgroups.jmx.protocols.pbcast.GMS
- GMS() - Constructor for class org.jgroups.protocols.pbcast.GMS
- GMS(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.GMS
- GMS.GmsHeader - Class in org.jgroups.protocols.pbcast
- GmsHeader() - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GmsHeader(byte) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
- GmsHeader(byte, Address) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
Used for JOIN_REQ or LEAVE_REQ header
- GmsHeader(byte, JoinRsp) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
Used for JOIN_RSP header
- GmsHeader(byte, View) - Constructor for class org.jgroups.protocols.pbcast.GMS.GmsHeader
-
Used for VIEW header
- GmsImpl - Class in org.jgroups.protocols.pbcast
- GmsImpl() - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
- GmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.GmsImpl
- GmsImpl.Request - Class in org.jgroups.protocols.pbcast
- GMSMBean - Interface in org.jgroups.jmx.protocols.pbcast
- go() - Method in class org.jgroups.demos.applets.DrawApplet
- go() - Method in class org.jgroups.demos.Draw
- go() - Method in class org.jgroups.demos.Draw2Channels
- go() - Method in class org.jgroups.demos.DrawRepl
- go() - Method in class org.jgroups.demos.Gossip
- Gossip - Class in org.jgroups.demos
-
Demos that tries to graphically illustrating the gossip (or pbcast) protocol: every sender periodically sends a DRAW command to a random subset of the group members.
- Gossip - Class in org.jgroups.protocols.pbcast
- Gossip(String, long) - Constructor for class org.jgroups.demos.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
- GOSSIP_GET - Static variable in class org.jgroups.stack.GossipRouter
- GOSSIP_REQUEST_TIMEOUT - Static variable in class org.jgroups.stack.GossipRouter
- GossipClient - Class in org.jgroups.stack
-
Local stub for clients to access one (or more) GossipRouters.
- GossipClient(Vector<IpAddress>, long) - Constructor for class org.jgroups.stack.GossipClient
-
Creates the GossipClient
- GossipClient(Vector<IpAddress>, long, int) - Constructor for class org.jgroups.stack.GossipClient
- GossipClient(IpAddress, long) - Constructor for class org.jgroups.stack.GossipClient
-
Creates the GossipClient
- GossipData - Class in org.jgroups.stack
-
Encapsulates data sent between GossipRouter and GossipClient
- GossipData() - Constructor for class org.jgroups.stack.GossipData
- GossipData(byte) - Constructor for class org.jgroups.stack.GossipData
- GossipData(byte, String, Address, List) - Constructor for class org.jgroups.stack.GossipData
- GossipRouter - Class in org.jgroups.stack
-
Router for TCP based group comunication (using layer TCP instead of UDP).
- GossipRouter() - Constructor for class org.jgroups.stack.GossipRouter
- GossipRouter(int) - Constructor for class org.jgroups.stack.GossipRouter
- GossipRouter(int, String) - Constructor for class org.jgroups.stack.GossipRouter
- GossipRouter(int, String, long) - Constructor for class org.jgroups.stack.GossipRouter
- GossipRouter(int, String, long, long, long) - Constructor for class org.jgroups.stack.GossipRouter
-
Creates a gossip router on a given port bound to a specified interface and an expiry time (in msecs) until a cached 'gossip' member entry expires.
- GraphPanel - Class in org.jgroups.demos.wb
- GraphPanel(Whiteboard) - Constructor for class org.jgroups.demos.wb.GraphPanel
- group - Variable in class org.jgroups.util.DefaultThreadFactory
- group_addr - Variable in class org.jgroups.protocols.TcpHeader
- GROUP_NAME_PROPERTY - Static variable in class org.jgroups.protocols.JMS
- groupname - Variable in class org.jgroups.blocks.DistributedQueue
- groupname - Static variable in class org.jgroups.demos.wb.Whiteboard
- GroupRequest - Class in org.jgroups.blocks
-
Sends a message to all members of the group and waits for all responses (or timeout).
- GroupRequest(Message, RequestCorrelator, Vector<Address>, int) - Constructor for class org.jgroups.blocks.GroupRequest
- GroupRequest(Message, RequestCorrelator, Vector<Address>, int, long, int) - Constructor for class org.jgroups.blocks.GroupRequest
- GroupRequest(Message, Transport, Vector<Address>, int) - Constructor for class org.jgroups.blocks.GroupRequest
- GroupRequest(Message, Transport, Vector<Address>, int, long, int) - Constructor for class org.jgroups.blocks.GroupRequest
- GuardedBy - Annotation Type in org.jgroups.annotations
-
Copyright (c) 2005 Brian Goetz and Tim Peierls Released under the Creative Commons Attribution License (http://creativecommons.org/licenses/by/2.5) Official home: http://www.jcip.net Adopted from Java Concurrency in Practice.
H
- handle(Message) - Method in class org.jgroups.blocks.MessageDispatcher
- handle(Message) - Method in interface org.jgroups.blocks.RequestHandler
- handle(Message) - Method in class org.jgroups.blocks.RpcDispatcher
-
Message contains MethodCall.
- handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.TP
- handleConfigEvent(Map<String, Object>) - Method in class org.jgroups.protocols.UDP
- handleConnect() - Method in class org.jgroups.protocols.Discovery
- handleConnect() - Method in class org.jgroups.protocols.PING
- handleConnect() - Method in class org.jgroups.protocols.TCPGOSSIP
- handleConnect() - Method in class org.jgroups.protocols.TP
- handleConnect() - Method in class org.jgroups.protocols.UDP
- handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleDigestResponse(Address, Digest) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleDisconnect() - Method in class org.jgroups.protocols.Discovery
- handleDisconnect() - Method in class org.jgroups.protocols.PING
- handleDisconnect() - Method in class org.jgroups.protocols.TCPGOSSIP
- handleDisconnect() - Method in class org.jgroups.protocols.TP
- handleDisconnect() - Method in class org.jgroups.protocols.UDP
- handleDownEvent(Event) - Method in class org.jgroups.protocols.BasicTCP
- handleDownEvent(Event) - Method in class org.jgroups.protocols.JMS
-
Handle down event, if it is not a Event.MSG type.
- handleDownEvent(Event) - Method in class org.jgroups.protocols.TP
- handleDownEvent(Event) - Method in class org.jgroups.protocols.TUNNEL
- handleExit() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleExit() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- 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
-
In case we get a different JOIN_RSP from a previous JOIN_REQ sent by us (as a client), we simply apply the new view if it is greater than ours
- handleLeave() - Method in class org.jgroups.demos.ChatCore
- 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
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMembershipChange(Collection<GmsImpl.Request>) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- handleMergeCancelled(ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleMergeCancelled(ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeRequest(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
Get the view and digest and send back both (MergeData) in the form of a MERGE_RSP to the sender.
- handleMergeRequest(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeRequest(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- handleMergeResponse(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- handleMergeResponse(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMergeView(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
If merge_id is not equal to this.merge_id then discard.
- handleMergeView(MergeData, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleMessage(Message) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.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
- handleProbe(String...) - Method in interface org.jgroups.protocols.TP.ProbeHandler
-
Handles a probe.
- handler - Variable in class org.jgroups.blocks.MessageDispatcher
- handleRequest(Message, RequestCorrelator.Header) - Method in class org.jgroups.blocks.RequestCorrelator
-
Handle a request msg for this correlator
- handleSend(String) - Method in class org.jgroups.demos.ChatCore
- handleUpEvent(Event) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- handleView(View) - Method in class org.jgroups.util.AckCollector
- 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.
- hasAllResponses() - Method in class org.jgroups.util.ResponseCollector
- 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.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
- 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.pbcast.Gossip
- hashCode() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- hashCode() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- hashCode() - Method in class org.jgroups.protocols.PingRsp
- hashCode() - Method in class org.jgroups.stack.IpAddress
- hashCode() - Method in class org.jgroups.util.UnmodifiableVector
- hashCode() - Method in class org.jgroups.View
- hashCode() - Method in class org.jgroups.ViewId
- hasMessagesToRemove() - Method in class org.jgroups.stack.AckReceiverWindow
- hasMessagesToRemove() - Method in class org.jgroups.stack.NakReceiverWindow
- hasMuxChannel(String, String) - Method in class org.jgroups.JChannelFactory
-
Returns true if this factory has already registered MuxChannel with given stack_name and an id, false otherwise.
- hasResult() - Method in class org.jgroups.util.Promise
-
Checks whether result is available.
- HDR_OVERHEAD - Static variable in class org.jgroups.Header
- HDRS - Class in org.jgroups.protocols
-
Example of a protocol layer.
- HDRS() - Constructor for class org.jgroups.protocols.HDRS
- Header - Class in org.jgroups
-
Abstract base class for all headers to be added to a Message.
- Header() - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
-
Used for externalization
- Header() - Constructor for class org.jgroups.Header
- Header() - Constructor for class org.jgroups.protocols.FD_ALL.Header
-
used for externalization
- Header() - Constructor for class org.jgroups.protocols.SFC.Header
- Header(byte) - Constructor for class org.jgroups.protocols.FD_ALL.Header
- Header(byte) - Constructor for class org.jgroups.protocols.SFC.Header
- Header(byte, long, boolean, String) - Constructor for class org.jgroups.blocks.RequestCorrelator.Header
- Header(byte, Address) - Constructor for class org.jgroups.protocols.FD_ALL.Header
- headers - Variable in class org.jgroups.Message
-
All headers are placed here
- Headers - Class in org.jgroups.util
-
Open addressing based implementation of a hashmap (not supporting the Map interface though) for message headers.
- Headers(int) - Constructor for class org.jgroups.util.Headers
- Headers(Headers) - Constructor for class org.jgroups.util.Headers
- HEARD_FROM - Static variable in class org.jgroups.Event
- HEARTBEAT - Static variable in class org.jgroups.protocols.FD_ALL.Header
- HEARTBEAT - Static variable in class org.jgroups.protocols.FD.FdHeader
- HEARTBEAT_ACK - Static variable in class org.jgroups.protocols.FD.FdHeader
- height - Variable in class org.jgroups.demos.wb.Node
- high - Variable in class org.jgroups.util.Range
- HIGH_PRIO - Static variable in class org.jgroups.Message
- highestDeliveredSeqnoAt(Address) - Method in class org.jgroups.util.Digest
- highestReceivedSeqnoAt(Address) - Method in class org.jgroups.util.Digest
- highestSequence(Digest) - Method in class org.jgroups.util.Digest
- HTOTAL - Class in org.jgroups.protocols
-
Implementation of UTO-TCP as designed by EPFL.
- HTOTAL() - Constructor for class org.jgroups.protocols.HTOTAL
- HTOTAL.HTotalHeader - Class in org.jgroups.protocols
- HTotalHeader() - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
- HTotalHeader(Address, Address) - Constructor for class org.jgroups.protocols.HTOTAL.HTotalHeader
I
- I_HAVE_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- id - 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.protocols.FragHeader
- ID - Static variable in class org.jgroups.blocks.MethodCall
-
Use an ID to map to a method
- IGNORE_BIND_ADDRESS_PROPERTY - Static variable in class org.jgroups.Global
- IGNORE_BIND_ADDRESS_PROPERTY_OLD - Static variable in class org.jgroups.Global
- Immutable - Annotation Type in org.jgroups.annotations
-
Copyright (c) 2005 Brian Goetz and Tim Peierls Released under the Creative Commons Attribution License (http://creativecommons.org/licenses/by/2.5) Official home: http://www.jcip.net Adopted from Java Concurrency in Practice.
- includeClusterName - Variable in class org.jgroups.util.DefaultThreadFactory
- includeLocalAddress - Variable in class org.jgroups.util.DefaultThreadFactory
- incoming_copies - Variable in class org.jgroups.protocols.DUPL
- incrementHighestDeliveredSeqno(Address) - Method in class org.jgroups.util.MutableDigest
-
Increments the sender's high_seqno by 1.
- indexOf(Object) - Method in class org.jgroups.util.UnmodifiableVector
- indexOf(Object, int) - Method in class org.jgroups.util.UnmodifiableVector
- info - Variable in class org.jgroups.JChannel
- INFO - Static variable in class org.jgroups.Event
- init() - Method in class org.jgroups.blocks.ConnectionTable
- init() - Method in class org.jgroups.blocks.ConnectionTableNIO
- init() - Method in class org.jgroups.blocks.DistributedQueue
- init() - Method in class org.jgroups.blocks.ReplicatedHashMap
- init() - Method in class org.jgroups.conf.ClassConfigurator
- init() - Method in class org.jgroups.demos.applets.DrawApplet
- init() - Method in class org.jgroups.demos.wb.Whiteboard
- init() - Method in class org.jgroups.protocols.AUTOCONF
- init() - Method in class org.jgroups.protocols.BARRIER
- init() - Method in class org.jgroups.protocols.BasicTCP
- init() - Method in class org.jgroups.protocols.BSH
- init() - Method in class org.jgroups.protocols.COMPRESS
- init() - Method in class org.jgroups.protocols.Discovery
- init() - Method in class org.jgroups.protocols.DUMMY_TP
- init() - Method in class org.jgroups.protocols.ENCRYPT
- init() - Method in class org.jgroups.protocols.FD_ALL
- init() - Method in class org.jgroups.protocols.FD_ICMP
- init() - Method in class org.jgroups.protocols.FD_SIMPLE
- init() - Method in class org.jgroups.protocols.FD_SOCK
- init() - Method in class org.jgroups.protocols.FD
- init() - Method in class org.jgroups.protocols.FRAG
- init() - Method in class org.jgroups.protocols.FRAG2
- init() - Method in class org.jgroups.protocols.LOOPBACK
- init() - Method in class org.jgroups.protocols.MERGE2
- init() - Method in class org.jgroups.protocols.MERGE3
- init() - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.GMS
- init() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.NAKACK
- init() - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- init() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- init() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- init() - Method in class org.jgroups.protocols.PERF_TP
- init() - Method in class org.jgroups.protocols.PING
- init() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- init() - Method in class org.jgroups.protocols.SIZE
- init() - Method in class org.jgroups.protocols.TP
- init() - Method in class org.jgroups.protocols.TUNNEL
- init() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- init() - Method in class org.jgroups.stack.Protocol
-
Called after instance has been created (null constructor) and before protocol is started.
- init(long) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- init(InputStream) - Method in class org.jgroups.persistence.DBPersistenceManager
-
used to intitiailize complete DB access.
- init(ProtocolStackConfigurator) - Method in class org.jgroups.JChannel
- 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
- initKeyPair() - Method in class org.jgroups.protocols.ENCRYPT
-
Generates the public/private key pair from the init params
- initProtocolStack(List<Protocol>) - Static method in class org.jgroups.stack.Configurator
- initSymKey() - Static method in class org.jgroups.demos.KeyStoreGenerator
- initSymKey() - Method in class org.jgroups.protocols.ENCRYPT
-
Used to initialise the symmetric key if none is supplied in a keystore.
- inputStream - Variable in class org.jgroups.stack.StateTransferInfo
- insertElementAt(Object, int) - Method in class org.jgroups.util.UnmodifiableVector
- insertProtocol(Protocol, int, Class<? extends Protocol>) - Method in class org.jgroups.stack.ProtocolStack
- insertProtocol(Protocol, int, Class<? extends Protocol>, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
- insertProtocol(Protocol, int, String) - Method in class org.jgroups.stack.ProtocolStack
-
Inserts an already created (and initialized) protocol into the protocol list.
- insertProtocol(Protocol, int, String, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
Inserts an already created (and initialized) protocol into the protocol list.
- insertProtocol(Protocol, int, Protocol) - Method in class org.jgroups.stack.ProtocolStack
- insertProtocol(Protocol, int, Protocol, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
- insertProtocol(Protocol, Protocol, int) - Static method in class org.jgroups.stack.Configurator
- INSTALL_MERGE_VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- INSTALL_MERGE_VIEW_OK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- installView(View) - Method in class org.jgroups.protocols.pbcast.GMS
- installView(View, Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Sets the new view and sends a VIEW_CHANGE event up and down the stack.
- INT_SIZE - Static variable in class org.jgroups.Global
- internalQueue - Variable in class org.jgroups.blocks.DistributedQueue
- interruptAndWaitToDie(Thread) - Static method in class org.jgroups.util.Util
- interruptAndWaitToDie(Thread, long) - Static method in class org.jgroups.util.Util
- Interval - Interface in org.jgroups.stack
-
Interface which returns a time series, one value at a time calling next()
- invoke(Object) - Method in class org.jgroups.blocks.MethodCall
-
Invokes the method with the supplied arguments against the target object.
- invoke(Object, Object[]) - Method in class org.jgroups.blocks.MethodCall
- IpAddress - Class in org.jgroups.stack
-
Network-dependent address (Internet).
- IpAddress() - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(int) - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(int, boolean) - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(String, int) - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(InetAddress, int) - Constructor for class org.jgroups.stack.IpAddress
- IpAddress(InetSocketAddress) - Constructor for class org.jgroups.stack.IpAddress
- IPV4_SIZE - Static variable in class org.jgroups.Global
- IPV6_SIZE - Static variable in class org.jgroups.Global
- is_server - Variable in class org.jgroups.protocols.PingRsp
- isAbort() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- isAcceptable(Object, Address) - Method in interface org.jgroups.blocks.RspFilter
-
Determines whether a response from a given sender should be added to the response list of the request
- isAlive() - Method in class org.jgroups.util.ReusableThread
- isBinaryCompatible(short) - Static method in class org.jgroups.Version
-
Checks whether ver is binary compatible with the current version.
- isBinaryCompatible(short, short) - Static method in class org.jgroups.Version
- isBindAddressPropertyIgnored() - Static method in class org.jgroups.util.Util
- isBlockingUpdates() - Method in class org.jgroups.blocks.ReplicatedHashMap
- isClosed() - Method in class org.jgroups.jmx.protocols.BARRIER
- isClosed() - Method in interface org.jgroups.jmx.protocols.BARRIERMBean
-
Indicates if barrier is currently closed.
- isClosed() - Method in class org.jgroups.protocols.BARRIER
- isCommit() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- isComplete() - Method in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- isConnected() - Method in class org.jgroups.Channel
-
Determines whether the channel is connected to a group.
- isConnected() - Method in class org.jgroups.JChannel
-
returns true if the Connect operation has been called successfully
- isConnected() - Method in class org.jgroups.jmx.JChannel
- isConnected() - Method in interface org.jgroups.jmx.JChannelMBean
- isConnected() - Method in class org.jgroups.stack.RouterStub
- isCoord() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- isCoord() - Method in interface org.jgroups.jmx.protocols.SEQUENCERMBean
- isCoord() - Method in class org.jgroups.protocols.PingRsp
- isCoordinator() - Method in class org.jgroups.blocks.NotificationBus
- isCoordinator() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- isCoordinator() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- isCoordinator() - Method in class org.jgroups.protocols.pbcast.GMS
- isCoordinator() - Method in class org.jgroups.protocols.SEQUENCER
- isCoordinator(JChannel) - Static method in class org.jgroups.util.Util
- isDefaulThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
- isDiscardAll() - Method in class org.jgroups.protocols.DISCARD
- isDiscardDeliveredMsgs() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- isDiscardDeliveredMsgs() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- isDiscardDeliveredMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
- isDiscardIncompatiblePackets() - Method in class org.jgroups.jmx.protocols.TP
- isDiscardIncompatiblePackets() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isDiscardIncompatiblePackets() - Method in class org.jgroups.protocols.TP
- isDiscardLoopbacks() - Method in class org.jgroups.stack.GossipRouter
- isDone() - Method in class org.jgroups.blocks.GroupRequest
- isEmpty() - Method in class org.jgroups.util.RspList
- isEmpty() - Method in class org.jgroups.util.SizeBoundedQueue
- isEmpty() - Method in class org.jgroups.util.UnmodifiableVector
- isEnable_unicast_bundling() - Method in class org.jgroups.protocols.TP
- isEnableBundling() - Method in class org.jgroups.jmx.protocols.TP
- isEnableBundling() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isEnableBundling() - Method in class org.jgroups.protocols.TP
- isExcludeItself() - Method in class org.jgroups.protocols.DISCARD
- isExposeChannels() - Method in class org.jgroups.JChannelFactory
- isExposeChannels() - Method in class org.jgroups.jmx.JChannelFactory
- isExposeChannels() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- isExposeProtocols() - Method in class org.jgroups.JChannelFactory
- isExposeProtocols() - Method in class org.jgroups.jmx.JChannelFactory
- isExposeProtocols() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- isFlagSet(byte) - Method in class org.jgroups.Message
- isGreaterThanOrEqual(Digest) - Method in class org.jgroups.util.Digest
-
Returns true if all senders of the current digest have their seqnos >= the ones from other
- isLogDiscardMsgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
- isLoopback() - Method in class org.jgroups.jmx.protocols.TP
- isLoopback() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isLoopback() - Method in class org.jgroups.protocols.TP
- isMulticastAddress() - Method in interface org.jgroups.Address
-
Checks whether this is an address that represents multiple destinations; e.g., a class D address in the Internet.
- isMulticastAddress() - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Is the address a multicast address?
- isMulticastAddress() - Method in class org.jgroups.stack.IpAddress
- isMultipleLocked() - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
- isOOBThreadPoolEnabled() - Method in class org.jgroups.protocols.TP
- isOpen() - Method in class org.jgroups.Channel
-
Determines whether the channel is open; i.e., the protocol stack has been created (may not be connected though).
- isOpen() - Method in class org.jgroups.JChannel
-
returns true if the Open operation has been called successfully
- isOpen() - Method in class org.jgroups.jmx.JChannel
- isOpen() - Method in interface org.jgroups.jmx.JChannelMBean
- isOpenerScheduled() - Method in class org.jgroups.jmx.protocols.BARRIER
- isOpenerScheduled() - Method in interface org.jgroups.jmx.protocols.BARRIERMBean
-
Returns true if barrier_opener_future is non-null.
- isOpenerScheduled() - Method in class org.jgroups.protocols.BARRIER
- isOverride() - Method in class org.jgroups.conf.ProtocolData
- isPartitionOn() - Method in class org.jgroups.jmx.protocols.PARTITION
- isPartitionOn() - Method in interface org.jgroups.jmx.protocols.PARTITIONMBean
- isPartitionOn() - Method in class org.jgroups.protocols.PARTITION
- isPrepare() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- isPrintLocalAddr() - Method in class org.jgroups.protocols.pbcast.GMS
- isReceived(Address) - Method in class org.jgroups.util.RspList
- isReceiveOnAllInterfaces() - Method in class org.jgroups.jmx.protocols.MPING
- isReceiveOnAllInterfaces() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- isReceiveOnAllInterfaces() - Method in class org.jgroups.jmx.protocols.TP
- isReceiveOnAllInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
- isReceiveOnAllInterfaces() - Method in class org.jgroups.protocols.TP
- isRefresherEnabled() - Method in class org.jgroups.stack.GossipClient
- isRunning() - Method in class org.jgroups.jmx.protocols.FD_ALL
- isRunning() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- isRunning() - Method in class org.jgroups.protocols.FD_ALL
- isSame(short) - Static method in class org.jgroups.Version
-
Compares the specified version number against the current version number.
- isSendOnAllInterfaces() - Method in class org.jgroups.jmx.protocols.MPING
- isSendOnAllInterfaces() - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- isSendOnAllInterfaces() - Method in class org.jgroups.jmx.protocols.TP
- isSendOnAllInterfaces() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isSendOnAllInterfaces() - Method in class org.jgroups.protocols.MPING
- isSendOnAllInterfaces() - Method in class org.jgroups.protocols.TP
- isServer() - Method in class org.jgroups.protocols.PingRsp
- isShun() - Method in class org.jgroups.jmx.protocols.FD_ALL
- isShun() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- isShun() - Method in class org.jgroups.jmx.protocols.FD
- isShun() - Method in interface org.jgroups.jmx.protocols.FDMBean
- isShun() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- isShun() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- isShun() - Method in class org.jgroups.protocols.FD_ALL
- isShun() - Method in class org.jgroups.protocols.FD
- isShun() - Method in class org.jgroups.protocols.pbcast.GMS
- isStarted() - Method in class org.jgroups.stack.GossipRouter
- isSuspected(Address) - Method in class org.jgroups.util.RspList
- isThreadPoolEnabled() - Method in class org.jgroups.stack.GossipRouter
- isThreadPoolQueueEnabled() - Method in class org.jgroups.stack.GossipRouter
- isUseIncomingPacketHandler() - Method in class org.jgroups.jmx.protocols.TP
- isUseIncomingPacketHandler() - Method in interface org.jgroups.jmx.protocols.TPMBean
- isUseIncomingPacketHandler() - Method in class org.jgroups.protocols.TP
- isUseMcastXmit() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- isUseMcastXmit() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- isUseMcastXmit() - Method in class org.jgroups.protocols.pbcast.NAKACK
- 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.
- isViewBundling() - Method in class org.jgroups.protocols.pbcast.GMS
- isViewHandlerSuspended() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- isViewHandlerSuspended() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- isViewHandlerSuspended() - Method in class org.jgroups.protocols.pbcast.GMS
- isXmitFromRandomMember() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- isXmitFromRandomMember() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- isXmitFromRandomMember() - Method in class org.jgroups.protocols.pbcast.NAKACK
- iterator() - Method in class org.jgroups.util.SizeBoundedQueue
- iterator() - Method in class org.jgroups.util.UnmodifiableVector
- iWouldBeCoordinator(Vector) - Method in class org.jgroups.protocols.pbcast.GmsImpl
-
Returns potential coordinator based on lexicographic ordering of member addresses.
J
- JAXP_MISSING_ERROR_MSG - Static variable in class org.jgroups.conf.ConfiguratorFactory
- JChannel - Class in org.jgroups
-
JChannel is a pure Java implementation of Channel.
- JChannel - Class in org.jgroups.jmx
- JChannel() - Constructor for class org.jgroups.JChannel
-
Constructs a
JChannel
instance with the protocol stack specified by theDEFAULT_PROTOCOL_STACK
member. - JChannel() - Constructor for class org.jgroups.jmx.JChannel
- JChannel(boolean) - Constructor for class org.jgroups.JChannel
-
Used by subclass to create a JChannel without a protocol stack, don't use as application programmer
- JChannel(File) - Constructor for class org.jgroups.JChannel
-
Constructs a
JChannel
instance with the protocol stack configuration contained by the specified file. - JChannel(Object) - Constructor for class org.jgroups.JChannel
-
Deprecated.Use the constructors with specific parameter types instead.
- JChannel(String) - Constructor for class org.jgroups.JChannel
-
Constructs a
JChannel
instance with the protocol stack configuration based upon the specified properties parameter. - JChannel(URL) - Constructor for class org.jgroups.JChannel
-
Constructs a
JChannel
instance with the protocol stack configuration indicated by the specified URL. - 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(JChannel) - Constructor for class org.jgroups.jmx.JChannel
- JChannel(Element) - Constructor for class org.jgroups.JChannel
-
Constructs a
JChannel
instance with the protocol stack configuration contained by the specified XML element. - JChannelFactory - Class in org.jgroups
-
JChannelFactory creates pure Java implementations of the
Channel
interface. - JChannelFactory - Class in org.jgroups.jmx
- JChannelFactory() - Constructor for class org.jgroups.JChannelFactory
-
Constructs a
JChannelFactory
instance that contains no protocol stack configuration. - JChannelFactory() - Constructor for class org.jgroups.jmx.JChannelFactory
- JChannelFactory(File) - Constructor for class org.jgroups.JChannelFactory
-
Constructs a
JChannelFactory
instance that utilizes the specified file for protocl stack configuration. - JChannelFactory(String) - Constructor for class org.jgroups.JChannelFactory
-
Constructs a
JChannel
instance with the protocol stack configuration based upon the specified properties parameter. - JChannelFactory(URL) - Constructor for class org.jgroups.JChannelFactory
-
Constructs a
JChannelFactory
instance that utilizes the specified file for protocl stack configuration. - JChannelFactory(JChannelFactory) - Constructor for class org.jgroups.jmx.JChannelFactory
- JChannelFactory(Element) - Constructor for class org.jgroups.JChannelFactory
-
Constructs a
JChannelFactory
instance that utilizes the specified file for protocl stack configuration. - JChannelFactoryMBean - Interface in org.jgroups.jmx
- JChannelMBean - Interface in org.jgroups.jmx
- JMS - Class in org.jgroups.protocols
-
Implementation of the transport protocol using the Java Message Service (JMS).
- JMS() - Constructor for class org.jgroups.protocols.JMS
-
Empty constructor.
- JMS.JMSAddress - Class in org.jgroups.protocols
-
Simple
Address
representing the JMS node ID or JMS topic group. - JMSAddress() - Constructor for class org.jgroups.protocols.JMS.JMSAddress
-
Empty constructor to allow externalization work.
- JmxConfigurator - Class in org.jgroups.jmx
- JmxConfigurator() - Constructor for class org.jgroups.jmx.JmxConfigurator
- join(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- 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_ANNOUNCEMENT - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
- JOIN_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- JOIN_REQ_WITH_STATE_TRANSFER - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- JOIN_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- JoinRsp - Class in org.jgroups.protocols.pbcast
-
Result of a JOIN request (sent by the GMS client).
- JoinRsp() - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- JoinRsp(String) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- JoinRsp(View, Digest) - Constructor for class org.jgroups.protocols.pbcast.JoinRsp
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- joinWithStateTransfer(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
K
- KEY_REQUEST - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- keyPress(String) - Static method in class org.jgroups.util.Util
- keySet() - Method in class org.jgroups.util.RspList
- KEYSTORE_PASSWORD - Static variable in class org.jgroups.auth.X509Token
- KEYSTORE_PATH - Static variable in class org.jgroups.auth.X509Token
- KEYSTORE_TYPE - Static variable in class org.jgroups.auth.X509Token
- KeyStoreGenerator - Class in org.jgroups.demos
-
Generates a keystore file that has a SecretKey in it.
- KeyStoreGenerator() - Constructor for class org.jgroups.demos.KeyStoreGenerator
L
- lastElement() - Method in class org.jgroups.util.UnmodifiableVector
- lastIndexOf(Object) - Method in class org.jgroups.util.UnmodifiableVector
- lastIndexOf(Object, int) - Method in class org.jgroups.util.UnmodifiableVector
- LazyThreadFactory - Class in org.jgroups.util
-
Lazily names threads: whenever the address or cluster name is changed, all threads are renamed
- LazyThreadFactory(ThreadGroup, String, boolean) - Constructor for class org.jgroups.util.LazyThreadFactory
- LazyThreadFactory(ThreadGroup, String, boolean, boolean) - Constructor for class org.jgroups.util.LazyThreadFactory
- lbl - Variable in class org.jgroups.demos.wb.Node
- 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_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
- length - Variable in class org.jgroups.Message
-
The number of bytes in the buffer (usually buf.length is buf not equal to null).
- lessThanOrEqual(TransportedVectorTime) - Method in class org.jgroups.protocols.TransportedVectorTime
-
Checks if this TransportedVectorTime is less than or equal to the the specified TransportedVectorTime.
- link() - Method in class org.jgroups.demos.ChatCore
- LIST_SERVICES_RSP - Static variable in class org.jgroups.mux.ServiceInfo
- listAlphabet() - Method in class org.jgroups.demos.CausalDemo
- listener - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- listeners - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- listIterator() - Method in class org.jgroups.util.UnmodifiableVector
- listIterator(int) - Method in class org.jgroups.util.UnmodifiableVector
- loadClass(String, Class) - Static method in class org.jgroups.util.Util
-
Tries to load the class from the current thread's context class loader.
- LOCAL - Static variable in class org.jgroups.Channel
- local_addr - Variable in class org.jgroups.blocks.MessageDispatcher
- local_addr - Variable in class org.jgroups.blocks.RequestCorrelator
-
The address of this group member
- local_addr - Variable in class org.jgroups.protocols.TP
-
The address (host and port) of this member
- local_address - Variable in class org.jgroups.protocols.PARTITION
- localAddressSet(Address) - Method in class org.jgroups.protocols.Discovery
-
Called after local_addr was set
- localAddressSet(Address) - Method in class org.jgroups.protocols.PING
- localAddressSet(Address) - Method in class org.jgroups.protocols.TCPPING
- localVote(Object) - Method in class org.jgroups.blocks.VotingAdapter
-
This method performs voting on the specific decree between all local voteListeners.
- lock - Variable in class org.jgroups.protocols.FD
- lock(Object, Object, int) - Method in class org.jgroups.blocks.DistributedLockManager
-
Locks an object with
lockId
on behalf of the specifiedowner
. - lock(Object, Object, int) - Method in interface org.jgroups.blocks.LockManager
-
Obtain lock on
obj
for specifiedowner
. - lockId - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
- LockingException - Exception Class in org.jgroups.blocks
- LockingException(String) - Constructor for exception class org.jgroups.blocks.LockingException
- LockingException(Map) - Constructor for exception class org.jgroups.blocks.LockingException
- LockManager - Interface in org.jgroups.blocks
-
LockManager
represents generic lock manager that allows obtaining and releasing locks on objects. - LockMultiLockedException - Exception Class in org.jgroups.blocks
-
Thrown by the
DistributedLockManager.unlock(Object, Object, boolean)
method if a lock is only locally released, because it is locked by multiple DistributedLockManagers. - LockMultiLockedException() - Constructor for exception class org.jgroups.blocks.LockMultiLockedException
- LockMultiLockedException(String) - Constructor for exception class org.jgroups.blocks.LockMultiLockedException
- LockNotGrantedException - Exception Class in org.jgroups.blocks
-
This exception indicated that lock manager refused to give a lock on some resource.
- LockNotGrantedException() - Constructor for exception class org.jgroups.blocks.LockNotGrantedException
- LockNotGrantedException(String) - Constructor for exception class org.jgroups.blocks.LockNotGrantedException
- LockNotReleasedException - Exception Class in org.jgroups.blocks
-
This exception indicated that lock manager refused to release a lock on some resource.
- LockNotReleasedException() - Constructor for exception class org.jgroups.blocks.LockNotReleasedException
- LockNotReleasedException(String) - Constructor for exception class org.jgroups.blocks.LockNotReleasedException
- log - Variable in class org.jgroups.auth.AuthToken
- log - Variable in class org.jgroups.blocks.BasicConnectionTable
- log - Variable in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- log - Variable in class org.jgroups.blocks.DistributedLockManager
- log - Static variable in class org.jgroups.blocks.DistributedTree
- log - Variable in class org.jgroups.blocks.MessageDispatcher
- log - Static variable in class org.jgroups.blocks.MethodCall
- log - Variable in class org.jgroups.blocks.NotificationBus
- log - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- log - Variable in class org.jgroups.blocks.ReplicatedHashMap
- log - Variable in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- log - Variable in class org.jgroups.blocks.ReplicatedTree
- log - Static variable in class org.jgroups.blocks.RequestCorrelator
- log - Variable in class org.jgroups.blocks.VotingAdapter
- log - Variable in class org.jgroups.conf.ClassConfigurator
- log - Static variable in class org.jgroups.conf.MagicNumberReader
- log - Static variable in class org.jgroups.conf.XmlConfigurator
- log - Variable in class org.jgroups.debug.ProtocolTester
- log - Variable in class org.jgroups.JChannel
- log - Static variable in class org.jgroups.Membership
- log - Static variable in class org.jgroups.Message
- log - Variable in class org.jgroups.persistence.DBPersistenceManager
- log - Static variable in class org.jgroups.persistence.PersistenceFactory
- log - Variable in class org.jgroups.protocols.pbcast.GmsImpl
- log - Static variable in class org.jgroups.stack.AckMcastReceiverWindow
- log - Static variable in class org.jgroups.stack.AckMcastSenderWindow
-
Default retransmit thread suspend timeout (ms)
- log - Static variable in class org.jgroups.stack.Configurator
- log - Variable in class org.jgroups.stack.GossipClient
- log - Variable in class org.jgroups.stack.GossipRouter
- log - Static variable in class org.jgroups.stack.IpAddress
- log - Static variable in class org.jgroups.stack.NakReceiverWindow
- log - Variable in class org.jgroups.stack.Protocol
- log - Static variable in class org.jgroups.stack.Retransmitter
- log - Static variable in class org.jgroups.util.Digest
- log - Static variable in class org.jgroups.util.Queue
- log - Static variable in class org.jgroups.util.ReusableThread
- log - Static variable in class org.jgroups.util.Scheduler
- log - Static variable in class org.jgroups.util.ThreadPool
- log - Static variable in class org.jgroups.util.TimeScheduler
- logger - Variable in class org.jgroups.blocks.DistributedQueue
- LONG_SIZE - Static variable in class org.jgroups.Global
- LOOPBACK - Class in org.jgroups.protocols
-
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
- low - Variable in class org.jgroups.util.Range
- LOW_PRIO - Static variable in class org.jgroups.Message
- lowSeqnoAt(Address) - Method in class org.jgroups.util.Digest
M
- MAGIC_NUMBER_FILE - Static variable in class org.jgroups.conf.MagicNumberReader
- MAGIC_NUMBER_FILE - Static variable in class org.jgroups.Global
- MagicNumberReader - Class in org.jgroups.conf
- MagicNumberReader() - Constructor for class org.jgroups.conf.MagicNumberReader
- MagicObjectInputStream - Class in org.jgroups.util
-
Uses magic numbers for class descriptors
- MagicObjectInputStream(InputStream) - Constructor for class org.jgroups.util.MagicObjectInputStream
- MagicObjectOutputStream - Class in org.jgroups.util
-
Uses magic numbers for class descriptors
- MagicObjectOutputStream(OutputStream) - Constructor for class org.jgroups.util.MagicObjectOutputStream
- main(String[]) - Static method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- main(String[]) - Static method in class org.jgroups.blocks.DistributedQueue
- main(String[]) - Static method in class org.jgroups.blocks.ReplicatedTree
- main(String[]) - Static method in class org.jgroups.conf.ClassConfigurator
- main(String[]) - Static method in class org.jgroups.conf.XmlConfigurator
- main(String[]) - Static method in class org.jgroups.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.DrawMultiplexer
- main(String[]) - Static method in class org.jgroups.demos.DrawRepl
- main(String[]) - Static method in class org.jgroups.demos.Gossip
- main(String[]) - Static method in class org.jgroups.demos.KeyStoreGenerator
- main(String[]) - Static method in class org.jgroups.demos.NotificationBusDemo
- main(String[]) - Static method in class org.jgroups.demos.QuoteClient
- main(String[]) - Static method in class org.jgroups.demos.QuoteServer
- main(String[]) - Static method in class org.jgroups.demos.ReplicatedHashMapDemo
- 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.pbcast.Gossip
- main(String[]) - Static method in class org.jgroups.stack.AckMcastReceiverWindow
- main(String[]) - Static method in class org.jgroups.stack.AckSenderWindow
- main(String[]) - Static method in class org.jgroups.stack.GossipClient
- main(String[]) - Static method in class org.jgroups.stack.GossipRouter
- main(String[]) - Static method in class org.jgroups.util.GetNetworkInterfaces
- main(String[]) - Static method in class org.jgroups.util.Proxy
- main(String[]) - Static method in class org.jgroups.util.TimedWriter
- main(String[]) - Static method in class org.jgroups.util.Util
- main(String[]) - Static method in class org.jgroups.Version
-
Prints the value of the description and cvs fields to System.out.
- major - Static variable in class org.jgroups.Version
- makeReply() - Method in class org.jgroups.Message
- makeView(Vector) - Method in class org.jgroups.protocols.Discovery
- makeView(Vector<Address>) - Method in class org.jgroups.protocols.pbcast.GMS
- makeView(Vector<Address>, ViewId) - Static method in class org.jgroups.protocols.pbcast.GMS
- managerId - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
- mapToString(Map<? extends Object, ? extends Object>) - Static method in class org.jgroups.util.Util
- marshalledSize() - Method in class org.jgroups.util.Headers
- marshaller - Variable in class org.jgroups.blocks.RequestCorrelator
-
Possibility for an external marshaller to marshal/unmarshal responses
- Marshaller - Class in org.jgroups.util
-
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
- MarshallerAdapter(RpcDispatcher.Marshaller) - Constructor for class org.jgroups.blocks.RpcDispatcher.MarshallerAdapter
- MARSHALLING_COMPAT - Static variable in class org.jgroups.Global
- match(long[], long[]) - Static method in class org.jgroups.util.Util
- match(Object, Object) - Static method in class org.jgroups.util.Util
- MAX_PORT - Static variable in class org.jgroups.util.Util
- MCAST - Static variable in class org.jgroups.protocols.SMACK.SmackHeader
- md5(String) - Static method in class org.jgroups.util.Util
-
Converts a java.lang.String in to a MD5 hashed String
- MD5Token - Class in org.jgroups.auth
-
This is an example of using a preshared token that is encrypted using an MD5/SHA hash for authentication purposes.
- MD5Token() - Constructor for class org.jgroups.auth.MD5Token
- MD5Token(String) - Constructor for class org.jgroups.auth.MD5Token
- MD5Token(String, String) - Constructor for class org.jgroups.auth.MD5Token
- 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.blocks.DistributedQueue
- members - Variable in class org.jgroups.blocks.MessageDispatcher
- members - Variable in class org.jgroups.protocols.TP
-
The members of this group (updated when a member joins or leaves)
- members - Variable in class org.jgroups.View
-
A list containing all the members of the view This list is always ordered, with the coordinator being the first member.
- Membership - Class in org.jgroups
-
Class to keep track of Addresses.
- Membership() - Constructor for class org.jgroups.Membership
-
Public constructor Creates a member ship object with zero members
- Membership(Collection<Address>) - Constructor for class org.jgroups.Membership
-
Creates a member ship object with the initial members.
- membership_listener - Variable in class org.jgroups.blocks.MessageDispatcher
- membership_listeners - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- MembershipListener - Interface in org.jgroups
-
Allows a listener to be notified when group membership changes.
- MembershipListenerAdapter - Class in org.jgroups.blocks
-
This class provides multiplexing possibilities for
MembershipListener
instances. - MembershipListenerAdapter() - Constructor for class org.jgroups.blocks.MembershipListenerAdapter
- membershipListeners - Variable in class org.jgroups.blocks.MembershipListenerAdapter
- membershipListenersCache - Variable in class org.jgroups.blocks.MembershipListenerAdapter
- memStats(boolean) - Static method in class org.jgroups.util.Util
- merge(Collection<Address>, Collection<Address>) - 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<Address>) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
-
Invoked upon receiving a MERGE event from the MERGE layer.
- merge(Vector<Address>) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- merge(Address, long, long, long) - Method in class org.jgroups.util.MutableDigest
-
Similar to add(), but if the sender already exists, its seqnos will be modified (no new entry) as follows: this.low_seqno=min(this.low_seqno, low_seqno) this.highest_delivered_seqno=max(this.highest_delivered_seqno, highest_delivered_seqno) this.highest_received_seqno=max(this.highest_received_seqno, highest_received_seqno) If the sender doesn not exist, a new entry will be added (provided there is enough space)
- merge(Digest) - Method in class org.jgroups.util.MutableDigest
-
Adds a digest to this digest.
- MERGE - Static variable in class org.jgroups.Event
- MERGE_DIGEST - Static variable in class org.jgroups.Event
- merge_history - Variable in class org.jgroups.protocols.pbcast.NAKACK
- MERGE_REQ - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- MERGE_RSP - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- MERGE2 - Class in org.jgroups.jmx.protocols
- MERGE2 - Class in org.jgroups.protocols
-
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
- MERGE2() - Constructor for class org.jgroups.jmx.protocols.MERGE2
- MERGE2() - Constructor for class org.jgroups.protocols.MERGE2
- MERGE2(Protocol) - Constructor for class org.jgroups.jmx.protocols.MERGE2
- MERGE2MBean - Interface in org.jgroups.jmx.protocols
- MERGE3 - Class in org.jgroups.protocols
-
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
- MERGE3() - Constructor for class org.jgroups.protocols.MERGE3
- MERGE3.CoordAnnouncement - Class in org.jgroups.protocols
- MergeData - Class in org.jgroups.protocols.pbcast
-
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
- mergeDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Send down a MERGE_DIGEST event
- MERGEFAST - Class in org.jgroups.protocols
-
The coordinator attaches a small header to each (or every nth) message.
- MERGEFAST() - Constructor for class org.jgroups.protocols.MERGEFAST
- MERGEFAST.MergefastHeader - Class in org.jgroups.protocols
- MergefastHeader() - Constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
- MergefastHeader(Address) - Constructor for class org.jgroups.protocols.MERGEFAST.MergefastHeader
- MergeView - Class in org.jgroups
-
A view that is sent as a result of a merge.
- MergeView() - Constructor for class org.jgroups.MergeView
-
Used by externalization
- MergeView(Address, long, Vector<Address>, Vector<View>) - Constructor for class org.jgroups.MergeView
-
Creates a new view
- MergeView(ViewId, Vector<Address>, Vector<View>) - Constructor for class org.jgroups.MergeView
-
Creates a new view
- Message - Class in org.jgroups
-
A Message encapsulates data sent to members of a group.
- Message() - Constructor for class org.jgroups.Message
- Message(boolean) - Constructor for class org.jgroups.Message
- Message(Address) - Constructor for class org.jgroups.Message
-
Public constructor
- 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
- MessageDialog - Class in org.jgroups.demos.wb
- MessageDialog(Frame, String, String) - Constructor for class org.jgroups.demos.wb.MessageDialog
- MessageDispatcher - Class in org.jgroups.blocks
-
Provides synchronous and asynchronous message sending with request-response correlation; i.e., matching responses with the original request.
- MessageDispatcher() - Constructor for class org.jgroups.blocks.MessageDispatcher
- MessageDispatcher(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
- 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
- messageGapDetected(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Called when a message gap is detected
- messageGapDetected(long, long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
- MessageListener - Interface in org.jgroups
-
Allows a listener to be notified when a message arrives.
- MessageListenerAdapter - Class in org.jgroups.blocks
-
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.
- messageListeners - Variable in class org.jgroups.blocks.MessageListenerAdapter
- messageListenersCache - Variable in class org.jgroups.blocks.MessageListenerAdapter
- messageToByteBuffer(Message) - Static method in class org.jgroups.util.Util
- method - Variable in class org.jgroups.blocks.MethodCall
-
The Method of the call.
- METHOD - Static variable in class org.jgroups.blocks.MethodCall
-
Explicitly ship the method, caller has to determine method himself.
- method_id - Variable in class org.jgroups.blocks.MethodCall
-
The ID of a method, maps to a java.lang.reflect.Method
- method_lookup - Variable in class org.jgroups.blocks.RpcDispatcher
- method_name - Variable in class org.jgroups.blocks.MethodCall
-
The name of the method, case sensitive.
- MethodCall - Class in org.jgroups.blocks
-
A method call is the JGroups representation of a remote method.
- MethodCall() - Constructor for class org.jgroups.blocks.MethodCall
-
Creates an empty method call, this is always invalid, until
setName()
has been called. - MethodCall(short, Object[]) - Constructor for class org.jgroups.blocks.MethodCall
- 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
- MethodLookup - Interface in org.jgroups.blocks
- methods - Static variable in class org.jgroups.blocks.ReplicatedHashMap
- micro - Static variable in class org.jgroups.Version
- minor - Static variable in class org.jgroups.Version
- MissingIndexesMessage() - Constructor for class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
-
Used for externalization.
- MissingIndexesMessage(Collection, Collection) - Constructor for class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- missingMessageReceived(long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
- missingMessageReceived(long, Address) - Method in interface org.jgroups.stack.NakReceiverWindow.Listener
- mMagicNumberFile - Variable in class org.jgroups.conf.MagicNumberReader
- mode - Variable in class org.jgroups.blocks.MethodCall
-
Which mode to use.
- Monitor() - Constructor for class org.jgroups.protocols.FD.Monitor
- mouseClicked(MouseEvent) - Method in class org.jgroups.demos.Chat
- mouseClicked(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.DrawRepl
- mouseDragged(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mouseEntered(MouseEvent) - Method in class org.jgroups.demos.Chat
- mouseEntered(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mouseExited(MouseEvent) - Method in class org.jgroups.demos.Chat
- mouseExited(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.applets.DrawApplet
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.DrawRepl
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.Gossip
- mouseMoved(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mousePressed(MouseEvent) - Method in class org.jgroups.demos.Chat
- mousePressed(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- mouseReleased(MouseEvent) - Method in class org.jgroups.demos.Chat
- mouseReleased(MouseEvent) - Method in class org.jgroups.demos.wb.GraphPanel
- moveNode(Node) - Method in class org.jgroups.demos.wb.GraphPanel
- moveNode(Node) - Method in class org.jgroups.demos.wb.Whiteboard
- MPING - Class in org.jgroups.jmx.protocols
- MPING - Class in org.jgroups.protocols
-
Uses its own IP multicast socket to send and receive discovery requests/responses.
- MPING() - Constructor for class org.jgroups.jmx.protocols.MPING
- MPING() - Constructor for class org.jgroups.protocols.MPING
- MPING(Protocol) - Constructor for class org.jgroups.jmx.protocols.MPING
- MPING_IP_TTL - Static variable in class org.jgroups.Global
- MPING_MCAST_ADDR - Static variable in class org.jgroups.Global
- MPING_MCAST_PORT - Static variable in class org.jgroups.Global
- MPINGMBean - Interface in org.jgroups.jmx.protocols
- MSG - Static variable in class org.jgroups.Event
- MSG - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
- msg_listener - Variable in class org.jgroups.blocks.MessageDispatcher
- msgListToByteBuffer(List<Message>) - Static method in class org.jgroups.util.Util
-
Marshalls a list of messages.
- Multiplexer - Class in org.jgroups.mux
-
The multiplexer allows multiple channel interfaces to be associated with one underlying instance of JChannel.
- Multiplexer(JChannel) - Constructor for class org.jgroups.mux.Multiplexer
- MutableDigest - Class in org.jgroups.util
-
A mutable version of Digest (which is immutable
- MutableDigest() - Constructor for class org.jgroups.util.MutableDigest
-
Used for externalization
- MutableDigest(int) - Constructor for class org.jgroups.util.MutableDigest
- MutableDigest(Map<Address, Digest.Entry>) - Constructor for class org.jgroups.util.MutableDigest
- MutableDigest(Digest) - Constructor for class org.jgroups.util.MutableDigest
- mutex - Variable in class org.jgroups.blocks.DistributedQueue
- MUX_ENABLED - Static variable in class org.jgroups.Global
- MUX_KEEPALIVE - Static variable in class org.jgroups.Global
- MUX_MAX_THREADS - Static variable in class org.jgroups.Global
- MUX_MIN_THREADS - Static variable in class org.jgroups.Global
- MuxChannel - Class in org.jgroups.mux
-
Multiplexer channel is a lightweight version of a regular channel where multiple MuxChannel(s) share the same underlying regular channel.
- MuxHeader - Class in org.jgroups.mux
-
Header used for multiplexing and de-multiplexing between service components on top of a Multiplexer (Channel)
- MuxHeader() - Constructor for class org.jgroups.mux.MuxHeader
- MuxHeader(String) - Constructor for class org.jgroups.mux.MuxHeader
- MuxHeader(ServiceInfo) - Constructor for class org.jgroups.mux.MuxHeader
- my_addr - Variable in class org.jgroups.demos.wb.GraphPanel
- MyFuture() - Constructor for class org.jgroups.blocks.ConnectionTableNIO.MyFuture
N
- NAKACK - Class in org.jgroups.jmx.protocols.pbcast
- NAKACK - Class in org.jgroups.protocols.pbcast
-
Negative AcKnowledgement layer (NAKs).
- NAKACK() - Constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
- NAKACK() - Constructor for class org.jgroups.protocols.pbcast.NAKACK
- NAKACK(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.NAKACK
- NakAckHeader - Class in org.jgroups.protocols.pbcast
- NakAckHeader() - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
- NakAckHeader(byte, long) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
-
Constructor for regular messages
- NakAckHeader(byte, long, long) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
-
Constructor for retransmit requests/responses (low and high define the range of msgs)
- NakAckHeader(byte, long, long, Address) - Constructor for class org.jgroups.protocols.pbcast.NakAckHeader
- NAKACKMBean - Interface in org.jgroups.jmx.protocols.pbcast
- NakReceiverWindow - Class in org.jgroups.stack
-
Keeps track of messages according to their sequence numbers.
- NakReceiverWindow(Address, Address, Retransmitter.RetransmitCommand, long, long, TimeScheduler) - Constructor for class org.jgroups.stack.NakReceiverWindow
- NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long) - Constructor for class org.jgroups.stack.NakReceiverWindow
-
Creates a new instance with the given retransmit command
- NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, long, TimeScheduler) - Constructor for class org.jgroups.stack.NakReceiverWindow
-
Creates a new instance with the given retransmit command
- NakReceiverWindow(Address, Retransmitter.RetransmitCommand, long, TimeScheduler) - Constructor for class org.jgroups.stack.NakReceiverWindow
-
Creates a new instance with the given retransmit command
- NakReceiverWindow.Listener - Interface in org.jgroups.stack
- name - Variable in class org.jgroups.blocks.RequestCorrelator
-
makes the instance unique (together with IDs)
- name - Static variable in class org.jgroups.protocols.pbcast.GMS
- name - Static variable in class org.jgroups.protocols.PING
- NAME - Static variable in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- NAME - Static variable in class org.jgroups.protocols.pbcast.FLUSH
- NBMessageForm_NIO - Class in org.jgroups.blocks
-
NBMessageForm - Message form for non-blocking message reads.
- NBMessageForm_NIO(int, SocketChannel) - Constructor for class org.jgroups.blocks.NBMessageForm_NIO
- needMoreResponses() - Method in interface org.jgroups.blocks.RspFilter
-
Right after calling
RspFilter.isAcceptable(Object, org.jgroups.Address)
, this method is called to see whether we are done with the request and can unblock the caller - newThread(Runnable) - Method in class org.jgroups.util.DefaultThreadFactory
- newThread(Runnable, String) - Method in class org.jgroups.util.DefaultThreadFactory
- newThread(Runnable, String) - Method in interface org.jgroups.util.ThreadFactory
- newThread(ThreadGroup, Runnable, String) - Method in class org.jgroups.util.DefaultThreadFactory
- newThread(ThreadGroup, Runnable, String) - Method in class org.jgroups.util.LazyThreadFactory
- newThread(ThreadGroup, Runnable, String) - Method in interface org.jgroups.util.ThreadFactory
- newThread(ThreadGroup, Runnable, String, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
- next() - Method in class org.jgroups.stack.ExponentialInterval
- next() - Method in interface org.jgroups.stack.Interval
- next() - Method in class org.jgroups.stack.StaticInterval
- nextInterval() - Method in interface org.jgroups.util.TimeScheduler.Task
- Node - Class in org.jgroups.demos.wb
- Node() - Constructor for class org.jgroups.demos.wb.Node
- nodeAdded(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- nodeAdded(String, Serializable) - Method in interface org.jgroups.blocks.DistributedTree.DistributedTreeListener
- nodeAdded(String, Serializable) - Method in class org.jgroups.demos.DistributedTreeDemo
- nodeModified(String) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- nodeModified(String, Serializable, Serializable) - Method in interface org.jgroups.blocks.DistributedTree.DistributedTreeListener
- 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
- NOT_MEMBER - Static variable in class org.jgroups.protocols.FD_ALL.Header
- NOT_MEMBER - Static variable in class org.jgroups.protocols.FD.FdHeader
- NotificationBus - Class in org.jgroups.blocks
-
This class provides notification sending and handling capability.
- NotificationBus() - Constructor for class org.jgroups.blocks.NotificationBus
- NotificationBus(String) - Constructor for class org.jgroups.blocks.NotificationBus
- NotificationBus(String, String) - Constructor for class org.jgroups.blocks.NotificationBus
- NotificationBus(Channel, String) - Constructor for class org.jgroups.blocks.NotificationBus
- NotificationBus.Consumer - Interface in org.jgroups.blocks
- NotificationBusDemo - Class in org.jgroups.demos
-
Demoes the NotificationBus (without caching).
- NotificationBusDemo() - Constructor for class org.jgroups.demos.NotificationBusDemo
- notifs - Variable in class org.jgroups.blocks.DistributedQueue
- notifyBlock() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- notifyChannelClosed(Channel) - Method in class org.jgroups.Channel
- notifyChannelConnected(Channel) - Method in class org.jgroups.Channel
- notifyChannelDisconnected(Channel) - Method in class org.jgroups.Channel
- notifyChannelReconnected(Address) - Method in class org.jgroups.Channel
- notifyChannelShunned() - Method in class org.jgroups.Channel
- notifyConsumer(Serializable) - Method in class org.jgroups.blocks.NotificationBus
-
Don't multicast this to all members, just apply it to local consumers.
- notifyServiceDown() - Method in class org.jgroups.mux.MuxChannel
- notifySuspect(Address) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- notifyUnblock() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- notifyViewChange(View) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- NULL - Static variable in class org.jgroups.Global
- NULL_MSG - Static variable in class org.jgroups.stack.NakReceiverWindow
-
dummy for null values: ConcurrentHashMap doesn't allow null values
- num_frags - Variable in class org.jgroups.protocols.FragHeader
- num_heartbeats - Variable in class org.jgroups.protocols.FD
- num_heartbeats_received - Variable in class org.jgroups.protocols.FD_ALL
- num_heartbeats_sent - Variable in class org.jgroups.protocols.FD_ALL
- num_prev_mbrs - Variable in class org.jgroups.protocols.pbcast.GMS
-
Max number of old members to keep in history
- num_suspect_events - Variable in class org.jgroups.protocols.FD_ALL
- num_suspect_events - Variable in class org.jgroups.protocols.FD
- numReceived() - Method in class org.jgroups.util.RspList
- numSuspectedMembers() - Method in class org.jgroups.util.RspList
O
- objectFromByteBuffer(byte[]) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
- objectFromByteBuffer(byte[]) - Method in class org.jgroups.blocks.RpcDispatcher.MarshallerAdapter
- objectFromByteBuffer(byte[]) - Static method in class org.jgroups.util.Util
-
Creates an object from a byte buffer
- objectFromByteBuffer(byte[], int, int) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller2
- objectFromByteBuffer(byte[], int, int) - Method in class org.jgroups.blocks.RpcDispatcher.MarshallerAdapter
- objectFromByteBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
- objectToBuffer(Object) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller2
-
Marshals the object into a byte[] buffer and returns a Buffer with a ref to the underlying byte[] buffer, offset and length.
Note that the underlying byte[] buffer must not be changed as this would change the buffer of a message which potentially can get retransmitted, and such a retransmission would then carry a ref to a changed byte[] buffer ! - objectToBuffer(Object) - Method in class org.jgroups.blocks.RpcDispatcher.MarshallerAdapter
- objectToByteBuffer(Object) - Method in interface org.jgroups.blocks.RpcDispatcher.Marshaller
- objectToByteBuffer(Object) - Method in class org.jgroups.blocks.RpcDispatcher.MarshallerAdapter
- objectToByteBuffer(Object) - Static method in class org.jgroups.util.Util
-
Serializes/Streams an object into a byte buffer.
- offer(Object) - Method in class org.jgroups.util.SizeBoundedQueue
- offer(Object, long, TimeUnit) - Method in class org.jgroups.util.SizeBoundedQueue
- offset - Variable in class org.jgroups.Message
-
The index into the payload (usually 0)
- OLD - Static variable in class org.jgroups.blocks.MethodCall
-
Infer the method from the arguments.
- oldObjectFromByteBuffer(byte[]) - Static method in class org.jgroups.util.Util
-
For backward compatibility in JBoss 4.0.2
- oldObjectFromByteBuffer(byte[], int, int) - Static method in class org.jgroups.util.Util
- oldObjectToByteBuffer(Object) - Static method in class org.jgroups.util.Util
-
Serializes/Streams an object into a byte buffer.
- onMessage(Message) - Method in class org.jgroups.protocols.JMS
-
Implementation of the
javax.jms.MessageListener
interface. - OOB - Static variable in class org.jgroups.Message
- open() - Method in class org.jgroups.Channel
-
Re-opens a closed channel.
- open() - Method in class org.jgroups.JChannel
-
Opens the channel.
- open() - Method in class org.jgroups.mux.MuxChannel
- OPEN_BARRIER - Static variable in class org.jgroups.Event
- Option 1 - Search tag in class org.jgroups.protocols.ENCRYPT
- Section
- Option 2 - Search tag in class org.jgroups.protocols.ENCRYPT
- Section
- option2String(int) - Static method in class org.jgroups.Channel
- org.jgroups - package org.jgroups
-
Provides top-level public JGroups classes such as Channel, Message, etc.
- org.jgroups.annotations - package org.jgroups.annotations
- org.jgroups.auth - package org.jgroups.auth
- org.jgroups.blocks - package org.jgroups.blocks
-
Provides building blocks that are layered on top of channels.
- org.jgroups.conf - package org.jgroups.conf
-
Provides ways to configure a protocol stack.
- org.jgroups.debug - package org.jgroups.debug
-
Provides debug support, including testing, profiling, and a graphical view of a protocol stack.
- org.jgroups.demos - package org.jgroups.demos
-
Provides demonstrations of JGroups functionality.
- org.jgroups.demos.applets - package org.jgroups.demos.applets
-
Provides an applet that demonstrates JGroups functionality.
- org.jgroups.demos.wb - package org.jgroups.demos.wb
-
A distributed whiteboard applet implemented using JGroups.
- org.jgroups.jmx - package org.jgroups.jmx
- org.jgroups.jmx.protocols - package org.jgroups.jmx.protocols
- org.jgroups.jmx.protocols.pbcast - package org.jgroups.jmx.protocols.pbcast
- org.jgroups.mux - package org.jgroups.mux
- org.jgroups.persistence - package org.jgroups.persistence
-
Provides features for storing information to a database or file.
- org.jgroups.protocols - package org.jgroups.protocols
-
Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.
- org.jgroups.protocols.pbcast - package org.jgroups.protocols.pbcast
-
Supports probabilistic broadcasts.
- org.jgroups.stack - package org.jgroups.stack
-
Support for managing protocol stacks.
- org.jgroups.util - package org.jgroups.util
-
Provides useful functionality which cannot be assigned to any particular other package.
- outgoing_copies - Variable in class org.jgroups.protocols.DUPL
- OutgoingBufferPool - Class in org.jgroups.util
-
Maintains a pool of ExposedDataOutputStreams.
- OutgoingBufferPool(int) - Constructor for class org.jgroups.util.OutgoingBufferPool
- outputStream - Variable in class org.jgroups.stack.StateTransferInfo
- override(ProtocolData) - Method in class org.jgroups.conf.XmlConfigurator
- override(ProtocolParameter[]) - Method in class org.jgroups.conf.ProtocolData
- own_addr - Variable in class org.jgroups.protocols.PingRsp
P
- paint(Graphics) - Method in class org.jgroups.demos.applets.DrawApplet
- paint(Graphics) - Method in class org.jgroups.demos.Topology
- paintNode(Graphics, Node, FontMetrics) - Method in class org.jgroups.demos.wb.GraphPanel
- parse(InputStream) - Static method in class org.jgroups.conf.MagicNumberReader
- parse(InputStream) - Static method in class org.jgroups.conf.XmlConfigurator
- parse(Element) - Static method in class org.jgroups.conf.XmlConfigurator
- parseBindAddress(Properties, String) - Static method in class org.jgroups.util.Util
- parseBoolean(Properties, String, boolean) - Static method in class org.jgroups.util.Util
- parseClassData(Node) - Static method in class org.jgroups.conf.MagicNumberReader
- parseCommaDelimitedLongs(String) - Static method in class org.jgroups.util.Util
-
Parses comma-delimited longs; e.g., 2000,4000,8000.
- parseCommaDelimitedStrings(String) - Static method in class org.jgroups.util.Util
-
e.g.
- parseConfigurations(String) - Static method in class org.jgroups.stack.Configurator
-
Return a number of ProtocolConfigurations in a vector
- parseInt(Properties, String, int) - Static method in class org.jgroups.util.Util
- parseInterfaceList(String) - Static method in class org.jgroups.util.Util
- parseLong(Properties, String, long) - Static method in class org.jgroups.util.Util
- 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
- parseProtocols(String) - Static 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.
- parseStringList(String, String) - Static method in class org.jgroups.util.Util
- ParticipantGmsImpl - Class in org.jgroups.protocols.pbcast
- ParticipantGmsImpl(GMS) - Constructor for class org.jgroups.protocols.pbcast.ParticipantGmsImpl
- PARTITION - Class in org.jgroups.jmx.protocols
- PARTITION - Class in org.jgroups.protocols
-
Protocol to simulate a partition.
- PARTITION() - Constructor for class org.jgroups.jmx.protocols.PARTITION
- PARTITION() - Constructor for class org.jgroups.protocols.PARTITION
- PARTITION(Protocol) - Constructor for class org.jgroups.jmx.protocols.PARTITION
- partition_on - Variable in class org.jgroups.protocols.PARTITION
- PARTITIONMBean - Interface in org.jgroups.jmx.protocols
- passItDown(Event) - Method in class org.jgroups.protocols.ENCRYPT
- passItUp(Event) - Method in class org.jgroups.protocols.ENCRYPT
- passToAllUpProtocols(Event) - Method in class org.jgroups.protocols.TP
- payload - Variable in class org.jgroups.blocks.MethodCall
-
To carry arbitrary data with a method call, data needs to be serializable if sent across the wire
- payload - Variable in class org.jgroups.View
- 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.Queue
-
returns the first object on the queue, without removing it.
- peek() - Method in class org.jgroups.util.SizeBoundedQueue
- peek(long) - Method in class org.jgroups.Channel
-
Deprecated.Use a
Receiver
instead, this method will not be available in JGroups 3.0 - peek(long) - Method in class org.jgroups.JChannel
-
Just peeks at the next message, view or block.
- peek(long) - Method in class org.jgroups.jmx.JChannel
- peek(long) - Method in interface org.jgroups.jmx.JChannelMBean
- peek(long) - Method in class org.jgroups.util.Queue
-
returns the first object on the queue, without removing it.
- PERF - Static variable in class org.jgroups.Event
- PERF_TP - Class in org.jgroups.protocols
-
Measures the time for a message to travel from the channel to the transport
- PERF_TP() - Constructor for class org.jgroups.protocols.PERF_TP
- PersistenceFactory - Class in org.jgroups.persistence
- PersistenceManager - Interface in org.jgroups.persistence
- persistent_ports - Variable in class org.jgroups.protocols.TP
- persistent_ports_file - Variable in class org.jgroups.protocols.TP
- pickRandomElement(Object[]) - Static method in class org.jgroups.util.Util
- pickRandomElement(List) - Static method in class org.jgroups.util.Util
- pickSubset(Vector, double) - Static method in class org.jgroups.util.Util
-
Selects a random subset of members according to subset_percentage and returns them.
- PING - Class in org.jgroups.jmx.protocols
- PING - Class in org.jgroups.protocols
-
The PING protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
- PING() - Constructor for class org.jgroups.jmx.protocols.PING
- PING() - Constructor for class org.jgroups.protocols.PING
- PING(Protocol) - Constructor for class org.jgroups.jmx.protocols.PING
- Pinger() - Constructor for class org.jgroups.protocols.FD_PING.Pinger
- PingHeader - Class in org.jgroups.protocols
- PingHeader() - Constructor for class org.jgroups.protocols.PingHeader
- PingHeader(byte, PingRsp) - Constructor for class org.jgroups.protocols.PingHeader
- PINGMBean - Interface in org.jgroups.jmx.protocols
- PingMonitor() - Constructor for class org.jgroups.protocols.FD_ICMP.PingMonitor
- PingMonitor() - Constructor for class org.jgroups.protocols.FD_PING.PingMonitor
- PingRsp - Class in org.jgroups.protocols
- PingRsp() - Constructor for class org.jgroups.protocols.PingRsp
- PingRsp(Address, Address, boolean) - Constructor for class org.jgroups.protocols.PingRsp
- PlainConfigurator - Class in org.jgroups.conf
-
A ProtocolStackConfigurator for the old style properties.
- PlainConfigurator(String) - Constructor for class org.jgroups.conf.PlainConfigurator
-
Instantiates a PlainConfigurator with old style properties
- pm - Variable in class org.jgroups.blocks.BasicConnectionTable
- pm - Variable in class org.jgroups.protocols.TP
- pm_expiry_time - Variable in class org.jgroups.protocols.TP
- poll() - Method in class org.jgroups.util.SizeBoundedQueue
- poll(long) - Method in class org.jgroups.util.FIFOMessageQueue
- poll(long, TimeUnit) - Method in class org.jgroups.util.SizeBoundedQueue
- PORT - Static variable in class org.jgroups.stack.GossipRouter
- PortsManager - Class in org.jgroups.util
-
Maintains a list of ports used on this host, associated with time stamps.
- PortsManager() - Constructor for class org.jgroups.util.PortsManager
- PortsManager(long) - Constructor for class org.jgroups.util.PortsManager
- PortsManager(long, String) - Constructor for class org.jgroups.util.PortsManager
- PortsManager(long, String, String) - Constructor for class org.jgroups.util.PortsManager
- PortsManager(String) - Constructor for class org.jgroups.util.PortsManager
- postDeregister() - Method in class org.jgroups.jmx.JChannelFactory
- postRegister(Boolean) - Method in class org.jgroups.jmx.JChannelFactory
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.BasicTCP
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.LOOPBACK
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.TP
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.TUNNEL
- postUnmarshalling(Message, Address, Address, boolean) - Method in class org.jgroups.protocols.UDP
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.BasicTCP
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.LOOPBACK
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.TP
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.TUNNEL
- postUnmarshallingList(Message, Address, boolean) - Method in class org.jgroups.protocols.UDP
- preDeregister() - Method in class org.jgroups.jmx.JChannelFactory
- 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.
- PREPARE_VIEW - Static variable in class org.jgroups.Event
- preRegister(MBeanServer, ObjectName) - Method in class org.jgroups.jmx.JChannelFactory
- print() - Method in class org.jgroups.blocks.DistributedTree
- print(short) - Static method in class org.jgroups.Version
-
Method copied from http://www.jboss.com/index.html?module=bbinvalid input: '&op'=viewtopicinvalid input: '&t'=77231
- print(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Prints a representation of the node defined by
fqn
. - print(Throwable) - Static method in class org.jgroups.util.Util
- print(List<NetworkInterface>) - Static method in class org.jgroups.util.Util
- print_stability_history_on_failed_xmit - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
When not finding a message on an XMIT request, include the last N stability messages in the error message
- printAgeOutCache() - Method in class org.jgroups.jmx.protocols.UNICAST
- printAgeOutCache() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- printAgeOutCache() - Method in class org.jgroups.protocols.UNICAST
- printAllStocks() - Method in class org.jgroups.demos.QuoteClient
- printAllStocks() - Method in class org.jgroups.demos.QuoteServer
- printBlockingTimes() - Method in class org.jgroups.jmx.protocols.SFC
- printBlockingTimes() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- printBlockingTimes() - Method in class org.jgroups.protocols.SFC
- printBytes(double) - Static method in class org.jgroups.util.Util
- printBytes(long) - Static method in class org.jgroups.util.Util
- printCache() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- printCache() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- printCache() - Method in class org.jgroups.protocols.FD_SOCK
- printClassMap() - Method in class org.jgroups.conf.ClassConfigurator
- printConnections() - Method in class org.jgroups.jmx.protocols.TCP
- printConnections() - Method in interface org.jgroups.jmx.protocols.TCPMBean
- printConnections() - Method in class org.jgroups.jmx.protocols.UNICAST
- printConnections() - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- printConnections() - Method in class org.jgroups.protocols.BasicTCP
- printConnections() - Method in class org.jgroups.protocols.TCP_NIO
- printConnections() - Method in class org.jgroups.protocols.TCP
- printConnections() - Method in class org.jgroups.protocols.UNICAST
- printCredits() - Method in class org.jgroups.jmx.protocols.FC
- printCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
- printCredits() - Method in class org.jgroups.protocols.FC
- printDescription() - Static method in class org.jgroups.Version
-
Returns the catenation of the description and cvs fields.
- printDetails() - Method in class org.jgroups.stack.AckReceiverWindow
- printDetails() - Method in class org.jgroups.stack.AckSenderWindow
- printDetails() - Method in class org.jgroups.View
-
debug only
- printDetails(long) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Prints all members plus whether an ack has been received from those members for a given seqno
- printEvent(Event) - Static method in class org.jgroups.util.Util
- printFragments(byte[][]) - Static method in class org.jgroups.util.Util
- printHeaders() - Method in class org.jgroups.Message
- printHeaders() - Method in class org.jgroups.util.Headers
- printHighestDeliveredSeqnos() - Method in class org.jgroups.util.Digest
- printHighestReceivedSeqnos() - Method in class org.jgroups.util.Digest
- printListWithDelimiter(Collection<T>, String) - Static method in class org.jgroups.util.Util
- printLossRate() - Method in class org.jgroups.stack.NakReceiverWindow
- printLossRates() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printLossRates() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printLossRates() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printMagicMap() - Method in class org.jgroups.conf.ClassConfigurator
- printMembers(Vector) - Static method in class org.jgroups.util.Util
- printMergeHistory() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printMergeHistory() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printMergeHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printMessage(Message) - Static method in class org.jgroups.util.Util
-
Tries to read an object from the message's buffer and prints it
- printMessages() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printMessages() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printMethodCall(Message) - Static method in class org.jgroups.util.Util
-
Tries to read a
MethodCall
object from the message's buffer and prints it. - printMissing() - Method in class org.jgroups.util.AckCollector
- printObjectHeaders() - Method in class org.jgroups.Message
- printObjectHeaders() - Method in class org.jgroups.util.Headers
- printPendingCreditors() - Method in class org.jgroups.jmx.protocols.SFC
- printPendingCreditors() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- printPendingCreditors() - Method in class org.jgroups.protocols.SFC
- printPendingRequesters() - Method in class org.jgroups.jmx.protocols.SFC
- printPendingRequesters() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- printPendingRequesters() - Method in class org.jgroups.protocols.SFC
- printPingRsps(List<PingRsp>) - Static method in class org.jgroups.util.Util
- printPreviousMembers() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- printPreviousMembers() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- printPreviousMembers() - Method in class org.jgroups.protocols.pbcast.GMS
- printPreviousViews() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- printPreviousViews() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- printPreviousViews() - Method in class org.jgroups.protocols.pbcast.GMS
- printProtocolSpec(boolean) - Method in class org.jgroups.JChannel
-
Returns a pretty-printed form of all the protocols.
- printProtocolSpec(boolean) - Method in class org.jgroups.jmx.JChannel
- printProtocolSpec(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- printProtocolSpec(boolean) - Method in class org.jgroups.stack.ProtocolStack
-
Prints the names of the protocols, from the bottom to top.
- printProtocolSpecAsPlainString() - Method in class org.jgroups.stack.ProtocolStack
- printProtocolSpecAsXML() - Method in class org.jgroups.stack.ProtocolStack
- printReceived() - Method in class org.jgroups.jmx.protocols.SFC
- printReceived() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- printReceived() - Method in class org.jgroups.protocols.SFC
- printReceived() - Method in class org.jgroups.util.AckCollector
- printReceiverCredits() - Method in class org.jgroups.jmx.protocols.FC
- printReceiverCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
- printReceiverCredits() - Method in class org.jgroups.protocols.FC
- printRetransmissionAvgs() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printRetransmissionAvgs() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printRetransmissionAvgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printRetransmissionTimes() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printRetransmissionTimes() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printRetransmissionTimes() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printSenderCredits() - Method in class org.jgroups.jmx.protocols.FC
- printSenderCredits() - Method in interface org.jgroups.jmx.protocols.FCMBean
- printSenderCredits() - Method in class org.jgroups.protocols.FC
- printSmoothedRetransmissionAvgs() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printSmoothedRetransmissionAvgs() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printSmoothedRetransmissionAvgs() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printStabilityHistory() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printStabilityMessages() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printStabilityMessages() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- printStabilityMessages() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printStackTrace(Throwable) - Static method in class org.jgroups.util.Util
-
Use with caution: lots of overhead
- printStats() - Method in class org.jgroups.jmx.Protocol
- printStats() - Method in interface org.jgroups.jmx.ProtocolMBean
- printStats() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- printStats() - Method in class org.jgroups.jmx.protocols.STATS
- printStats() - Method in interface org.jgroups.jmx.protocols.STATSMBean
- printStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
- printStats() - Method in class org.jgroups.protocols.SEQUENCER
- printStats() - Method in class org.jgroups.protocols.STATS
- printStats() - Method in class org.jgroups.stack.Protocol
- printSuspectHistory() - Method in class org.jgroups.jmx.protocols.FD_ALL
- printSuspectHistory() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- printSuspectHistory() - Method in class org.jgroups.jmx.protocols.FD_SOCK
- printSuspectHistory() - Method in interface org.jgroups.jmx.protocols.FD_SOCKMBean
- printSuspectHistory() - Method in class org.jgroups.jmx.protocols.FD
- printSuspectHistory() - Method in interface org.jgroups.jmx.protocols.FDMBean
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_ALL
- printSuspectHistory() - Method in class org.jgroups.protocols.FD_SOCK
- printSuspectHistory() - Method in class org.jgroups.protocols.FD
- printThreads() - Static method in class org.jgroups.util.Util
- printTimestamps() - Method in class org.jgroups.jmx.protocols.FD_ALL
- printTimestamps() - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- printTimestamps() - Method in class org.jgroups.protocols.FD_ALL
- printVersion() - Static method in class org.jgroups.Version
-
Returns the version field as a String.
- printXmitTable() - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- printXmitTable() - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- processEvent(String, AWTEvent) - Method in class org.jgroups.demos.DrawRepl
- processResponses(RspList, int, Object) - Method in class org.jgroups.blocks.DistributedLockManager
-
Processes the response list and votes like the default processResponses method with the consensusType VOTE_ALL If the result of the voting is false, but this DistributedLockManager owns the lock, the result is changed to true and the lock is released, but marked as multiple locked.
- processResponses(RspList, int, Object) - Method in interface org.jgroups.blocks.VoteResponseProcessor
-
Processes the responses returned by the other nodes.
- processResponses(RspList, int, Object) - Method in class org.jgroups.blocks.VotingAdapter
-
Processes the response list and makes a decision according to the type of the consensus for current voting.
- Profiler - Class in org.jgroups.debug
-
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 in org.jgroups.debug
- Promise<T> - Class in org.jgroups.util
-
Allows a thread to submit an asynchronous request and to wait for the result.
- Promise() - Constructor for class org.jgroups.util.Promise
- prompt(String) - Static method in class org.jgroups.util.Util
- props - Variable in class org.jgroups.stack.Protocol
- prot_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
- Protocol - Class in org.jgroups.jmx
- Protocol - Class in org.jgroups.stack
-
The Protocol class provides a set of common services for protocol layers.
- Protocol() - Constructor for class org.jgroups.jmx.Protocol
- Protocol() - Constructor for class org.jgroups.stack.Protocol
- Protocol(Protocol) - Constructor for class org.jgroups.jmx.Protocol
- ProtocolAdapter(String, String, Protocol, Protocol, String, Address) - Constructor for class org.jgroups.protocols.TP.ProtocolAdapter
- ProtocolConfiguration() - Constructor for class org.jgroups.stack.Configurator.ProtocolConfiguration
- ProtocolConfiguration(String) - Constructor for class org.jgroups.stack.Configurator.ProtocolConfiguration
-
Creates a new ProtocolConfiguration.
- ProtocolData - Class in org.jgroups.conf
- ProtocolData(String, String, String, ProtocolParameter[]) - Constructor for class org.jgroups.conf.ProtocolData
- ProtocolData(String, ProtocolParameter[]) - Constructor for class org.jgroups.conf.ProtocolData
- ProtocolMBean - Interface in org.jgroups.jmx
- ProtocolParameter - Class in org.jgroups.conf
-
Data holder for protocol data
- ProtocolParameter(String, String) - Constructor for class org.jgroups.conf.ProtocolParameter
- ProtocolStack - Class in org.jgroups.stack
-
A ProtocolStack manages a number of protocols layered above each other.
- ProtocolStack() - Constructor for class org.jgroups.stack.ProtocolStack
-
Only used by Simulator; don't use
- ProtocolStack(JChannel, String) - Constructor for class org.jgroups.stack.ProtocolStack
- ProtocolStackConfigurator - Interface in org.jgroups.conf
- ProtocolTester - Class in org.jgroups.debug
-
Generic class to test one or more protocol layers directly.
- ProtocolTester(String, Protocol) - Constructor for class org.jgroups.debug.ProtocolTester
- providedDownServices() - Method in class org.jgroups.protocols.pbcast.FLUSH
- providedDownServices() - Method in class org.jgroups.stack.Protocol
-
List of events that are provided to layers below (they will be handled when sent down from below).
- providedUpServices() - Method in class org.jgroups.protocols.Discovery
- providedUpServices() - Method in class org.jgroups.protocols.pbcast.NAKACK
- 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).
- Proxy - Class in org.jgroups.util
-
Redirects incoming TCP connections to other hosts/ports.
- Proxy(InetAddress, int, InetAddress, int, boolean, boolean) - Constructor for class org.jgroups.util.Proxy
- Proxy(InetAddress, int, InetAddress, int, boolean, boolean, String) - Constructor for class org.jgroups.util.Proxy
- PullHeader() - Constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- PullHeader(Serializable) - Constructor for class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- PullPushAdapter - Class in org.jgroups.blocks
-
Deprecated.Use
Receiver
instead, this class will be removed in JGroups 3.0 - PullPushAdapter(Transport) - Constructor for class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- PullPushAdapter(Transport, MembershipListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- PullPushAdapter(Transport, MessageListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- PullPushAdapter(Transport, MessageListener, MembershipListener) - Constructor for class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- PullPushAdapter(Transport, MessageListener, MembershipListener, boolean) - Constructor for class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- PullPushAdapter.PullHeader - Class in org.jgroups.blocks
-
Deprecated.
- put(Object) - Method in class org.jgroups.util.SizeBoundedQueue
- put(Object, Object) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Maps the specified key to the specified value in the hashtable.
- put(Object, Object) - Method in class org.jgroups.blocks.MethodCall
- put(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.Maps the specified key to the specified value in the hashtable.
- put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a key and value to a given node.
- put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
-
Adds a new node to the tree and sets its data.
- put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Maps the specified key to the specified value in this table.
- put(Address, K, V) - Method in class org.jgroups.util.FIFOMessageQueue
- put(Address, Rsp) - Method in class org.jgroups.util.RspList
- put(ExposedDataOutputStream) - Method in class org.jgroups.util.OutgoingBufferPool
- putAll(Map) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.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
-
Deprecated.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<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Copies all of the mappings from the specified map to this one.
- putAll(Map<? extends Address, ? extends Rsp>) - Method in class org.jgroups.util.RspList
- putHeader(String, Header) - Method in class org.jgroups.Message
-
Puts a header given a key into the hashmap.
- putHeader(String, Header) - Method in class org.jgroups.util.Headers
-
Puts a header given a key into the hashmap.
- putHeaderIfAbsent(String, Header) - Method in class org.jgroups.Message
-
Puts a header given a key into the map, only if the key doesn't exist yet
- putHeaderIfAbsent(String, Header) - Method in class org.jgroups.util.Headers
-
Puts a header given a key into the map, only if the key doesn't exist yet
- putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
Q
- Queue - Class in org.jgroups.util
-
Elements are added at the tail and removed from the head.
- Queue() - Constructor for class org.jgroups.util.Queue
-
creates an empty queue
- QueueClosedException - Exception Class in org.jgroups.util
- QueueClosedException() - Constructor for exception class org.jgroups.util.QueueClosedException
- QueueClosedException(String) - Constructor for exception class org.jgroups.util.QueueClosedException
- QuoteClient - Class in org.jgroups.demos
-
Used in conjunction with QuoteServer: a client is member of a group of quote servers which replicate stock quotes among themselves.
- QuoteClient() - Constructor for class org.jgroups.demos.QuoteClient
- QuoteServer - Class in org.jgroups.demos
-
Example of a replicated quote server.
- QuoteServer() - Constructor for class org.jgroups.demos.QuoteServer
R
- random(long) - Static method in class org.jgroups.util.Util
-
Returns a random value in the range [1 - range]
- Range - Class in org.jgroups.util
- Range() - Constructor for class org.jgroups.util.Range
-
For externalization
- Range(long, long) - Constructor for class org.jgroups.util.Range
- rc - Variable in class org.jgroups.blocks.DistributedTree
- read() - Method in class org.jgroups.util.ExposedByteArrayInputStream
- read(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayInputStream
- read(ObjectInput) - Static method in class org.jgroups.util.Marshaller
-
reads the magic number, instantiates the class (from the configurator) and invokes the readExternal method on the object.
- readAddress(DataInputStream) - Static method in class org.jgroups.util.Util
- readAddresses(DataInputStream, Class) - Static method in class org.jgroups.util.Util
- readAuthToken(DataInputStream) - Static method in class org.jgroups.util.Util
- readByteBuffer(DataInputStream) - Static method in class org.jgroups.util.Util
- readClassDescriptor() - Method in class org.jgroups.util.MagicObjectInputStream
- readCompleteMsgBuffer() - Method in class org.jgroups.blocks.NBMessageForm_NIO
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.MethodCall
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- readExternal(ObjectInput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- readExternal(ObjectInput) - Method in class org.jgroups.MergeView
- readExternal(ObjectInput) - Method in class org.jgroups.Message
- readExternal(ObjectInput) - Method in class org.jgroups.mux.MuxHeader
- readExternal(ObjectInput) - Method in class org.jgroups.mux.ServiceInfo
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.AuthHeader
- 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.CAUSAL.CausalNewViewHeader
-
Manual deserialization
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.FC.FcHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.FD_ALL.Header
- 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.FD.FdHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.FragHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Read object from external input.
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.MERGE3.CoordAnnouncement
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.MERGEFAST.MergefastHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- 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.STABLE.StableHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.PingHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.SFC.Header
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.SMACK.SmackHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.TcpHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.TpHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.TunnelHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.UdpHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- readExternal(ObjectInput) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- readExternal(ObjectInput) - Method in class org.jgroups.stack.IpAddress
- readExternal(ObjectInput) - Method in class org.jgroups.util.Digest.Entry
- readExternal(ObjectInput) - Method in class org.jgroups.util.Digest
- readExternal(ObjectInput) - Method in class org.jgroups.util.Range
- readExternal(ObjectInput) - Method in class org.jgroups.View
- readExternal(ObjectInput) - Method in class org.jgroups.ViewId
- readFrom(DataInputStream) - Method in class org.jgroups.auth.FixedMembershipToken
-
Required to deserialize the object when read in from the wire
- readFrom(DataInputStream) - Method in class org.jgroups.auth.MD5Token
- readFrom(DataInputStream) - Method in class org.jgroups.auth.SimpleToken
-
Required to deserialize the object when read in from the wire
- readFrom(DataInputStream) - Method in class org.jgroups.auth.X509Token
- readFrom(DataInputStream) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- readFrom(DataInputStream) - Method in class org.jgroups.demos.DrawCommand
- readFrom(DataInputStream) - Method in class org.jgroups.MergeView
- readFrom(DataInputStream) - Method in class org.jgroups.Message
- readFrom(DataInputStream) - Method in class org.jgroups.mux.MuxHeader
- readFrom(DataInputStream) - Method in class org.jgroups.mux.ServiceInfo
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.AuthHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.CAUSAL.CausalHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FC.FcHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD_ALL.Header
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FD.FdHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.FragHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.JMS.JMSAddress
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.JoinRsp
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.PingHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.PingRsp
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.SFC.Header
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.SMACK.SmackHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.TcpHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.TpHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.TunnelHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.UdpHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- readFrom(DataInputStream) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- readFrom(DataInputStream) - Method in class org.jgroups.stack.GossipData
- readFrom(DataInputStream) - Method in class org.jgroups.stack.IpAddress
- readFrom(DataInputStream) - Method in class org.jgroups.util.Digest.Entry
- readFrom(DataInputStream) - Method in class org.jgroups.util.Digest
- readFrom(DataInputStream) - Method in class org.jgroups.util.Range
- readFrom(DataInputStream) - Method in interface org.jgroups.util.Streamable
-
Read the state of the current object (including superclasses) from instream Note that the input stream must not be closed
- readFrom(DataInputStream) - Method in class org.jgroups.View
- readFrom(DataInputStream) - Method in class org.jgroups.ViewId
- readGenericStreamable(DataInputStream) - Static method in class org.jgroups.util.Util
- readMagicNumberMapping() - Method in class org.jgroups.conf.MagicNumberReader
-
try to read the magic number configuration file as a Resource form the classpath using getResourceAsStream if this fails this method tries to read the configuration file from mMagicNumberFile using a FileInputStream (not in classpath but somewhere else in the disk)
- readObject(DataInputStream) - Static method in class org.jgroups.util.Util
- readStreamable(Class, DataInputStream) - Static method in class org.jgroups.util.Util
- readString(DataInputStream) - Static method in class org.jgroups.util.Util
- reaper_interval - Variable in class org.jgroups.protocols.BasicTCP
- reason - Variable in exception class org.jgroups.persistence.CannotConnectException
- reason - Variable in exception class org.jgroups.persistence.CannotRemoveException
- REBROADCAST - Static variable in class org.jgroups.Event
- receive(long) - Method in class org.jgroups.Channel
-
Deprecated.Use a
Receiver
instead - receive(long) - Method in class org.jgroups.JChannel
-
Deprecated.Use a
Receiver
instead - receive(long) - Method in class org.jgroups.jmx.JChannel
- receive(long) - Method in interface org.jgroups.jmx.JChannelMBean
- receive(long) - Method in class org.jgroups.stack.ProtocolStack
- receive(long) - Method in interface org.jgroups.Transport
- receive(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Calls the receiver callback.
- receive(Address, byte[], int, int) - Method in interface org.jgroups.blocks.BasicConnectionTable.Receiver
- receive(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
-
ConnectionTable.Receiver interface
- receive(Address, Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Subclasses must call this method when a unicast or multicast message has been received.
- receive(Event) - Method in class org.jgroups.blocks.RequestCorrelator
-
Callback.
- receive(Event) - Method in class org.jgroups.debug.Simulator
- receive(Event) - Method in interface org.jgroups.debug.Simulator.Receiver
- receive(Message) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- receive(Message) - Method in class org.jgroups.blocks.DistributedQueue
- receive(Message) - Method in class org.jgroups.blocks.DistributedTree
- 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.ReplicatedHashMap
- receive(Message) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- receive(Message) - Method in class org.jgroups.blocks.ReplicatedTree
-
Callback.
- receive(Message) - Method in class org.jgroups.blocks.VotingAdapter
-
Receive the message.
- receive(Message) - Method in class org.jgroups.demos.ChatCore
- receive(Message) - Method in class org.jgroups.demos.Draw
- 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.ExtendedReceiverAdapter
- receive(Message) - Method in interface org.jgroups.MessageListener
-
Called when a message is received.
- receive(Message) - Method in class org.jgroups.ReceiverAdapter
- received_bytes - Variable in class org.jgroups.JChannel
- received_msgs - Variable in class org.jgroups.JChannel
- receiveMessage(Message) - Method in class org.jgroups.blocks.RequestCorrelator
-
Handles a message coming from a layer below
- receiver - Variable in class org.jgroups.Channel
- Receiver - Interface in org.jgroups
-
Defines the callbacks that are invoked when messages, views etc are received on a channel
- receiver_thread - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- ReceiverAdapter - Class in org.jgroups
- ReceiverAdapter() - Constructor for class org.jgroups.ReceiverAdapter
- receiveResponse(Object, Address) - Method in class org.jgroups.blocks.GroupRequest
-
Callback (called by RequestCorrelator or Transport).
- receiveResponse(Object, Address) - Method in interface org.jgroups.blocks.RspCollector
- receiveSuspect(Address) - Method in class org.jgroups.blocks.RequestCorrelator
-
Event.SUSPECT event received from a layer below.
- receiveView(View) - Method in class org.jgroups.blocks.RequestCorrelator
-
Event.VIEW_CHANGE event received from a layer below.
- register(String, Address) - Method in class org.jgroups.stack.GossipClient
-
Adds the member to the given group.
- REGISTER - Static variable in class org.jgroups.stack.GossipRouter
- registerChannel(JChannel, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Registers an already created channel with the MBeanServer.
- registerChannel(JChannel, MBeanServer, String, String, boolean) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Registers an already created channel with the MBeanServer.
- registerChannelFactory(JChannelFactory, MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
- registerForStateTransfer(String, String) - Method in class org.jgroups.mux.Multiplexer
- registerListener(Serializable, MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.Sets a listener to messages with a given identifier.
- registerManager(PersistenceManager) - Method in class org.jgroups.persistence.PersistenceFactory
-
Register a custom persistence manager as opposed to the
FilePersistenceManager
orDBPersistenceManager
. - registerProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
- registerProbeHandler(TP.ProbeHandler) - Method in class org.jgroups.protocols.TP
- registerProtocols(MBeanServer, JChannel, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Takes all protocols of an existing stack, creates corresponding MBean proxies and registers them with the MBean server
- rejectedExecution(Runnable, ThreadPoolExecutor) - Method in class org.jgroups.util.ShutdownRejectedExecutionHandler
- remainingCapacity() - Method in class org.jgroups.util.SizeBoundedQueue
- remove() - Method in class org.jgroups.blocks.DistributedQueue
-
Try to return the first objet in the queue.It does not wait for an object.
- remove() - Method in class org.jgroups.stack.AckReceiverWindow
-
Removes a message whose seqno is equal to
next_to_remove
, increments the latter. - remove() - Method in class org.jgroups.stack.NakReceiverWindow
- remove() - Method in class org.jgroups.util.Queue
-
Removes 1 element from head or blocks until next element has been added or until queue has been closed
- remove() - Method in class org.jgroups.util.SizeBoundedQueue
- remove(int) - Method in class org.jgroups.util.UnmodifiableVector
- remove(long) - Method in class org.jgroups.blocks.DistributedQueue
- remove(long) - Method in class org.jgroups.stack.Retransmitter
-
Remove the given sequence number from the list of seqnos eligible for retransmission.
- remove(long) - Method in class org.jgroups.util.Queue
-
Removes 1 element from the head.
- remove(Serializable) - Method in class org.jgroups.persistence.DBPersistenceManager
-
Removes existing entry.
- remove(Serializable) - Method in class org.jgroups.persistence.FilePersistenceManager
-
Remove existing NV from being persisted
- remove(Serializable) - Method in interface org.jgroups.persistence.PersistenceManager
-
Remove existing NV from being persisted
- remove(Object) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Removes the key (and its corresponding value) from the Hashtable.
- remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Removes the key (and its corresponding value) from this map.
- remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.Removes the key (and its corresponding value) from the Hashtable.
- remove(Object) - Method in class org.jgroups.util.RspList
- remove(Object) - Method in class org.jgroups.util.SizeBoundedQueue
- remove(Object) - Method in class org.jgroups.util.UnmodifiableVector
- remove(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- remove(Object, Vector) - Method in class org.jgroups.stack.AckMcastReceiverWindow
- remove(String) - Method in class org.jgroups.blocks.DistributedTree
- remove(String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Removes the node from the tree.
- remove(String, int) - Method in class org.jgroups.blocks.DistributedTree
- remove(String, String) - Method in class org.jgroups.blocks.ReplicatedTree
-
Removes
key
from the node's hashmap - remove(Collection<Address>) - Method in class org.jgroups.Membership
-
removes all the members contained in v from this membership
- remove(K) - Method in class org.jgroups.util.AgeOutCache
- remove(Address) - Method in class org.jgroups.Membership
-
removes an member from the membership.
- remove(Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Remove
obj
from all receiver sets and wake up retransmission thread. - remove(Address) - Method in class org.jgroups.util.ResponseCollector
- remove(Address) - Method in class org.jgroups.util.SeqnoTable
- removeAll() - Method in class org.jgroups.stack.AckMcastReceiverWindow
- removeAll(Collection) - Method in class org.jgroups.util.SizeBoundedQueue
- removeAll(Collection) - Method in class org.jgroups.util.UnmodifiableVector
- removeAll(Collection<K>) - Method in class org.jgroups.util.AgeOutCache
- removeAllConnections() - Method in class org.jgroups.protocols.UNICAST
-
This method is public only so it can be invoked by unit testing, but should not otherwise be used !
- removeAllElements() - Method in class org.jgroups.util.UnmodifiableVector
- removeChannelListener(ChannelListener) - Method in class org.jgroups.blocks.RpcDispatcher
- removeChannelListener(ChannelListener) - Method in class org.jgroups.Channel
- removeChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
- removeConfig(String) - Method in class org.jgroups.JChannelFactory
- removeConfig(String) - Method in class org.jgroups.jmx.JChannelFactory
- removeConfig(String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- removeConnection(Address) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Remove
addr
from connection table. - removeConnection(Address) - Method in class org.jgroups.protocols.UNICAST
-
Removes and resets from connection table (which is already locked).
- removeConnectionListener(BasicConnectionTable.ConnectionListener) - Method in class org.jgroups.blocks.BasicConnectionTable
- removeDistributedTreeListener(DistributedTree.DistributedTreeListener) - Method in class org.jgroups.blocks.DistributedTree
- removeElement(Object) - Method in class org.jgroups.util.Queue
-
removes a specific object from the queue.
- removeElement(Object) - Method in class org.jgroups.util.UnmodifiableVector
- removeElementAt(int) - Method in class org.jgroups.util.UnmodifiableVector
- removeFromHead() - Method in class org.jgroups.util.BoundedList
- removeFromNotSeenList(Address) - Method in class org.jgroups.protocols.pbcast.Gossip
-
Removes obj from not_seen list
- removeHeader(String) - Method in class org.jgroups.Message
-
Deprecated.Use getHeader() instead. The issue with removing a header is described in http://jira.jboss.com/jira/browse/JGRP-393
- removeHeader(String) - Method in class org.jgroups.util.Headers
-
Deprecated.Use getHeader() instead. The issue with removing a header is described in http://jira.jboss.com/jira/browse/JGRP-393
- removeIgnoredMember(Address) - Method in class org.jgroups.protocols.DISCARD
- removeListener(TwoPhaseVotingListener) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
-
Removes the listener from the voteChannel
- removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MembershipListenerAdapter
-
Remove membership listener from this adapter.
- removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- removeMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.VotingAdapter
- 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
-
Deprecated.
- removeNotifier(DistributedQueue.Notification) - Method in class org.jgroups.blocks.DistributedQueue
- removeNotifier(ReplicatedHashMap.Notification) - Method in class org.jgroups.blocks.ReplicatedHashMap
- removeOOBMessage() - Method in class org.jgroups.stack.AckReceiverWindow
- removeOOBMessage() - Method in class org.jgroups.stack.NakReceiverWindow
- removePort(int) - Method in class org.jgroups.util.PortsManager
-
Loads the file, removes the port (if existent) and closes the file again
- removeProtocol(String) - Method in class org.jgroups.stack.ProtocolStack
-
Removes a protocol from the stack.
- removeProtocol(Protocol, String) - Static method in class org.jgroups.stack.Configurator
-
Removes a protocol from the stack.
- removeReplicatedTreeListener(ReplicatedTree.ReplicatedTreeListener) - Method in class org.jgroups.blocks.ReplicatedTree
- removeService(String) - Method in class org.jgroups.mux.Multiplexer
- removeStateTransferListener(ReplicatedHashtable.StateTransferListener) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- removeViewListener(DistributedTree.ViewListener) - Method in class org.jgroups.blocks.DistributedTree
- removeVoteListener(VotingListener) - Method in class org.jgroups.blocks.VotingAdapter
-
Removes voting listener.
- renameThread(String, Thread) - Method in class org.jgroups.util.DefaultThreadFactory
- renameThread(String, Thread) - Method in interface org.jgroups.util.ThreadFactory
- renameThread(String, Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
- renameThread(Thread) - Method in class org.jgroups.util.DefaultThreadFactory
- renameThread(Thread, String, String) - Method in class org.jgroups.util.DefaultThreadFactory
- renameThreads() - Method in class org.jgroups.util.LazyThreadFactory
- repaint() - Method in class org.jgroups.demos.wb.Whiteboard
- replace(String, String, String) - Static method in class org.jgroups.conf.XmlConfigurator
- replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- replace(Digest) - Method in class org.jgroups.util.MutableDigest
- REPLENISH - Static variable in class org.jgroups.protocols.FC.FcHeader
- REPLENISH - Static variable in class org.jgroups.protocols.SFC.Header
- ReplicatedHashMap<K,
V> - Class in org.jgroups.blocks -
Subclass of a
ConcurrentHashMap
with replication of the contents across a cluster. - ReplicatedHashMap(String, ChannelFactory, String, boolean, long) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Creates a ReplicatedHashMap.
- ReplicatedHashMap(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
-
Creates a ReplicatedHashMap
- ReplicatedHashMap(Channel) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
- ReplicatedHashMap(Channel, boolean) - Constructor for class org.jgroups.blocks.ReplicatedHashMap
- ReplicatedHashMap.Notification<K,
V> - Interface in org.jgroups.blocks - ReplicatedHashMapDemo - Class in org.jgroups.demos
-
Uses the ReplicatedHashMap building block, which subclasses java.util.HashMap and overrides the methods that modify the hashmap (e.g.
- ReplicatedHashMapDemo() - Constructor for class org.jgroups.demos.ReplicatedHashMapDemo
- ReplicatedHashtable - Class in org.jgroups.blocks
-
Deprecated.Use
ReplicatedHashMap
instead - ReplicatedHashtable(String, ChannelFactory, String, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- ReplicatedHashtable(String, ChannelFactory, ReplicatedHashtable.StateTransferListener, String, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.Creates a ReplicatedHashtable
- ReplicatedHashtable(JChannel, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- ReplicatedHashtable(JChannel, ReplicatedHashtable.StateTransferListener, long) - Constructor for class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- ReplicatedHashtable.Notification - Interface in org.jgroups.blocks
-
Deprecated.
- ReplicatedHashtable.StateTransferListener - Interface in org.jgroups.blocks
-
Deprecated.
- ReplicatedMap<K,
V> - Interface in org.jgroups.blocks - ReplicatedTree - Class in org.jgroups.blocks
-
A tree-like structure that is replicated across several members.
- ReplicatedTree() - Constructor for class org.jgroups.blocks.ReplicatedTree
- ReplicatedTree(String, String, long) - Constructor for class org.jgroups.blocks.ReplicatedTree
-
Creates a channel with the given properties.
- ReplicatedTree(String, String, long, boolean) - Constructor for class org.jgroups.blocks.ReplicatedTree
- ReplicatedTree(JChannel) - Constructor for class org.jgroups.blocks.ReplicatedTree
-
Expects an already connected channel.
- ReplicatedTree.Node - Class in org.jgroups.blocks
- ReplicatedTree.ReplicatedTreeListener - Interface in org.jgroups.blocks
- ReplicatedTreeDemo - Class in org.jgroups.demos
-
Graphical view of a ReplicatedTree
- ReplicatedTreeDemo() - Constructor for class org.jgroups.demos.ReplicatedTreeDemo
- REQ - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
- REQ - Static variable in class org.jgroups.protocols.BSH.BshHeader
- req_handler - Variable in class org.jgroups.blocks.MessageDispatcher
- req_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
-
Marshaller to marshall requests at the caller and unmarshal requests at the receiver(s)
- request_handler - Variable in class org.jgroups.blocks.RequestCorrelator
-
The handler for the incoming requests.
- request_msg - Variable in class org.jgroups.blocks.GroupRequest
- RequestCorrelator - Class in org.jgroups.blocks
-
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, 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(String, Object, RequestHandler, Address) - Constructor for class org.jgroups.blocks.RequestCorrelator
- RequestCorrelator.Header - Class in org.jgroups.blocks
-
The header for RequestCorrelator messages
- requester - Variable in class org.jgroups.blocks.DistributedLockManager.LockDecree
- RequestHandler - Interface in org.jgroups.blocks
- 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.MERGE2
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.GMS
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STABLE
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- requiredDownServices() - Method in class org.jgroups.protocols.pbcast.STREAMING_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.stack.Protocol
-
List of events that are required to be answered by some layer above.
- reset() - Method in class org.jgroups.blocks.DistributedQueue
- reset() - Method in class org.jgroups.blocks.NBMessageForm_NIO
- reset() - Method in class org.jgroups.protocols.ENCRYPT
-
Just remove if you don't need to reset any state
- reset() - Static method in class org.jgroups.protocols.EXAMPLE
-
Just remove if you don't need to reset any state
- reset() - Method in class org.jgroups.protocols.PERF_TP
- 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.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.ExposedByteArrayInputStream
- reset() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Resets the
count
field of this byte array output stream to zero, so that all currently accumulated output in the output stream is discarded. - reset() - Method in class org.jgroups.util.ExposedDataOutputStream
- reset() - Method in class org.jgroups.util.Promise
-
Causes all waiting threads to return
- reset() - Method in class org.jgroups.util.Queue
-
resets the queue.
- reset() - Method in class org.jgroups.util.ResponseCollector
- reset() - Method in class org.jgroups.util.RspList
-
Deprecated.Use
RspList.clear()
instead - reset(int) - Method in class org.jgroups.util.ExposedBufferedInputStream
- reset(int) - Method in class org.jgroups.util.ExposedBufferedOutputStream
- reset(int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Resets count and creates a new buf if the current buf is > max_size.
- reset(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
-
resets an existing node, useful after a merge when you want to tell other members of your state, but do not wish to remove and then add as two separate calls
- reset(String, Serializable, int) - Method in class org.jgroups.blocks.DistributedTree
-
resets an existing node, useful after a merge when you want to tell other members of your state, but do not wish to remove and then add as two separate calls
- reset(Collection<Address>) - Method in class org.jgroups.util.ResponseCollector
- reset(Vector<Address>) - Method in class org.jgroups.blocks.GroupRequest
-
This method sets the
membership
variable to the value ofmembers
. - reset(ViewId, List<Address>) - Method in class org.jgroups.util.AckCollector
- resetAt(Address) - Method in class org.jgroups.util.MutableDigest
-
Resets the seqnos for the sender at 'index' to 0.
- resetIgnoredMembers() - Method in class org.jgroups.protocols.DISCARD
- resetStats() - Method in class org.jgroups.JChannel
- resetStats() - Method in class org.jgroups.jmx.JChannel
- resetStats() - Method in interface org.jgroups.jmx.JChannelMBean
- resetStats() - Method in class org.jgroups.jmx.Protocol
- resetStats() - Method in interface org.jgroups.jmx.ProtocolMBean
- resetStats() - Method in class org.jgroups.jmx.protocols.SEQUENCER
- resetStats() - Method in class org.jgroups.jmx.protocols.SFC
- resetStats() - Method in class org.jgroups.protocols.DISCARD
- resetStats() - Method in class org.jgroups.protocols.Discovery
- resetStats() - Method in class org.jgroups.protocols.FC
- resetStats() - Method in class org.jgroups.protocols.FD_ALL
- resetStats() - Method in class org.jgroups.protocols.FD_SOCK
- resetStats() - Method in class org.jgroups.protocols.FD
- resetStats() - Method in class org.jgroups.protocols.FRAG
- resetStats() - Method in class org.jgroups.protocols.FRAG2
- resetStats() - Method in class org.jgroups.protocols.pbcast.GMS
- resetStats() - Method in class org.jgroups.protocols.pbcast.NAKACK
- resetStats() - Method in class org.jgroups.protocols.pbcast.STABLE
- resetStats() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- resetStats() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- resetStats() - Method in class org.jgroups.protocols.SEQUENCER
- resetStats() - Method in class org.jgroups.protocols.SFC
- resetStats() - Method in class org.jgroups.protocols.STATS
- resetStats() - Method in class org.jgroups.protocols.TP
- resetStats() - Method in class org.jgroups.protocols.UNICAST
- resetStats() - Method in class org.jgroups.protocols.VIEW_SYNC
- resetStats() - Method in class org.jgroups.stack.Protocol
- RESOLVE_DNS - Static variable in class org.jgroups.Global
- resolveClass(ObjectStreamClass) - Method in class org.jgroups.util.ContextObjectInputStream
- ResponseCollector<T> - Class in org.jgroups.util
-
Similar to AckCollector, but collects responses, not just acks.
- ResponseCollector() - Constructor for class org.jgroups.util.ResponseCollector
- ResponseCollector(Collection<Address>) - Constructor for class org.jgroups.util.ResponseCollector
- result - Variable in class org.jgroups.protocols.FlushRsp
- resume() - Method in class org.jgroups.util.ReusableThread
-
Resumes the thread.
- RESUME - Static variable in class org.jgroups.Event
- RESUME_STABLE - Static variable in class org.jgroups.Event
- resumed(Runnable) - Method in interface org.jgroups.util.SchedulerListener
- resumeMergeTask() - Method in class org.jgroups.jmx.protocols.MERGE2
- resumeMergeTask() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- resumeMergeTask() - Method in class org.jgroups.protocols.MERGE2
-
Resumes the sending of merge multicast (only if coord)
- resumeViewHandler() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- resumeViewHandler() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- resumeViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
- retainAll(Collection) - Method in class org.jgroups.util.SizeBoundedQueue
- retainAll(Collection) - Method in class org.jgroups.util.UnmodifiableVector
- retainAll(Collection<Address>) - Method in class org.jgroups.blocks.BasicConnectionTable
-
Removes all connections from ConnectionTable which are not in current_mbrs
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.BasicTCP
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP_NIO
- retainAll(Collection<Address>) - Method in class org.jgroups.protocols.TCP
- retainAll(Collection<Address>) - Method in class org.jgroups.util.SeqnoTable
- retransmit(long, long, Address) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Implementation of Retransmitter.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
andlast_seqno
. - retransmit(long, long, Address, boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
- 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, Message) - Method in interface org.jgroups.stack.AckSenderWindow.RetransmitCommand
- retransmit(long, Message, Address) - Method in class org.jgroups.protocols.SMACK
- retransmit(long, Message, Address) - Method in interface org.jgroups.stack.AckMcastSenderWindow.RetransmitCommand
-
Retranmit the given msg
- Retransmitter - Class in org.jgroups.stack
-
Maintains a pool of sequence numbers of messages that need to be retransmitted.
- Retransmitter(Address, Retransmitter.RetransmitCommand) - Constructor for class org.jgroups.stack.Retransmitter
-
Create a new Retransmitter associated with the given sender address
- Retransmitter(Address, Retransmitter.RetransmitCommand, TimeScheduler) - Constructor for class org.jgroups.stack.Retransmitter
-
Create a new Retransmitter associated with the given sender address
- Retransmitter.RetransmitCommand - Interface in org.jgroups.stack
-
Retransmit command (see Gamma et al.) used to retrieve missing messages
- 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 callingreceive()
. - returnState(byte[]) - Method in class org.jgroups.JChannel
-
Called by the application is response to receiving a
getState()
object when callingreceive()
. - returnState(byte[]) - Method in class org.jgroups.jmx.JChannel
- returnState(byte[]) - Method in interface org.jgroups.jmx.JChannelMBean
- returnState(byte[]) - Method in class org.jgroups.mux.MuxChannel
- returnState(byte[], String) - Method in class org.jgroups.Channel
-
Returns a given substate (state_id of null means return entire state)
- returnState(byte[], String) - Method in class org.jgroups.JChannel
-
Returns a substate as indicated by state_id
- returnState(byte[], String) - Method in class org.jgroups.jmx.JChannel
- returnState(byte[], String) - Method in interface org.jgroups.jmx.JChannelMBean
- returnState(byte[], String) - Method in class org.jgroups.mux.MuxChannel
- ReusableThread - Class in org.jgroups.util
-
Reusable thread class.
- ReusableThread() - Constructor for class org.jgroups.util.ReusableThread
- ReusableThread(String) - Constructor for class org.jgroups.util.ReusableThread
- ROUTER_GET - Static variable in class org.jgroups.stack.GossipRouter
- RouterStub - Class in org.jgroups.stack
-
Client stub that talks to a remote GossipRouter
- RouterStub(String, int, InetAddress) - Constructor for class org.jgroups.stack.RouterStub
-
Creates a stub for a remote Router object.
- RouterStub.ConnectionListener - Interface in org.jgroups.stack
- ROUTING_CLIENT_REPLY_TIMEOUT - Static variable in class org.jgroups.stack.GossipRouter
- RpcDispatcher - Class in org.jgroups.blocks
-
This class allows a programmer to invoke remote methods in all (or single) group members and optionally wait for the return value(s).
- RpcDispatcher() - Constructor for class org.jgroups.blocks.RpcDispatcher
- RpcDispatcher(PullPushAdapter, Serializable, MessageListener, MembershipListener, Object) - Constructor for class org.jgroups.blocks.RpcDispatcher
- 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.Marshaller - Interface in org.jgroups.blocks
- RpcDispatcher.Marshaller2 - Interface in org.jgroups.blocks
- RpcDispatcher.MarshallerAdapter - Class in org.jgroups.blocks
-
Used to provide a Marshaller2 interface to a Marshaller.
- Rsp - Class in org.jgroups.util
-
class that represents a response from a communication
- Rsp(Address) - Constructor for class org.jgroups.util.Rsp
- Rsp(Address, boolean) - Constructor for class org.jgroups.util.Rsp
- Rsp(Address, Object) - Constructor for class org.jgroups.util.Rsp
- RSP - Static variable in class org.jgroups.blocks.RequestCorrelator.Header
- RSP - Static variable in class org.jgroups.protocols.BSH.BshHeader
- rsp_expected - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
msg is synchronous if true
- rsp_filter - Variable in class org.jgroups.blocks.GroupRequest
- rsp_marshaller - Variable in class org.jgroups.blocks.RpcDispatcher
-
Marshaller to marshal responses at the receiver(s) and unmarshal responses at the caller
- rsp_mode - Variable in class org.jgroups.blocks.GroupRequest
- RspCollector - Interface in org.jgroups.blocks
- RspFilter - Interface in org.jgroups.blocks
-
Interface defining when a group request is done.
- RspList - Class in org.jgroups.util
-
Contains responses from all members.
- RspList() - Constructor for class org.jgroups.util.RspList
- RspList(Collection<Rsp>) - Constructor for class org.jgroups.util.RspList
-
Adds a list of responses
- run() - Method in class org.jgroups.blocks.ConnectionTable
-
Acceptor thread.
- run() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
Acceptor thread.
- run() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.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.applets.DrawApplet
- 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.protocols.FD_ICMP.PingMonitor
- run() - Method in class org.jgroups.protocols.FD_PING.PingMonitor
- run() - Method in class org.jgroups.protocols.FD_SOCK
-
Runs as long as there are 2 members and more.
- run() - Method in class org.jgroups.protocols.FD.BroadcastTask
- run() - Method in class org.jgroups.protocols.FD.Monitor
- run() - Method in class org.jgroups.protocols.MPING
- run() - Method in class org.jgroups.protocols.SHUFFLE
-
Removes a random chosen message from the
messages Listinvalid input: '<'\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.UDP
- run() - Method in class org.jgroups.protocols.UDP.UcastReceiver
- 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.util.ReusableThread
-
Delicate piece of code (means very important :-)).
- run() - Method in class org.jgroups.util.Scheduler
- runMessageGarbageCollection() - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- runMessageGarbageCollection() - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- runMessageGarbageCollection() - Method in class org.jgroups.protocols.pbcast.STABLE
- runRequest(Address, ByteBuffer) - Method in class org.jgroups.blocks.ConnectionTableNIO
S
- sameHost(Address, Address) - Static method in class org.jgroups.util.Util
-
Checks whether 2 Addresses are on the same host
- sameSenders(Digest) - Method in class org.jgroups.util.Digest
-
Compares two digests and returns true if the senders are the same, otherwise false.
- sanityCheck(Vector<Protocol>) - Static method in class org.jgroups.stack.Configurator
-
Throws an exception if sanity check fails.
- save(Serializable, Serializable) - Method in class org.jgroups.persistence.DBPersistenceManager
-
Saves NV pair as serializable object; creates if new, stores new state if already exists.
- save(Serializable, Serializable) - Method in class org.jgroups.persistence.FilePersistenceManager
-
Save new NV pair as serializable objects or if already exist; store new state
- save(Serializable, Serializable) - Method in interface org.jgroups.persistence.PersistenceManager
-
Save new NV pair as serializable objects or if already exist; store new state
- saveAll(Map) - Method in class org.jgroups.persistence.DBPersistenceManager
-
Saves all row entries for the map to DB.
- saveAll(Map) - Method in class org.jgroups.persistence.FilePersistenceManager
-
Use to store a complete map into persistent state
- saveAll(Map) - Method in interface org.jgroups.persistence.PersistenceManager
-
Use to store a complete map into persistent state
- saveState() - Method in class org.jgroups.demos.wb.GraphPanel
- scheduler - Variable in class org.jgroups.blocks.RequestCorrelator
-
The dispatching thread pool
- Scheduler - Class in org.jgroups.util
-
Implementation of a priority scheduler.
- Scheduler() - Constructor for class org.jgroups.util.Scheduler
- Scheduler(int) - Constructor for class org.jgroups.util.Scheduler
- SCHEDULER_MAX_THREADS - Static variable in class org.jgroups.Global
- Scheduler.Task - Class in org.jgroups.util
- SchedulerListener - Interface in org.jgroups.util
-
Provides callback for use with a
Scheduler
. - scheduleWithDynamicInterval(TimeScheduler.Task) - Method in class org.jgroups.util.TimeScheduler
-
Add a task for execution at adjustable intervals
- scheduleWithDynamicInterval(TimeScheduler.Task, boolean) - Method in class org.jgroups.util.TimeScheduler
-
Schedule a task for execution at varying intervals.
- seal() - Method in class org.jgroups.util.MutableDigest
-
Seals the instance against modifications
- SECRETKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- SECRETKEY_READY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- send(Serializable, Message) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.Sends a message to the group - listeners to this identifier will receive the messages.
- send(Address, byte[], int, int) - Method in class org.jgroups.blocks.BasicConnectionTable
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP_NIO
- send(Address, byte[], int, int) - Method in class org.jgroups.protocols.TCP
- send(Address, Address, Serializable) - Method in class org.jgroups.Channel
-
Helper method.
- 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(Address, Address, Serializable) - Method in class org.jgroups.jmx.JChannel
- send(Address, Address, Serializable) - Method in interface org.jgroups.jmx.JChannelMBean
- send(Address, Address, Serializable) - Method in class org.jgroups.mux.MuxChannel
- send(Event) - Method in class org.jgroups.debug.Simulator
- send(Message) - Method in class org.jgroups.blocks.MessageDispatcher
- send(Message) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.Sends a message with no identifier; listener member will get this message on the other group members.
- send(Message) - Method in class org.jgroups.Channel
-
Sends a message to a (unicast) destination.
- send(Message) - Method in class org.jgroups.JChannel
-
Sends a message through the protocol stack.
- send(Message) - Method in class org.jgroups.jmx.JChannel
- send(Message) - Method in interface org.jgroups.jmx.JChannelMBean
- send(Message) - Method in class org.jgroups.mux.MuxChannel
- send(Message) - Method in class org.jgroups.stack.ProtocolStack
- send(Message) - Method in interface org.jgroups.Transport
- SEND_FIRST_SEQNO - Static variable in class org.jgroups.protocols.UNICAST.UnicastHeader
- send_message - Variable in class org.jgroups.blocks.DistributedTree
-
Determines when the updates have to be sent across the network, avoids sending unnecessary messages when there are no member in the group
- sendClearPanelMsg() - Method in class org.jgroups.demos.applets.DrawApplet
- sendClearPanelMsg() - Method in class org.jgroups.demos.Draw
- sendClearPanelMsg() - Method in class org.jgroups.demos.Draw2Channels
- sendClearPanelMsg() - Method in class org.jgroups.demos.Gossip
- SendDialog - Class in org.jgroups.demos.wb
- SendDialog(Frame, Node, String, RpcDispatcher) - Constructor for class org.jgroups.demos.wb.SendDialog
- senders - Variable in class org.jgroups.util.Digest
-
Map<Address, Entry>
- sendGetMembersRequest() - Method in class org.jgroups.protocols.Discovery
- sendGetMembersRequest() - Method in class org.jgroups.protocols.PING
- sendGetMembersRequest() - Method in class org.jgroups.protocols.TCPGOSSIP
- sendGetMembersRequest() - Method in class org.jgroups.protocols.TCPPING
- sendJoinResponse(JoinRsp, Address) - Method in class org.jgroups.protocols.pbcast.GMS
- sendMergeRejectedResponse(Address, ViewId) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- sendMergeSolicitation() - Method in class org.jgroups.jmx.protocols.MERGE2
- sendMergeSolicitation() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- sendMergeSolicitation() - Method in class org.jgroups.protocols.MERGE2
-
Discovers members and detects whether we have multiple coordinator.
- sendMessage(Message) - Method in class org.jgroups.protocols.JMS
-
Publish message in the JMS topic.
- 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
- 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
- sendNotification(Address, 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, List<Address>, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
- sendRequest(long, List<Address>, Message, RspCollector, boolean) - Method in class org.jgroups.blocks.RequestCorrelator
-
Send a request to a group.
- sendRequest(long, Message, RspCollector) - Method in class org.jgroups.blocks.RequestCorrelator
-
Helper method for
RequestCorrelator.sendRequest(long,List,Message,RspCollector)
. - sendToAll(String) - Method in class org.jgroups.jmx.JChannel
- sendToAll(String) - Method in interface org.jgroups.jmx.JChannelMBean
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.LOOPBACK
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Send to all members in the group.
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.protocols.UDP
- sendToAllMembers(byte[], int, int) - Method in class org.jgroups.stack.RouterStub
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.BasicTCP
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.LOOPBACK
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.TP
-
Send to all members in the group.
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.TUNNEL
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.protocols.UDP
- sendToSingleMember(Address, byte[], int, int) - Method in class org.jgroups.stack.RouterStub
- sendUpLocalAddressEvent() - Method in class org.jgroups.protocols.TP
- sendViewRequest() - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- sendViewRequest() - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- sendViewRequest() - Method in class org.jgroups.protocols.VIEW_SYNC
-
Sends a VIEW_SYNC_REQ to all members, every member replies with a VIEW multicast
- senseMaxFragSize() - Method in class org.jgroups.protocols.AUTOCONF
-
Tries to find out the max number of bytes in a DatagramPacket we can send by sending increasingly larger packets, until there is an exception (e.g., java.io.IOException: message too long).
- senseMaxFragSizeStatic() - Static method in class org.jgroups.protocols.AUTOCONF
- sent_bytes - Variable in class org.jgroups.JChannel
- sent_msgs - Variable in class org.jgroups.JChannel
- SEPARATOR - Static variable in class org.jgroups.blocks.ReplicatedTree
- SeqnoTable - Class in org.jgroups.util
-
Maintains the highest received and highest delivered seqno per member
- SeqnoTable(long) - Constructor for class org.jgroups.util.SeqnoTable
- SEQUENCER - Class in org.jgroups.jmx.protocols
- SEQUENCER - Class in org.jgroups.protocols
-
Implementation of total order protocol using a sequencer.
- SEQUENCER() - Constructor for class org.jgroups.jmx.protocols.SEQUENCER
- SEQUENCER() - Constructor for class org.jgroups.protocols.SEQUENCER
- SEQUENCER(Protocol) - Constructor for class org.jgroups.jmx.protocols.SEQUENCER
- SEQUENCER.SequencerHeader - Class in org.jgroups.protocols
- SequencerHeader() - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
- SequencerHeader(byte, Address, long) - Constructor for class org.jgroups.protocols.SEQUENCER.SequencerHeader
- SEQUENCERMBean - Interface in org.jgroups.jmx.protocols
- serializedSize() - Method in class org.jgroups.MergeView
- serializedSize() - Method in class org.jgroups.protocols.pbcast.JoinRsp
- serializedSize() - Method in class org.jgroups.util.Digest
- serializedSize() - Method in class org.jgroups.View
- serializedSize() - Method in class org.jgroups.ViewId
- server_obj - Variable in class org.jgroups.blocks.RpcDispatcher
- SERVER_PUBKEY - Static variable in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- service_ack_timeout - Variable in class org.jgroups.mux.Multiplexer
- SERVICE_DOWN - Static variable in class org.jgroups.mux.ServiceInfo
- SERVICE_UP - Static variable in class org.jgroups.mux.ServiceInfo
- ServiceInfo - Class in org.jgroups.mux
-
Class used for service state communication between Multiplexers
- ServiceInfo() - Constructor for class org.jgroups.mux.ServiceInfo
- ServiceInfo(byte, String, Address, byte[]) - Constructor for class org.jgroups.mux.ServiceInfo
- SERVICES_MERGED - Static variable in class org.jgroups.mux.ServiceInfo
- set(int, Object) - Method in class org.jgroups.util.UnmodifiableVector
- set(Object) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
- set(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
- set(String, Serializable, int) - Method in class org.jgroups.blocks.DistributedTree
- set(Collection<Address>) - 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(Address, long, long, long) - Method in class org.jgroups.util.MutableDigest
- 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_DIGEST - Static variable in class org.jgroups.Event
- SET_LOCAL_ADDRESS - Static variable in class org.jgroups.Event
- setAdditionalData(byte[]) - Method in class org.jgroups.stack.IpAddress
-
Sets the additional_data.
- setAddress(String) - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Set the node address.
- setAddress(String) - Method in class org.jgroups.util.DefaultThreadFactory
- setAddress(String) - Method in class org.jgroups.util.LazyThreadFactory
- setAddress(String) - Method in interface org.jgroups.util.ThreadFactory
- setArg(Object) - Method in class org.jgroups.Event
- setArgs(Object[]) - Method in class org.jgroups.blocks.MethodCall
- setAssociatedMessage(Message) - Method in class org.jgroups.protocols.TransportedVectorTime
-
Sets a message associated with this vector timestamp
- setAutoGetState(boolean) - Method in class org.jgroups.jmx.JChannel
- setAutoGetState(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- setAutoReconnect(boolean) - Method in class org.jgroups.jmx.JChannel
- setAutoReconnect(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- setAverageSendInterval(long) - Method in class org.jgroups.jmx.protocols.VIEW_SYNC
- setAverageSendInterval(long) - Method in interface org.jgroups.jmx.protocols.VIEW_SYNCMBean
- setAverageSendInterval(long) - Method in class org.jgroups.protocols.VIEW_SYNC
- setBacklog(int) - Method in class org.jgroups.stack.GossipRouter
- setBindAddr(String) - Method in class org.jgroups.jmx.protocols.TCP
- setBindAddr(String) - Method in interface org.jgroups.jmx.protocols.TCPMBean
- setBindAddr(InetAddress) - Method in class org.jgroups.jmx.protocols.MPING
- setBindAddr(InetAddress) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- setBindAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
- setBindAddress(String) - Method in class org.jgroups.jmx.protocols.TP
- setBindAddress(String) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setBindAddress(String) - Method in class org.jgroups.protocols.TP
- setBindAddress(String) - Method in class org.jgroups.stack.GossipRouter
- setBindPort(int) - Method in class org.jgroups.protocols.TP
- setBindToAllInterfaces(boolean) - Method in class org.jgroups.protocols.TP
- setBlockingUpdates(boolean) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Whether updates across the cluster should be asynchronous (default) or synchronous)
- setBuffer(byte[]) - Method in class org.jgroups.Message
- setBuffer(byte[], int, int) - Method in class org.jgroups.Message
-
Set the internal buffer to point to a subset of a given buffer
- setBuffer(Buffer) - Method in class org.jgroups.Message
-
Note that the byte[] buffer passed as argument must not be modified.
- setCaller(Address) - Method in class org.jgroups.blocks.GroupRequest
- setChannel(Channel) - Method in class org.jgroups.blocks.MessageDispatcher
- setChannelListener(ChannelListener) - Method in class org.jgroups.Channel
-
Deprecated.Use addChannelListener() instead
- setChannelListener(ChannelListener) - Method in class org.jgroups.jmx.JChannel
-
Deprecated.Use addChannelListener() instead
- setChannelListener(ChannelListener) - Method in interface org.jgroups.jmx.JChannelMBean
- setClosed(boolean) - Method in class org.jgroups.mux.MuxChannel
- setClusterConfig(Element) - Method in class org.jgroups.jmx.JChannel
- setClusterConfig(Element) - Method in interface org.jgroups.jmx.JChannelMBean
-
To configure via XML file
- setClusterName(String) - Method in class org.jgroups.jmx.JChannel
- setClusterName(String) - Method in interface org.jgroups.jmx.JChannelMBean
- setClusterName(String) - Method in class org.jgroups.util.DefaultThreadFactory
- setClusterName(String) - Method in class org.jgroups.util.LazyThreadFactory
- setClusterName(String) - Method in interface org.jgroups.util.ThreadFactory
- 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
- setConnected(boolean) - Method in class org.jgroups.mux.MuxChannel
- setConnectionListener(RouterStub.ConnectionListener) - Method in class org.jgroups.stack.RouterStub
- setConnExpireTime(long) - Method in class org.jgroups.jmx.protocols.TCP
- setConnExpireTime(long) - Method in interface org.jgroups.jmx.protocols.TCPMBean
- setConnExpireTime(long) - Method in class org.jgroups.protocols.BasicTCP
- setConsumer(NotificationBus.Consumer) - Method in class org.jgroups.blocks.NotificationBus
- setData(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayInputStream
- setDeadlockDetection(boolean) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- setDeadlockDetection(boolean) - Method in class org.jgroups.blocks.DistributedTree
- setDeadlockDetection(boolean) - Method in class org.jgroups.blocks.MessageDispatcher
- setDeadlockDetection(boolean) - Method in class org.jgroups.blocks.ReplicatedHashMap
- setDeadlockDetection(boolean) - Method in class org.jgroups.blocks.RequestCorrelator
-
Switch the deadlock detection mechanism on/off
- setDecree(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- setDefaultThreadPool(Executor) - Method in class org.jgroups.protocols.TP
- setDefaultThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
- setDefaultThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.stack.GossipRouter
- setDelay(long) - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
- setDesiredAverageGossip(long) - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- setDesiredAverageGossip(long) - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- setDesiredAverageGossip(long) - Method in class org.jgroups.protocols.pbcast.STABLE
- setDest(Address) - Method in class org.jgroups.Message
- setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.GMS
-
Send down a SET_DIGEST event
- setDigest(Digest) - Method in class org.jgroups.protocols.pbcast.MergeData
- setDiscardAll(boolean) - Method in class org.jgroups.protocols.DISCARD
- setDiscardDeliveredMessages(boolean) - Method in class org.jgroups.stack.NakReceiverWindow
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- setDiscardDeliveredMsgs(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- setDiscardDeliveredMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
- setDiscardIncompatiblePackets(boolean) - Method in class org.jgroups.jmx.protocols.TP
- setDiscardIncompatiblePackets(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setDiscardIncompatiblePackets(boolean) - Method in class org.jgroups.protocols.TP
- setDiscardLoopbacks(boolean) - Method in class org.jgroups.stack.GossipRouter
- setDomain(String) - Method in class org.jgroups.JChannelFactory
- setDomain(String) - Method in class org.jgroups.jmx.JChannelFactory
- setDomain(String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- setDownDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
- setDownProtocol(Protocol) - Method in class org.jgroups.stack.Protocol
- setDropDownMulticasts(int) - Method in class org.jgroups.protocols.DISCARD
- setDropDownUnicasts(int) - Method in class org.jgroups.protocols.DISCARD
-
Drop the next N unicasts down the stack
- setElementAt(Object, int) - Method in class org.jgroups.util.UnmodifiableVector
- setEnable_unicast_bundling(boolean) - Method in class org.jgroups.protocols.TP
- setEnableBundling(boolean) - Method in class org.jgroups.jmx.protocols.TP
- setEnableBundling(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setEnableBundling(boolean) - Method in class org.jgroups.protocols.TP
- setEndPort(int) - Method in class org.jgroups.jmx.protocols.TCP
- setEndPort(int) - Method in interface org.jgroups.jmx.protocols.TCPMBean
- setEndPort(int) - Method in class org.jgroups.protocols.BasicTCP
- setException(Throwable) - Method in class org.jgroups.blocks.ConnectionTableNIO.MyFuture
- setExcludeItself(boolean) - Method in class org.jgroups.protocols.DISCARD
- setExpectedMessages(long) - Method in class org.jgroups.protocols.PERF_TP
- setExpiryTime(long) - Method in class org.jgroups.stack.GossipRouter
- setExpiryTime(long) - Method in class org.jgroups.util.PortsManager
- setExposeChannels(boolean) - Method in class org.jgroups.JChannelFactory
- setExposeChannels(boolean) - Method in class org.jgroups.jmx.JChannelFactory
- setExposeChannels(boolean) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- setExposeProtocols(boolean) - Method in class org.jgroups.JChannelFactory
- setExposeProtocols(boolean) - Method in class org.jgroups.jmx.JChannelFactory
- setExposeProtocols(boolean) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- setFailReason(String) - Method in class org.jgroups.protocols.pbcast.JoinRsp
- setFilename(String) - Method in class org.jgroups.conf.MagicNumberReader
- setFilename(String) - Static method in class org.jgroups.debug.Profiler
- setFlag(byte) - Method in class org.jgroups.Message
- setFragSize(int) - Method in class org.jgroups.jmx.protocols.FRAG
- setFragSize(int) - Method in class org.jgroups.jmx.protocols.FRAG2
- setFragSize(int) - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- setFragSize(int) - Method in interface org.jgroups.jmx.protocols.FRAGMBean
- setFragSize(int) - Method in class org.jgroups.protocols.FRAG
- setFragSize(int) - Method in class org.jgroups.protocols.FRAG2
- setGcLag(int) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- setGcLag(int) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- setGcLag(int) - Method in class org.jgroups.protocols.pbcast.NAKACK
- setGossipPort(int) - Method in class org.jgroups.protocols.PING
- setGossipRefresh(long) - Method in class org.jgroups.protocols.PING
- setGossipRequestTimeout(long) - Method in class org.jgroups.stack.GossipRouter
-
Deprecated.
- setGroupName(String) - Method in class org.jgroups.demos.Draw
- setGroupName(String) - Method in class org.jgroups.jmx.JChannel
- setGroupName(String) - Method in interface org.jgroups.jmx.JChannelMBean
- setHandler(AgeOutCache.Handler) - Method in class org.jgroups.util.AgeOutCache
- setHighestDeliveredAndSeenSeqnos(Address, long, long, long) - Method in class org.jgroups.util.MutableDigest
- setId(short) - Method in class org.jgroups.blocks.MethodCall
- setImpl(GmsImpl) - Method in class org.jgroups.protocols.pbcast.GMS
- setIncludeClusterName(boolean) - Method in class org.jgroups.util.DefaultThreadFactory
- setIncludeClusterName(boolean) - Method in interface org.jgroups.util.ThreadFactory
- setIncomingKeepAliveTime(long) - Method in class org.jgroups.jmx.protocols.TP
- setIncomingKeepAliveTime(long) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setIncomingKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
- setIncomingMaxPoolSize(int) - Method in class org.jgroups.jmx.protocols.TP
- setIncomingMaxPoolSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setIncomingMaxPoolSize(int) - Method in class org.jgroups.protocols.TP
- setIncomingMinPoolSize(int) - Method in class org.jgroups.jmx.protocols.TP
- setIncomingMinPoolSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setIncomingMinPoolSize(int) - Method in class org.jgroups.protocols.TP
- setInDelay(int) - Method in class org.jgroups.protocols.DELAY
- setInfo(String, Object) - Method in class org.jgroups.Channel
- setInfo(String, Object) - Method in class org.jgroups.JChannel
- setInitialMembers(int) - Method in class org.jgroups.jmx.protocols.Discovery
- setInitialMembers(int) - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- setInterval(long) - Method in class org.jgroups.jmx.protocols.FD_ALL
- setInterval(long) - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- setInterval(long) - Method in class org.jgroups.protocols.FD_ALL
- setJoinRetryTimeout(long) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- setJoinRetryTimeout(long) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- setJoinRetryTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
-
Deprecated.
- setJoinTimeout(long) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- setJoinTimeout(long) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- setJoinTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
- setKeyServerAddr(Address) - Method in class org.jgroups.protocols.ENCRYPT
- setLinger(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setLingerTimeout(long) - Method in class org.jgroups.stack.GossipRouter
- setListener(MessageListener) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- setListener(NakReceiverWindow.Listener) - Method in class org.jgroups.stack.NakReceiverWindow
- setListener(SchedulerListener) - Method in class org.jgroups.util.Scheduler
- setLocal_addr(Address) - Method in class org.jgroups.protocols.ENCRYPT
- setLocalAddress(Address) - Method in class org.jgroups.blocks.RequestCorrelator
- setLocalAddress(Address) - Method in class org.jgroups.debug.Simulator
- setLocalAddress(Address) - Method in class org.jgroups.protocols.DISCARD
- setLogDiscardMsgs(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
- setLoopback(boolean) - Method in class org.jgroups.jmx.protocols.TP
- setLoopback(boolean) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setLoopback(boolean) - Method in class org.jgroups.protocols.TP
- setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RequestCorrelator
- setMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
- setMaxBlockTime(long) - Method in class org.jgroups.jmx.protocols.FC
- setMaxBlockTime(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
- setMaxBlockTime(long) - Method in class org.jgroups.protocols.FC
- setMaxBundleSize(int) - Method in class org.jgroups.jmx.protocols.TP
- setMaxBundleSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setMaxBundleSize(int) - Method in class org.jgroups.protocols.TP
- setMaxBundleTimeout(long) - Method in class org.jgroups.jmx.protocols.TP
- setMaxBundleTimeout(long) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setMaxBundleTimeout(long) - Method in class org.jgroups.protocols.TP
- setMaxBundlingTime(long) - Method in class org.jgroups.protocols.pbcast.GMS
- setMaxBytes(long) - Method in class org.jgroups.jmx.protocols.pbcast.STABLE
- setMaxBytes(long) - Method in interface org.jgroups.jmx.protocols.pbcast.STABLEMBean
- setMaxBytes(long) - Method in class org.jgroups.protocols.pbcast.STABLE
- setMaxCredits(long) - Method in class org.jgroups.jmx.protocols.FC
- setMaxCredits(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
- setMaxCredits(long) - Method in class org.jgroups.protocols.FC
- setMaxInterval(long) - Method in class org.jgroups.jmx.protocols.MERGE2
- setMaxInterval(long) - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- setMaxInterval(long) - Method in class org.jgroups.protocols.MERGE2
- setMaxRetransmitTime(long) - Method in class org.jgroups.jmx.protocols.UNICAST
- setMaxRetransmitTime(long) - Method in interface org.jgroups.jmx.protocols.UNICASTMBean
- setMaxRetransmitTime(long) - Method in class org.jgroups.protocols.UNICAST
- setMaxTries(int) - Method in class org.jgroups.jmx.protocols.FD
- setMaxTries(int) - Method in interface org.jgroups.jmx.protocols.FDMBean
- setMaxTries(int) - Method in class org.jgroups.protocols.FD
- setMaxXmitBufSize(int) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- setMaxXmitBufSize(int) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- setMaxXmitBufSize(int) - Method in class org.jgroups.protocols.pbcast.NAKACK
- setMaxXmitBufSize(int) - Method in class org.jgroups.stack.NakReceiverWindow
- setMaxXmitSize(long) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
-
Deprecated.removed in 2.6
- setMaxXmitSize(long) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
-
Deprecated.removed in 2.6
- setMaxXmitSize(long) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Deprecated.removed in 2.6
- setMBeanServerName(String) - Method in class org.jgroups.jmx.JChannel
- setMcastAddr(InetAddress) - Method in class org.jgroups.jmx.protocols.MPING
- setMcastAddr(InetAddress) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- setMcastAddr(InetAddress) - Method in class org.jgroups.protocols.MPING
- setMcastPort(int) - Method in class org.jgroups.jmx.protocols.MPING
- setMcastPort(int) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- setMcastPort(int) - Method in class org.jgroups.protocols.MPING
- setMcastPort(int) - Method in class org.jgroups.protocols.UDP
- setMembers(List) - Method in class org.jgroups.stack.GossipData
- setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.MessageDispatcher
- setMembershipListener(MembershipListener) - Method in class org.jgroups.blocks.PullPushAdapter
- setMessageListener(MessageListener) - Method in class org.jgroups.blocks.MessageDispatcher
- setMethod(Method) - Method in class org.jgroups.blocks.MethodCall
- setMethodLookup(MethodLookup) - Method in class org.jgroups.blocks.RpcDispatcher
- setMinCredits(long) - Method in class org.jgroups.jmx.protocols.FC
- setMinCredits(long) - Method in interface org.jgroups.jmx.protocols.FCMBean
- setMinCredits(long) - Method in class org.jgroups.protocols.FC
- setMinInterval(long) - Method in class org.jgroups.jmx.protocols.MERGE2
- setMinInterval(long) - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- setMinInterval(long) - Method in class org.jgroups.protocols.MERGE2
- setMinThreshold(double) - Method in class org.jgroups.jmx.protocols.FC
- setMinThreshold(double) - Method in interface org.jgroups.jmx.protocols.FCMBean
- setMinThreshold(double) - Method in class org.jgroups.protocols.FC
- setMultipleLocked(boolean) - Method in class org.jgroups.blocks.DistributedLockManager.LockDecree
- setMultiplexerConfig(File) - Method in interface org.jgroups.ChannelFactory
-
Initializes the factory from a file.
- setMultiplexerConfig(File) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(File, boolean) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(Object) - Method in interface org.jgroups.ChannelFactory
-
Initializes the factory.
- setMultiplexerConfig(Object) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(Object, boolean) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(String) - Method in interface org.jgroups.ChannelFactory
- setMultiplexerConfig(String) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(String) - Method in class org.jgroups.jmx.JChannelFactory
- setMultiplexerConfig(String) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- setMultiplexerConfig(String, boolean) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(String, boolean) - Method in class org.jgroups.jmx.JChannelFactory
- setMultiplexerConfig(String, boolean) - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- setMultiplexerConfig(URL) - Method in interface org.jgroups.ChannelFactory
- setMultiplexerConfig(URL) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(URL, boolean) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(Element) - Method in interface org.jgroups.ChannelFactory
- setMultiplexerConfig(Element) - Method in class org.jgroups.JChannelFactory
- setMultiplexerConfig(Element, boolean) - Method in class org.jgroups.JChannelFactory
- 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
- setNumInitialMembers(int) - Method in class org.jgroups.protocols.Discovery
- setNumPingRequests(int) - Method in class org.jgroups.protocols.Discovery
- setObject(Serializable) - Method in class org.jgroups.Message
-
Takes an object and uses Java serialization to generate the byte[] buffer which is set in the message.
- setObjectName(String) - Method in class org.jgroups.jmx.JChannel
- setObjectName(String) - Method in interface org.jgroups.jmx.JChannelMBean
- setObserver(ENCRYPT.Observer) - Method in class org.jgroups.protocols.ENCRYPT
- setOOBKeepAliveTime(long) - Method in class org.jgroups.jmx.protocols.TP
- setOOBKeepAliveTime(long) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setOOBKeepAliveTime(long) - Method in class org.jgroups.protocols.TP
- setOOBMaxPoolSize(int) - Method in class org.jgroups.jmx.protocols.TP
- setOOBMaxPoolSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setOOBMaxPoolSize(int) - Method in class org.jgroups.protocols.TP
- setOOBMinPoolSize(int) - Method in class org.jgroups.jmx.protocols.TP
- setOOBMinPoolSize(int) - Method in interface org.jgroups.jmx.protocols.TPMBean
- setOOBMinPoolSize(int) - Method in class org.jgroups.protocols.TP
- setOOBThreadPool(Executor) - Method in class org.jgroups.protocols.TP
- setOOBThreadPoolThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
- setOpt(int, Object) - Method in class org.jgroups.Channel
-
Sets an option.
- setOpt(int, Object) - Method in class org.jgroups.JChannel
-
Sets a channel option.
- setOutDelay(int) - Method in class org.jgroups.protocols.DELAY
- setOverhead(int) - Method in class org.jgroups.jmx.protocols.FRAG2
- setOverhead(int) - Method in interface org.jgroups.jmx.protocols.FRAG2MBean
- setOverhead(int) - Method in class org.jgroups.protocols.FRAG2
- setPattern(String) - Method in class org.jgroups.util.DefaultThreadFactory
- setPattern(String) - Method in interface org.jgroups.util.ThreadFactory
- setPeerAddressReadTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setPersistent(boolean) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- setPersistent(boolean) - Method in class org.jgroups.blocks.ReplicatedHashMap
- setPingRequests(int) - Method in class org.jgroups.jmx.protocols.Discovery
- setPingRequests(int) - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- setPort(int) - Method in class org.jgroups.stack.GossipRouter
- setPrintLocalAddr(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- setProcessorKeepAliveTime(long) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setProcessorMaxThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setProcessorMinThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setProcessorQueueSize(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setProcessorThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setProperties(String) - Method in class org.jgroups.jmx.JChannel
- setProperties(String) - Method in interface org.jgroups.jmx.JChannelMBean
- setProperties(Properties) - Method in class org.jgroups.jmx.Protocol
- setProperties(Properties) - Method in interface org.jgroups.jmx.ProtocolMBean
- setProperties(Properties) - Method in class org.jgroups.protocols.AUTH
- 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.BARRIER
- setProperties(Properties) - Method in class org.jgroups.protocols.BasicTCP
- setProperties(Properties) - Method in class org.jgroups.protocols.CAUSAL
- setProperties(Properties) - Method in class org.jgroups.protocols.COMPRESS
- setProperties(Properties) - Method in class org.jgroups.protocols.DELAY_JOIN_REQ
- setProperties(Properties) - Method in class org.jgroups.protocols.DELAY
- setProperties(Properties) - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
- setProperties(Properties) - Method in class org.jgroups.protocols.DISCARD
- setProperties(Properties) - Method in class org.jgroups.protocols.Discovery
-
sets the properties of the PING protocol.
- setProperties(Properties) - Method in class org.jgroups.protocols.DUPL
- setProperties(Properties) - Method in class org.jgroups.protocols.ENCRYPT
- setProperties(Properties) - Method in class org.jgroups.protocols.FC
- setProperties(Properties) - Method in class org.jgroups.protocols.FD_ALL
- setProperties(Properties) - Method in class org.jgroups.protocols.FD_ICMP
- setProperties(Properties) - Method in class org.jgroups.protocols.FD_PING
- 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.FD
- 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.HTOTAL
- setProperties(Properties) - Method in class org.jgroups.protocols.JMS
-
Set protocol properties.
- setProperties(Properties) - Method in class org.jgroups.protocols.MERGE2
- setProperties(Properties) - Method in class org.jgroups.protocols.MERGE3
- setProperties(Properties) - Method in class org.jgroups.protocols.MPING
- setProperties(Properties) - Method in class org.jgroups.protocols.pbcast.FLUSH
- 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.STABLE
- setProperties(Properties) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- setProperties(Properties) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- setProperties(Properties) - Method in class org.jgroups.protocols.PING
-
sets the properties of the PING protocol.
- setProperties(Properties) - Method in class org.jgroups.protocols.SEQUENCER
- setProperties(Properties) - Method in class org.jgroups.protocols.SFC
- 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.STATS
- setProperties(Properties) - Method in class org.jgroups.protocols.TCP_NIO
-
Setup the Protocol instance acording to the configuration string
- setProperties(Properties) - Method in class org.jgroups.protocols.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.TP
-
Setup the Protocol instance according to the configuration string
- setProperties(Properties) - Method in class org.jgroups.protocols.TUNNEL
-
Setup the Protocol instance acording to the configuration string
- setProperties(Properties) - Method in class org.jgroups.protocols.UDP
-
Setup the Protocol instance acording to the configuration string.
- setProperties(Properties) - Method in class org.jgroups.protocols.UNICAST
- setProperties(Properties) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- setProperties(Properties) - Method in class org.jgroups.protocols.VIEW_SYNC
- setProperties(Properties) - Method in class org.jgroups.stack.Protocol
-
Configures the protocol initially.
- setPropertiesInternal(Properties) - Method in class org.jgroups.stack.Protocol
-
Called by Configurator.
- setPropertiesString(String) - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
- setProtocolName(String) - Method in class org.jgroups.stack.Configurator.ProtocolConfiguration
- setProtocolStack(Protocol[]) - Method in class org.jgroups.debug.Simulator
- setProtocolStack(ProtocolStack) - Method in class org.jgroups.stack.Protocol
- setQuote(String, Float) - Method in class org.jgroups.demos.QuoteClient
- setQuote(String, Float) - Method in class org.jgroups.demos.QuoteServer
- setReaderThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setReaperInterval(long) - Method in class org.jgroups.jmx.protocols.TCP
- setReaperInterval(long) - Method in interface org.jgroups.jmx.protocols.TCPMBean
- setReaperInterval(long) - Method in class org.jgroups.protocols.BasicTCP
- setReceiveBlockEvents(boolean) - Method in class org.jgroups.jmx.JChannel
- setReceiveBlockEvents(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- setReceiveBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setReceived(boolean) - Method in class org.jgroups.util.Rsp
- setReceiveLocalMessages(boolean) - Method in class org.jgroups.jmx.JChannel
- setReceiveLocalMessages(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- setReceiver(BasicConnectionTable.Receiver) - Method in class org.jgroups.blocks.BasicConnectionTable
- setReceiver(Simulator.Receiver) - Method in class org.jgroups.debug.Simulator
- setReceiver(Receiver) - Method in class org.jgroups.Channel
-
Sets the receiver, which will handle all messages, view changes etc
- setReconnectInterval(long) - Method in class org.jgroups.protocols.TUNNEL
- setRefresherEnabled(boolean) - Method in class org.jgroups.stack.GossipClient
- setRefreshInterval(long) - Method in class org.jgroups.stack.GossipClient
- setRemoteCalls(boolean) - Method in class org.jgroups.blocks.ReplicatedTree
- setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.MessageDispatcher
- setRequestHandler(RequestHandler) - Method in class org.jgroups.blocks.RequestCorrelator
- setRequestMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
- setResponseFilter(RspFilter) - Method in class org.jgroups.blocks.GroupRequest
- setResponseMarshaller(RpcDispatcher.Marshaller) - Method in class org.jgroups.blocks.RpcDispatcher
- setResult(T) - Method in class org.jgroups.util.Promise
-
Sets the result and notifies any threads waiting for it
- setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.NakReceiverWindow
- setRetransmitTimeouts(Interval) - Method in class org.jgroups.stack.Retransmitter
- setRootNode(ReplicatedTree.Node) - Method in class org.jgroups.blocks.ReplicatedTree
- setRouterHost(String) - Method in class org.jgroups.protocols.TUNNEL
- setRouterPort(int) - Method in class org.jgroups.protocols.TUNNEL
- setRoutingClientReplyTimeout(long) - Method in class org.jgroups.stack.GossipRouter
-
Deprecated.
- setSendBufferSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setSendQueueSize(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setServer(MBeanServer) - Method in class org.jgroups.JChannelFactory
- setServerObject(Object) - Method in class org.jgroups.blocks.RpcDispatcher
- setServiceAckTimeout(long) - Method in class org.jgroups.mux.Multiplexer
- setServicesResponseTimeout(long) - Method in class org.jgroups.mux.Multiplexer
- setShun(boolean) - Method in class org.jgroups.jmx.protocols.FD_ALL
- setShun(boolean) - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- setShun(boolean) - Method in class org.jgroups.jmx.protocols.FD
- setShun(boolean) - Method in interface org.jgroups.jmx.protocols.FDMBean
- setShun(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- setShun(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- setShun(boolean) - Method in class org.jgroups.protocols.FD_ALL
- setShun(boolean) - Method in class org.jgroups.protocols.FD
- setShun(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- setSize(int) - Method in class org.jgroups.util.UnmodifiableVector
- setSocketConnectionTimeout(int) - Method in class org.jgroups.blocks.BasicConnectionTable
- setSocketConnectionTimeout(int) - Method in class org.jgroups.stack.GossipClient
- setSocketReadTimeout(int) - Method in class org.jgroups.stack.GossipClient
- setSocketReadTimeout(long) - Method in class org.jgroups.stack.GossipRouter
- setSrc(Address) - Method in class org.jgroups.Message
- setStartFlushTimeout(long) - Method in class org.jgroups.protocols.pbcast.FLUSH
- setStartPort(int) - Method in class org.jgroups.jmx.protocols.TCP
- setStartPort(int) - Method in interface org.jgroups.jmx.protocols.TCPMBean
- setStartPort(int) - Method in class org.jgroups.protocols.BasicTCP
- setState(byte[]) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- 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.ReplicatedHashMap
- setState(byte[]) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- setState(byte[]) - Method in class org.jgroups.blocks.ReplicatedTree
-
Set the cache (tree) to this value
- setState(byte[]) - Method in class org.jgroups.blocks.VotingAdapter
-
Set the channel state.
- setState(byte[]) - Method in class org.jgroups.demos.ChatCore
- setState(byte[]) - Method in class org.jgroups.demos.Draw
- setState(byte[]) - Method in class org.jgroups.demos.QuoteServer
- setState(byte[]) - Method in class org.jgroups.demos.wb.GraphPanel
- setState(byte[]) - Method in class org.jgroups.demos.wb.Whiteboard
- setState(byte[]) - Method in class org.jgroups.ExtendedReceiverAdapter
- setState(byte[]) - Method in interface org.jgroups.MessageListener
-
Sets the group state; e.g., when joining.
- setState(byte[]) - Method in class org.jgroups.ReceiverAdapter
- setState(InputStream) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- setState(InputStream) - Method in class org.jgroups.blocks.MessageListenerAdapter
- setState(InputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
- setState(InputStream) - Method in class org.jgroups.demos.Draw
- setState(InputStream) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to read a state through a provided InputStream.
- setState(InputStream) - Method in class org.jgroups.ExtendedReceiverAdapter
- setState(String, byte[]) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- setState(String, byte[]) - Method in class org.jgroups.blocks.MessageListenerAdapter
- setState(String, byte[]) - Method in class org.jgroups.blocks.ReplicatedHashMap
- setState(String, byte[]) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to read a partial state indicated by state_id from a given state byte array parameter.
- setState(String, byte[]) - Method in class org.jgroups.ExtendedReceiverAdapter
- setState(String, InputStream) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- setState(String, InputStream) - Method in class org.jgroups.blocks.MessageListenerAdapter
- setState(String, InputStream) - Method in class org.jgroups.blocks.ReplicatedHashMap
- setState(String, InputStream) - Method in interface org.jgroups.ExtendedMessageListener
-
Allows an application to read a partial state through a provided InputStream.
- setState(String, InputStream) - Method in class org.jgroups.ExtendedReceiverAdapter
- setState(Vector) - Method in class org.jgroups.demos.Topology
- SetStateEvent - Class in org.jgroups
-
Encapsulates a state returned by
Channel.receive()
, as requested byChannel.getState(s)
previously. - SetStateEvent(byte[], String) - Constructor for class org.jgroups.SetStateEvent
- setStateListener(MessageListener) - Method in class org.jgroups.blocks.MessageListenerAdapter
-
Register
listener
for state notification events. - setStatsEnabled(boolean) - Method in class org.jgroups.jmx.JChannel
- setStatsEnabled(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- setStatsEnabled(boolean) - Method in class org.jgroups.jmx.Protocol
- setStatsEnabled(boolean) - Method in interface org.jgroups.jmx.ProtocolMBean
- setSuspected(boolean) - Method in class org.jgroups.util.Rsp
- setTcpNodelay(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
- setThreadDecorator(ThreadDecorator) - Method in class org.jgroups.util.DefaultThreadFactory
- setThreadDecorator(ThreadDecorator) - Method in interface org.jgroups.util.ThreadManager
-
Sets the ThreadDecorator associated this manager should use.
- setThreadDecorator(ThreadDecorator) - Method in class org.jgroups.util.ThreadManagerThreadPoolExecutor
- setThreadDecorator(ThreadDecorator) - Method in class org.jgroups.util.TimeScheduler
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.blocks.BasicConnectionTable
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
- setThreadFactory(ThreadFactory) - Method in class org.jgroups.stack.ProtocolStack
-
Deprecated.Use
Protocol.getThreadFactory()
instead - setThreadNames() - Method in class org.jgroups.protocols.TP
- setThreadNames() - Method in class org.jgroups.protocols.UDP
- setThreadPoolEnabled(boolean) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolKeepAliveTime(long) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolMaxThreads(int) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolMinThreads(int) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolQueueEnabled(boolean) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolQueueMaxSize(int) - Method in class org.jgroups.stack.GossipRouter
- setThreadPoolRejectionPolicy(String) - Method in class org.jgroups.stack.GossipRouter
- setTimeout(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Sets the cluster call timeout (until all acks have been received)
- setTimeout(long) - Method in class org.jgroups.jmx.protocols.Discovery
- setTimeout(long) - Method in interface org.jgroups.jmx.protocols.DiscoveryMBean
- setTimeout(long) - Method in class org.jgroups.jmx.protocols.FD_ALL
- setTimeout(long) - Method in interface org.jgroups.jmx.protocols.FD_ALLMBean
- setTimeout(long) - Method in class org.jgroups.jmx.protocols.FD
- setTimeout(long) - Method in interface org.jgroups.jmx.protocols.FDMBean
- setTimeout(long) - Method in class org.jgroups.protocols.Discovery
- setTimeout(long) - Method in class org.jgroups.protocols.FD_ALL
- setTimeout(long) - Method in class org.jgroups.protocols.FD
- setTimeout(long) - Method in class org.jgroups.util.AgeOutCache
- setTimerThreadFactory(ThreadFactory) - Method in class org.jgroups.protocols.TP
- setTimerThreadFactory(ThreadFactory) - Static method in class org.jgroups.stack.ProtocolStack
-
Deprecated.
- setToken(AuthToken) - Method in class org.jgroups.protocols.AuthHeader
-
Sets the token value to that of the passed in token object
- setTTL(int) - Method in class org.jgroups.jmx.protocols.MPING
- setTTL(int) - Method in interface org.jgroups.jmx.protocols.MPINGMBean
- setTTL(int) - Method in class org.jgroups.protocols.MPING
- setType(int) - Method in class org.jgroups.Event
-
Deprecated.in order to make an Event immutable
- setup() - Method in class org.jgroups.stack.ProtocolStack
- setUpDiscardRate(double) - Method in class org.jgroups.protocols.DISCARD
- 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
- setupProtocolStack(String, ProtocolStack) - Static method in class org.jgroups.stack.Configurator
-
The configuration string has a number of entries, separated by a ':' (colon).
- setUseMcastXmit(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- setUseMcastXmit(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- setUseMcastXmit(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
- setUseSendQueues(boolean) - Method in class org.jgroups.blocks.BasicConnectionTable
- setVal1(V1) - Method in class org.jgroups.util.Triple
- setVal1(V1) - Method in class org.jgroups.util.Tuple
- setVal2(V2) - Method in class org.jgroups.util.Triple
- setVal2(V2) - Method in class org.jgroups.util.Tuple
- setVal3(V3) - Method in class org.jgroups.util.Triple
- setValue(Object) - Method in class org.jgroups.util.Rsp
- setValue(String) - Method in class org.jgroups.conf.ProtocolParameter
- setValue(Properties) - Method in class org.jgroups.auth.AuthToken
-
Called during the setup of the AUTH protocol to pass property values from the JGroups config XML document to the implementing class.
- setValue(Properties) - Method in class org.jgroups.auth.FixedMembershipToken
- setValue(Properties) - Method in class org.jgroups.auth.MD5Token
- setValue(Properties) - Method in class org.jgroups.auth.SimpleToken
- setValue(Properties) - Method in class org.jgroups.auth.X509Token
- setValues() - Method in class org.jgroups.jmx.JChannel
- setView(View) - Method in class org.jgroups.debug.Simulator
- setView(View) - Method in class org.jgroups.protocols.pbcast.MergeData
- setViewAckCollectionTimeout(long) - Method in class org.jgroups.protocols.pbcast.GMS
- setViewBundling(boolean) - Method in class org.jgroups.protocols.pbcast.GMS
- setVisible(boolean) - Method in class org.jgroups.demos.DistributedTreeDemo
- setWriterThreads(int) - Method in class org.jgroups.blocks.ConnectionTableNIO
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.jmx.protocols.pbcast.NAKACK
- setXmitFromRandomMember(boolean) - Method in interface org.jgroups.jmx.protocols.pbcast.NAKACKMBean
- setXmitFromRandomMember(boolean) - Method in class org.jgroups.protocols.pbcast.NAKACK
- SFC - Class in org.jgroups.jmx.protocols
- SFC - Class in org.jgroups.protocols
-
Simple flow control protocol.
- SFC() - Constructor for class org.jgroups.jmx.protocols.SFC
- SFC() - Constructor for class org.jgroups.protocols.SFC
- SFC(Protocol) - Constructor for class org.jgroups.jmx.protocols.SFC
- SFC.Header - Class in org.jgroups.protocols
- SFCMBean - Interface in org.jgroups.jmx.protocols
- sha(String) - Static method in class org.jgroups.util.Util
-
Converts a java.lang.String in to a SHA hashed String
- SHARED_LOOPBACK - Class in org.jgroups.protocols
-
Loopback transport shared by all channels within the same VM.
- SHARED_LOOPBACK() - Constructor for class org.jgroups.protocols.SHARED_LOOPBACK
- SHORT_SIZE - Static variable in class org.jgroups.Global
- shortForm() - Method in class org.jgroups.protocols.pbcast.Gossip
- shortName(String) - Static method in class org.jgroups.util.Util
- shortName(InetAddress) - Static method in class org.jgroups.util.Util
- showLastBlockingTimes() - Method in class org.jgroups.jmx.protocols.FC
- showLastBlockingTimes() - Method in interface org.jgroups.jmx.protocols.FCMBean
- showLastBlockingTimes() - Method in class org.jgroups.protocols.FC
- SHUFFLE - Class in org.jgroups.protocols
-
This layer shuffles upcoming messages, put it just above your bottom layer.
- SHUFFLE() - Constructor for class org.jgroups.protocols.SHUFFLE
- shutdown() - Method in class org.jgroups.Channel
-
Shuts down the channel without disconnecting if connected, stops all the threads
- shutdown() - Method in class org.jgroups.JChannel
-
Shuts down the channel without disconnecting
- shutdown() - Method in class org.jgroups.jmx.JChannel
- shutdown() - Method in interface org.jgroups.jmx.JChannelMBean
- shutdown() - Method in class org.jgroups.mux.MuxChannel
- shutDown() - Method in class org.jgroups.persistence.DBPersistenceManager
-
Shutting down the database cleanly
- shutDown() - Method in class org.jgroups.persistence.FilePersistenceManager
-
Used to handle shutdown call the PersistenceManager implementation.
- shutDown() - Method in interface org.jgroups.persistence.PersistenceManager
-
Used to handle shutdown call the PersistenceManager implementation.
- SHUTDOWN - Static variable in class org.jgroups.Event
- SHUTDOWN - Static variable in class org.jgroups.stack.GossipRouter
- ShutdownRejectedExecutionHandler - Class in org.jgroups.util
-
ShutdownRejectedExecutionHandler is a decorator RejectedExecutionHandler used in all JGroups ThreadPoolExecutor(s).
- ShutdownRejectedExecutionHandler(RejectedExecutionHandler) - Constructor for class org.jgroups.util.ShutdownRejectedExecutionHandler
- shutdownThreadPool() - Method in class org.jgroups.mux.Multiplexer
- shutting_down - Variable in class org.jgroups.protocols.VERIFY_SUSPECT
- signature - Variable in class org.jgroups.blocks.MethodCall
-
The signature, e.g., new String[]{String.class.getName(), int.class.getName()}.
- SIGNATURE - Static variable in class org.jgroups.blocks.MethodCall
-
Provide a signature, similar to JMX.
- SimpleToken - Class in org.jgroups.auth
-
This is an example of using a preshared token for authentication purposes.
- SimpleToken() - Constructor for class org.jgroups.auth.SimpleToken
- SimpleToken(String) - Constructor for class org.jgroups.auth.SimpleToken
- Simulator - Class in org.jgroups.debug
-
Tests one or more protocols independently.
- Simulator() - Constructor for class org.jgroups.debug.Simulator
- Simulator.Receiver - Interface in org.jgroups.debug
- SINGLETON_NAME - Static variable in class org.jgroups.Global
- size() - Method in interface org.jgroups.Address
-
Returns serialized size of this address
- size() - Method in class org.jgroups.blocks.DistributedQueue
- size() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- size() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- size() - Method in class org.jgroups.Header
-
To be implemented by subclasses.
- size() - Method in class org.jgroups.Membership
-
Returns the number of addresses in this membership
- size() - Method in class org.jgroups.Message
-
Returns the exact size of the marshalled message.
- size() - Method in class org.jgroups.mux.MuxHeader
- size() - Method in class org.jgroups.mux.ServiceInfo
- size() - Method in class org.jgroups.protocols.AuthHeader
- 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.CAUSAL.CausalNewViewHeader
-
Size of this vector timestamp estimation, used in fragmentation.
- size() - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- size() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- size() - Method in class org.jgroups.protocols.FC.FcHeader
- size() - Method in class org.jgroups.protocols.FD_ALL.Header
- size() - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
- size() - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- size() - Method in class org.jgroups.protocols.FD.FdHeader
- size() - Method in class org.jgroups.protocols.FragHeader
- size() - Method in class org.jgroups.protocols.JMS.JMSAddress
- size() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- size() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- size() - Method in class org.jgroups.protocols.pbcast.NakAckHeader
- size() - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- size() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- size() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- size() - Method in class org.jgroups.protocols.PingHeader
- size() - Method in class org.jgroups.protocols.PingRsp
- size() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- size() - Method in class org.jgroups.protocols.SFC.Header
- size() - Method in class org.jgroups.protocols.SMACK.SmackHeader
- size() - Method in class org.jgroups.protocols.TcpHeader
- size() - Method in class org.jgroups.protocols.TpHeader
- size() - Method in class org.jgroups.protocols.TransportedVectorTime
-
Returns size of this vector timestamp i.e number of process group members
- size() - Method in class org.jgroups.protocols.TunnelHeader
- size() - Method in class org.jgroups.protocols.UdpHeader
- size() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- size() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- size() - Method in class org.jgroups.stack.AckMcastReceiverWindow
- size() - Method in class org.jgroups.stack.AckMcastSenderWindow
- size() - Method in class org.jgroups.stack.AckReceiverWindow
- size() - Method in class org.jgroups.stack.AckSenderWindow
- size() - Method in class org.jgroups.stack.IpAddress
- size() - Method in class org.jgroups.stack.NakReceiverWindow
- size() - Method in class org.jgroups.stack.Retransmitter
- size() - Method in class org.jgroups.util.AckCollector
- size() - Method in class org.jgroups.util.AgeOutCache
- size() - Method in class org.jgroups.util.Digest.Entry
- size() - Method in class org.jgroups.util.Digest
- size() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Returns the current size of the buffer.
- size() - Method in class org.jgroups.util.FIFOMessageQueue
- size() - Method in class org.jgroups.util.Headers
- size() - Method in class org.jgroups.util.Queue
-
returns the number of objects that are currently in the queue
- size() - Method in class org.jgroups.util.ResponseCollector
- size() - Method in class org.jgroups.util.RspList
- size() - Method in class org.jgroups.util.SizeBoundedQueue
- size() - Method in class org.jgroups.util.TimeScheduler
-
Answers the number of tasks currently in the queue.
- size() - Method in class org.jgroups.util.UnmodifiableVector
- size() - Method in class org.jgroups.View
-
returns the number of members in this view
- size(Collection) - Static method in class org.jgroups.util.Util
-
Returns the marshalled size of a Collection of Addresses.
- size(Address) - Static method in class org.jgroups.util.Util
- SIZE - Class in org.jgroups.protocols
-
Protocol which prints out the real size of a message.
- SIZE() - Constructor for class org.jgroups.protocols.SIZE
- SizeBoundedQueue - Class in org.jgroups.util
-
Queue as described in http://jira.jboss.com/jira/browse/JGRP-376.
- SizeBoundedQueue() - Constructor for class org.jgroups.util.SizeBoundedQueue
- sizeOf(Object) - Static method in class org.jgroups.util.Util
- sizeOf(String) - Static method in class org.jgroups.util.Util
- sizeOf(Streamable) - Static method in class org.jgroups.util.Util
- sizeOfNotSeenList() - Method in class org.jgroups.protocols.pbcast.Gossip
- skip(long) - Method in class org.jgroups.util.ExposedByteArrayInputStream
- sleep(long) - Static method in class org.jgroups.util.Util
-
Sleep for timeout msecs.
- sleep(long, boolean) - Static method in class org.jgroups.util.Util
-
On most UNIX systems, the minimum sleep time is 10-20ms.
- sleep(long, int) - Static method in class org.jgroups.util.Util
- sleepRandom(long) - Static method in class org.jgroups.util.Util
-
Sleeps between 1 and timeout milliseconds, chosen randomly.
- sleepRandom(long, long) - Static method in class org.jgroups.util.Util
-
Sleeps between floor and ceiling milliseconds, chosen randomly
- SMACK - Class in org.jgroups.protocols
-
Simple Multicast ACK protocol.
- SMACK() - Constructor for class org.jgroups.protocols.SMACK
- SMACK.SmackHeader - Class in org.jgroups.protocols
- SmackHeader() - Constructor for class org.jgroups.protocols.SMACK.SmackHeader
- SmackHeader(byte, long) - Constructor for class org.jgroups.protocols.SMACK.SmackHeader
- smallerThanNextToRemove(long) - Method in class org.jgroups.stack.AckReceiverWindow
- sort() - Method in class org.jgroups.Membership
- src_addr - Variable in class org.jgroups.Message
- SRC_PROPERTY - Static variable in class org.jgroups.protocols.JMS
- STABILITY - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- stability_msgs - Variable in class org.jgroups.protocols.pbcast.NAKACK
-
BoundedList
, keeps the last 10 stability messages - stable(long) - Method in class org.jgroups.stack.NakReceiverWindow
-
Delete all messages invalid input: '<'= seqno (they are stable, that is, have been received at all members).
- STABLE - Class in org.jgroups.jmx.protocols.pbcast
- STABLE - Class in org.jgroups.protocols.pbcast
-
Computes the broadcast messages that are stable; i.e., have been received by all members.
- STABLE - Static variable in class org.jgroups.Event
- STABLE() - Constructor for class org.jgroups.jmx.protocols.pbcast.STABLE
- STABLE() - Constructor for class org.jgroups.protocols.pbcast.STABLE
- STABLE(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.STABLE
- STABLE_GOSSIP - Static variable in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- STABLE.StableHeader - Class in org.jgroups.protocols.pbcast
- StableHeader() - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
- StableHeader(int, Digest) - Constructor for class org.jgroups.protocols.pbcast.STABLE.StableHeader
- STABLEMBean - Interface in org.jgroups.jmx.protocols.pbcast
- stack - Variable in class org.jgroups.stack.Protocol
- start() - Method in class org.jgroups.blocks.BasicConnectionTable
- start() - Method in class org.jgroups.blocks.ConnectionTable
- start() - Method in class org.jgroups.blocks.ConnectionTableNIO
- start() - Method in class org.jgroups.blocks.DistributedTree
- start() - Method in class org.jgroups.blocks.MessageDispatcher
- start() - Method in class org.jgroups.blocks.NotificationBus
- start() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- start() - Method in class org.jgroups.blocks.ReplicatedTree
- start() - Method in class org.jgroups.blocks.RequestCorrelator
- start() - Method in class org.jgroups.debug.ProtocolTester
- start() - Method in class org.jgroups.debug.Simulator
- start() - Method in class org.jgroups.demos.applets.DrawApplet
- start() - Method in class org.jgroups.demos.Chat
- 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() - Method in class org.jgroups.JChannelFactory
- start() - Method in class org.jgroups.jmx.JChannel
- start() - Method in class org.jgroups.jmx.JChannelFactory
- start() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- start() - Method in interface org.jgroups.jmx.JChannelMBean
- start() - Method in class org.jgroups.jmx.Protocol
- start() - Method in interface org.jgroups.jmx.ProtocolMBean
- start() - Method in class org.jgroups.protocols.AUTOCONF
- start() - Method in class org.jgroups.protocols.BSH
- start() - Method in class org.jgroups.protocols.DISCARD
- start() - Method in class org.jgroups.protocols.Discovery
- start() - Method in class org.jgroups.protocols.DUMMY_TP
- start() - Method in class org.jgroups.protocols.FC
- start() - Method in class org.jgroups.protocols.FD_SOCK
- 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.MPING
- start() - Method in class org.jgroups.protocols.pbcast.FLUSH
- start() - Method in class org.jgroups.protocols.pbcast.GMS
- start() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- start() - Method in class org.jgroups.protocols.pbcast.NAKACK
- start() - Method in class org.jgroups.protocols.pbcast.STABLE
- start() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- start() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- start() - Method in class org.jgroups.protocols.PERF_TP
- start() - Method in class org.jgroups.protocols.SFC
- start() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- start() - Method in class org.jgroups.protocols.SHUFFLE
-
Starts the
messagesHandlerinvalid input: '<'\code>
- start() - Method in class org.jgroups.protocols.TCP_NIO
- start() - Method in class org.jgroups.protocols.TCP
- start() - Method in class org.jgroups.protocols.TCPGOSSIP
- start() - Method in class org.jgroups.protocols.TP
-
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() - Method in class org.jgroups.protocols.TUNNEL
- start() - Method in class org.jgroups.protocols.UDP
-
Creates the unicast and multicast sockets and starts the unicast and multicast receiver threads
- start() - Method in class org.jgroups.protocols.UDP.UcastReceiver
- start() - Method in class org.jgroups.protocols.UNICAST
- start() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- start() - Method in class org.jgroups.protocols.VIEW_SYNC
- start() - Method in class org.jgroups.stack.GossipRouter
-
JBoss MBean lifecycle operation.
- start() - Method in class org.jgroups.stack.Protocol
-
This method is called on a
Channel.connect(String)
. - start() - Method in class org.jgroups.util.Proxy
- start() - Method in class org.jgroups.util.ReusableThread
-
Will always be called from synchronized method, no need to do our own synchronization
- start() - Method in class org.jgroups.util.Scheduler
- start() - Method in class org.jgroups.util.TimeScheduler
-
Start the scheduler, if it's suspended or stopped
- start(long) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Fetches the state
- start(long) - Method in class org.jgroups.blocks.DistributedQueue
- start(long) - Method in class org.jgroups.blocks.DistributedTree
- start(long) - Method in class org.jgroups.blocks.ReplicatedHashMap
-
Fetches the state
- start(String) - Static method in class org.jgroups.debug.Profiler
- start(String) - Method in class org.jgroups.demos.wb.GraphPanel
- start(String, boolean) - Method in class org.jgroups.demos.ViewDemo
- start(String, String) - Method in class org.jgroups.demos.NotificationBusDemo
- start(String, ChannelFactory, String) - Method in class org.jgroups.demos.DistributedQueueDemo
- start(ChannelFactory, String, boolean) - Method in class org.jgroups.demos.DistributedHashtableDemo
- start(ChannelFactory, String, boolean) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- START_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- START_PARTITION - Static variable in class org.jgroups.Event
- start_port - Variable in class org.jgroups.protocols.BasicTCP
- started - Variable in class org.jgroups.blocks.RequestCorrelator
- started(Runnable) - Method in interface org.jgroups.util.SchedulerListener
- startFlush() - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- startFlush() - Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
- startFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
- startFlush(boolean) - Method in class org.jgroups.Channel
- startFlush(boolean) - Method in class org.jgroups.JChannel
-
Will perform a flush of the system, ie.
- startFlush(long, boolean) - Method in class org.jgroups.Channel
- startFlush(long, boolean) - Method in class org.jgroups.JChannel
-
Will perform a flush of the system, ie.
- startFlush(List<Address>, boolean) - Method in class org.jgroups.Channel
- startFlush(List<Address>, boolean) - Method in class org.jgroups.JChannel
-
Performs a partial flush in a cluster for flush participants.
- startFlush(Channel) - Static method in class org.jgroups.util.Util
- startFlush(Channel, int, long, long) - Static method in class org.jgroups.util.Util
- startFlush(Channel, List<Address>) - Static method in class org.jgroups.util.Util
- startFlush(Channel, List<Address>, int, long, long) - Static method in class org.jgroups.util.Util
- startPartition() - Method in class org.jgroups.jmx.protocols.PARTITION
- startPartition() - Method in interface org.jgroups.jmx.protocols.PARTITIONMBean
- startPartition() - Method in class org.jgroups.protocols.PARTITION
- startProtocolStack(List<Protocol>, String, Map<String, Tuple<TP, Short>>) - Static method in class org.jgroups.stack.Configurator
- startStack(String) - Method in class org.jgroups.stack.ProtocolStack
-
Start all layers.
- state - Variable in class org.jgroups.stack.StateTransferInfo
- state_id - Variable in class org.jgroups.stack.StateTransferInfo
- STATE_PART - Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- state_promise - Variable in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- state_promise - Variable in class org.jgroups.blocks.ReplicatedHashMap
- STATE_RECEIVED - Static variable in class org.jgroups.Event
- STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- STATE_REQ - Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- STATE_RSP - Static variable in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- STATE_TRANSFER - Class in org.jgroups.jmx.protocols.pbcast
- STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
-
New STATE_TRANSFER protocol based on PBCAST.
- STATE_TRANSFER() - Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- STATE_TRANSFER() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER
- STATE_TRANSFER(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.STATE_TRANSFER
- STATE_TRANSFER_INPUTSTREAM - Static variable in class org.jgroups.Event
- STATE_TRANSFER_INPUTSTREAM_CLOSED - Static variable in class org.jgroups.Event
- STATE_TRANSFER_OUTPUTSTREAM - Static variable in class org.jgroups.Event
- STATE_TRANSFER_OUTPUTSTREAM_CLOSED - Static variable in class org.jgroups.Event
- STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
-
Wraps data for a state request/response.
- STATE_TRANSFERMBean - Interface in org.jgroups.jmx.protocols.pbcast
- StateHeader() - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- StateHeader() - Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- StateHeader(byte, Address, long, Digest) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- StateHeader(byte, Address, long, Digest) - Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- StateHeader(byte, Address, long, Digest, String) - Constructor for class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- StateHeader(byte, Address, String) - Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- StateHeader(byte, Address, IpAddress, Digest, String) - Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- stateListener - Variable in class org.jgroups.blocks.MessageListenerAdapter
- stateTransferCompleted(boolean) - Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
-
Deprecated.
- StateTransferException - Exception Class in org.jgroups
-
StateTransferException
is thrown to indicate failure of state transfer between cluster members. - StateTransferException() - Constructor for exception class org.jgroups.StateTransferException
- StateTransferException(String) - Constructor for exception class org.jgroups.StateTransferException
- StateTransferException(String, Throwable) - Constructor for exception class org.jgroups.StateTransferException
- StateTransferInfo - Class in org.jgroups.stack
-
Contains parameters for state transfer.
- StateTransferInfo() - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address) - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address, long) - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address, InputStream, String) - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address, OutputStream, String) - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address, String, long) - Constructor for class org.jgroups.stack.StateTransferInfo
- StateTransferInfo(Address, String, long, byte[]) - Constructor for class org.jgroups.stack.StateTransferInfo
- stateTransferRunning() - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- stateTransferStarted() - Method in interface org.jgroups.blocks.ReplicatedHashtable.StateTransferListener
-
Deprecated.
- StaticInterval - Class in org.jgroups.stack
-
Manages retransmission timeouts.
- StaticInterval(long...) - Constructor for class org.jgroups.stack.StaticInterval
- stats - Variable in class org.jgroups.JChannel
-
Collect statistics
- stats - Variable in class org.jgroups.stack.Protocol
- STATS - Class in org.jgroups.jmx.protocols
- STATS - Class in org.jgroups.protocols
-
Provides various stats
- STATS() - Constructor for class org.jgroups.jmx.protocols.STATS
- STATS() - Constructor for class org.jgroups.protocols.STATS
- STATS(Protocol) - Constructor for class org.jgroups.jmx.protocols.STATS
- statsEnabled() - Method in class org.jgroups.JChannel
- statsEnabled() - Method in class org.jgroups.stack.Protocol
- STATSMBean - Interface in org.jgroups.jmx.protocols
- STATUS_CONNECTED - Static variable in class org.jgroups.stack.RouterStub
- STATUS_DISCONNECTED - Static variable in class org.jgroups.stack.RouterStub
- stop() - Method in class org.jgroups.blocks.BasicConnectionTable
- stop() - Method in class org.jgroups.blocks.ConnectionTableNIO
-
Closes all open sockets, the server socket and all threads waiting for incoming messages
- stop() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- stop() - Method in class org.jgroups.blocks.DistributedQueue
- stop() - Method in class org.jgroups.blocks.DistributedTree
- stop() - Method in class org.jgroups.blocks.MessageDispatcher
- stop() - Method in class org.jgroups.blocks.NotificationBus
- stop() - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- stop() - Method in class org.jgroups.blocks.ReplicatedHashMap
- stop() - Method in class org.jgroups.blocks.ReplicatedTree
- stop() - Method in class org.jgroups.blocks.RequestCorrelator
- stop() - Method in class org.jgroups.debug.ProtocolTester
- stop() - Method in class org.jgroups.debug.Simulator
- stop() - Method in class org.jgroups.demos.ChatCore
- stop() - Method in class org.jgroups.demos.Draw
- stop() - Method in class org.jgroups.demos.wb.GraphPanel
- stop() - Method in class org.jgroups.JChannelFactory
- stop() - Method in class org.jgroups.jmx.JChannel
- stop() - Method in class org.jgroups.jmx.JChannelFactory
- stop() - Method in interface org.jgroups.jmx.JChannelFactoryMBean
- stop() - Method in interface org.jgroups.jmx.JChannelMBean
- stop() - Method in class org.jgroups.jmx.Protocol
- stop() - Method in interface org.jgroups.jmx.ProtocolMBean
- stop() - Method in class org.jgroups.protocols.BARRIER
- stop() - Method in class org.jgroups.protocols.BSH
- stop() - Method in class org.jgroups.protocols.DISCARD
- stop() - Method in class org.jgroups.protocols.Discovery
- stop() - Method in class org.jgroups.protocols.FC
- stop() - Method in class org.jgroups.protocols.FD_ALL
- stop() - Method in class org.jgroups.protocols.FD_SIMPLE
- stop() - Method in class org.jgroups.protocols.FD_SOCK
- stop() - Method in class org.jgroups.protocols.FD.BroadcastTask
- stop() - Method in class org.jgroups.protocols.FD
- stop() - Method in class org.jgroups.protocols.JMS
-
Stops the work of the JMS protocol.
- stop() - Method in class org.jgroups.protocols.MERGE2
- stop() - Method in class org.jgroups.protocols.MPING
- stop() - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- stop() - Method in class org.jgroups.protocols.pbcast.FLUSH
- stop() - Method in class org.jgroups.protocols.pbcast.GMS
- stop() - Method in class org.jgroups.protocols.pbcast.GmsImpl
- stop() - Method in class org.jgroups.protocols.pbcast.NAKACK
- stop() - Method in class org.jgroups.protocols.pbcast.STABLE
- stop() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- stop() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- stop() - Method in class org.jgroups.protocols.PING
- stop() - Method in class org.jgroups.protocols.SFC
- stop() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- 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.TCP_NIO
- stop() - Method in class org.jgroups.protocols.TCP
- stop() - Method in class org.jgroups.protocols.TCPGOSSIP
- stop() - Method in class org.jgroups.protocols.TP
- stop() - Method in class org.jgroups.protocols.TUNNEL
- stop() - Method in class org.jgroups.protocols.UDP
- stop() - Method in class org.jgroups.protocols.UDP.UcastReceiver
- stop() - Method in class org.jgroups.protocols.UNICAST
- stop() - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- stop() - Method in class org.jgroups.protocols.VIEW_SYNC
- stop() - Method in class org.jgroups.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.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.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.
- stop(String) - Static method in class org.jgroups.debug.Profiler
- STOP_FLUSH - Static variable in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- STOP_PARTITION - Static variable in class org.jgroups.Event
- stopFlush() - Method in class org.jgroups.Channel
- stopFlush() - Method in class org.jgroups.JChannel
- stopFlush() - Method in class org.jgroups.jmx.protocols.pbcast.FLUSH
- stopFlush() - Method in interface org.jgroups.jmx.protocols.pbcast.FLUSHMBean
- stopFlush() - Method in class org.jgroups.protocols.pbcast.FLUSH
- stopFlush(List<Address>) - Method in class org.jgroups.Channel
- stopFlush(List<Address>) - Method in class org.jgroups.JChannel
- stopPartition() - Method in class org.jgroups.jmx.protocols.PARTITION
- stopPartition() - Method in interface org.jgroups.jmx.protocols.PARTITIONMBean
- stopPartition() - Method in class org.jgroups.protocols.PARTITION
- stopped - Variable in class org.jgroups.blocks.DistributedQueue
- stopped(Runnable) - Method in interface org.jgroups.util.SchedulerListener
- stopProtocolStack(List<Protocol>, String, Map<String, Tuple<TP, Short>>) - Static method in class org.jgroups.stack.Configurator
- stopStack(boolean, boolean) - Method in class org.jgroups.JChannel
- stopStack(String) - Method in class org.jgroups.stack.ProtocolStack
-
Iterates through all the protocols from top to bottom and does the following: Waits until all messages in the down queue have been flushed (ie., size is 0) Calls stop() on the protocol
- Streamable - Interface in org.jgroups.util
-
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization
- streamableFromByteBuffer(Class, byte[]) - Static method in class org.jgroups.util.Util
- streamableFromByteBuffer(Class, byte[], int, int) - Static method in class org.jgroups.util.Util
- streamableToByteBuffer(Streamable) - Static method in class org.jgroups.util.Util
- STREAMING_STATE_TRANSFER - Class in org.jgroups.jmx.protocols.pbcast
- STREAMING_STATE_TRANSFER - Class in org.jgroups.protocols.pbcast
-
STREAMING_STATE_TRANSFER
, as its name implies, allows a streaming state transfer between two channel instances. - STREAMING_STATE_TRANSFER() - Constructor for class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- STREAMING_STATE_TRANSFER() - Constructor for class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- STREAMING_STATE_TRANSFER(Protocol) - Constructor for class org.jgroups.jmx.protocols.pbcast.STREAMING_STATE_TRANSFER
- STREAMING_STATE_TRANSFER.StateHeader - Class in org.jgroups.protocols.pbcast
- STREAMING_STATE_TRANSFERMBean - Interface in org.jgroups.jmx.protocols.pbcast
- StreamingGetStateEvent - Class in org.jgroups
-
Represents an event returned by
channel.receive()
, as a result of another channel instance requesting a state from this channel. - StreamingGetStateEvent(OutputStream, String) - Constructor for class org.jgroups.StreamingGetStateEvent
- StreamingSetStateEvent - Class in org.jgroups
-
Represents an event returned by
channel.receive()
, as requested bychannel.getState()
previously. - StreamingSetStateEvent(InputStream, String) - Constructor for class org.jgroups.StreamingSetStateEvent
- string_version - Static variable in class org.jgroups.Version
- subgroups - Variable in class org.jgroups.MergeView
- subList(int, int) - Method in class org.jgroups.util.UnmodifiableVector
- substituteVariable(String) - Static method in class org.jgroups.util.Util
-
Replaces variables of ${var:default} with System.getProperty(var, default).
- substituteVariables(ProtocolStackConfigurator) - Static method in class org.jgroups.conf.ConfiguratorFactory
-
Replace variables of the form ${var:default} with the getProperty(var, default)
- supportedKeys() - Method in interface org.jgroups.protocols.TP.ProbeHandler
-
Returns a list of supported keys
- suspect(Object) - Method in class org.jgroups.stack.AckMcastReceiverWindow
- suspect(Address) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.Called when a member is suspected
- suspect(Address) - Method in class org.jgroups.blocks.DistributedLockManager
- 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.ReplicatedHashMap
-
Called when a member is suspected
- suspect(Address) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.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.ChatCore
- suspect(Address) - Method in class org.jgroups.demos.QuoteClient
- suspect(Address) - Method in class org.jgroups.demos.QuoteServer
- suspect(Address) - Method in class org.jgroups.demos.Topology
- suspect(Address) - Method in class org.jgroups.demos.ViewDemo
-
Called when a member is suspected
- suspect(Address) - Method in class org.jgroups.demos.wb.Whiteboard
- suspect(Address) - Method in class org.jgroups.ExtendedReceiverAdapter
- suspect(Address) - Method in interface org.jgroups.MembershipListener
-
Called whenever a member is suspected of having crashed, but has not yet been excluded.
- suspect(Address) - Method in class org.jgroups.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.ReceiverAdapter
- suspect(Address) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Process with address
suspected
is suspected: remove it from all receiver sets. - suspect(Address) - Method in class org.jgroups.util.AckCollector
- suspect(Address) - Method in class org.jgroups.util.ResponseCollector
- SUSPECT - Static variable in class org.jgroups.Channel
- SUSPECT - Static variable in class org.jgroups.Event
- SUSPECT - Static variable in class org.jgroups.protocols.FD_ALL.Header
- SUSPECT - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- SUSPECT - Static variable in class org.jgroups.protocols.FD.FdHeader
- SuspectedException - Exception Class in org.jgroups
-
Thrown if a message is sent to a suspected member.
- SuspectedException() - Constructor for exception class org.jgroups.SuspectedException
- SuspectedException(Object) - Constructor for exception class org.jgroups.SuspectedException
- SuspectEvent - Class in org.jgroups
-
Represents a suspect event.
- SuspectEvent(Object) - Constructor for class org.jgroups.SuspectEvent
- suspend() - Method in class org.jgroups.util.ReusableThread
-
Suspends the thread.
- SUSPEND - Static variable in class org.jgroups.Event
- SUSPEND_STABLE - Static variable in class org.jgroups.Event
- suspended(Runnable) - Method in interface org.jgroups.util.SchedulerListener
- suspendMergeTask() - Method in class org.jgroups.jmx.protocols.MERGE2
- suspendMergeTask() - Method in interface org.jgroups.jmx.protocols.MERGE2MBean
- suspendMergeTask() - Method in class org.jgroups.protocols.MERGE2
-
Suspends the sending of merge multicasts (only if coord)
- suspendViewHandler() - Method in class org.jgroups.jmx.protocols.pbcast.GMS
- suspendViewHandler() - Method in interface org.jgroups.jmx.protocols.pbcast.GMSMBean
- suspendViewHandler() - Method in class org.jgroups.protocols.pbcast.GMS
- synchronizedMap(ReplicatedMap<K, V>) - Static method in class org.jgroups.blocks.ReplicatedHashMap
-
Creates a synchronized facade for a ReplicatedMap.
T
- t - Variable in exception 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 exception class org.jgroups.persistence.CannotRemoveException
-
members are made available so that the top level user can dump appropriate members on to his stack trace
- tableChanged(TableModelEvent) - Method in class org.jgroups.demos.DistributedTreeDemo
- take() - Method in class org.jgroups.util.FIFOMessageQueue
- take() - Method in class org.jgroups.util.OutgoingBufferPool
- take() - Method in class org.jgroups.util.SizeBoundedQueue
- target - Variable in class org.jgroups.stack.StateTransferInfo
- TCP - Class in org.jgroups.jmx.protocols
- TCP - Class in org.jgroups.protocols
-
TCP based protocol.
- TCP() - Constructor for class org.jgroups.jmx.protocols.TCP
- TCP() - Constructor for class org.jgroups.protocols.TCP
- TCP(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCP
- TCP_NIO - Class in org.jgroups.jmx.protocols
- TCP_NIO - Class in org.jgroups.protocols
-
Transport using NIO
- TCP_NIO() - Constructor for class org.jgroups.jmx.protocols.TCP_NIO
- TCP_NIO() - Constructor for class org.jgroups.protocols.TCP_NIO
- TCP_NIO(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCP_NIO
- TCP_NIOMBean - Interface in org.jgroups.jmx.protocols
- TCPGOSSIP - Class in org.jgroups.jmx.protocols
- TCPGOSSIP - Class in org.jgroups.protocols
-
The TCPGOSSIP protocol layer retrieves the initial membership (used by the GMS when started by sending event FIND_INITIAL_MBRS down the stack).
- TCPGOSSIP() - Constructor for class org.jgroups.jmx.protocols.TCPGOSSIP
- TCPGOSSIP() - Constructor for class org.jgroups.protocols.TCPGOSSIP
- TCPGOSSIP(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCPGOSSIP
- TCPGOSSIPMBean - Interface in org.jgroups.jmx.protocols
- TcpHeader - Class in org.jgroups.protocols
- TcpHeader() - Constructor for class org.jgroups.protocols.TcpHeader
- TcpHeader(String) - Constructor for class org.jgroups.protocols.TcpHeader
- TCPMBean - Interface in org.jgroups.jmx.protocols
- TCPPING - Class in org.jgroups.jmx.protocols
- TCPPING - Class in org.jgroups.protocols
-
The TCPPING protocol layer retrieves the initial membership in answer to the GMS's FIND_INITIAL_MBRS event.
- TCPPING() - Constructor for class org.jgroups.jmx.protocols.TCPPING
- TCPPING() - Constructor for class org.jgroups.protocols.TCPPING
- TCPPING(Protocol) - Constructor for class org.jgroups.jmx.protocols.TCPPING
- TCPPING_INITIAL_HOSTS - Static variable in class org.jgroups.Global
- TCPPINGMBean - Interface in org.jgroups.jmx.protocols
- thread_naming_pattern - Variable in class org.jgroups.protocols.TP
-
Names the current thread.
- thread_pool - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_enabled - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_keep_alive_time - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_max_threads - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_min_threads - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_queue - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_queue_enabled - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_queue_max_size - Variable in class org.jgroups.stack.GossipRouter
- thread_pool_rejection_policy - Variable in class org.jgroups.stack.GossipRouter
- THREAD_PREFIX - Static variable in class org.jgroups.Global
- THREAD_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
- threadCreated(Thread) - Method in interface org.jgroups.util.ThreadDecorator
-
Notification that
thread
has just been created. - threadDecorator - Variable in class org.jgroups.util.DefaultThreadFactory
- ThreadDecorator - Interface in org.jgroups.util
-
An object that can alter the state of a thread when it receives a callback from a
ThreadManager
notifying it that the thread has been created or released from use. - ThreadFactory - Interface in org.jgroups.util
- ThreadManager - Interface in org.jgroups.util
-
An object that manages threads and provides callbacks to a
ThreadDecorator
to allow it to alter their state. - ThreadManagerThreadPoolExecutor - Class in org.jgroups.util
-
ThreadPoolExecutor subclass that implements @{link ThreadManager}.
- ThreadManagerThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>) - Constructor for class org.jgroups.util.ThreadManagerThreadPoolExecutor
- ThreadManagerThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class org.jgroups.util.ThreadManagerThreadPoolExecutor
- ThreadManagerThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory) - Constructor for class org.jgroups.util.ThreadManagerThreadPoolExecutor
- ThreadManagerThreadPoolExecutor(int, int, long, TimeUnit, BlockingQueue<Runnable>, ThreadFactory, RejectedExecutionHandler) - Constructor for class org.jgroups.util.ThreadManagerThreadPoolExecutor
- ThreadPool - Class in org.jgroups.util
-
Maintains a set of ReusableThreads.
- ThreadPool(int) - Constructor for class org.jgroups.util.ThreadPool
- THREADPOOL_SHUTDOWN_WAIT_TIME - Static variable in class org.jgroups.Global
- threadReleased(Thread) - Method in interface org.jgroups.util.ThreadDecorator
-
Notification that
thread
has just been released from use (e.g. - TIME_TO_LIVE - Static variable in class org.jgroups.protocols.JMS
- TimedWriter - Class in org.jgroups.util
-
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
- timeout - Variable in class org.jgroups.blocks.GroupRequest
- timeout - Variable in class org.jgroups.blocks.ReplicatedHashMap
-
For blocking updates only: the max time to wait (0 == forever)
- timeout - Variable in class org.jgroups.stack.StateTransferInfo
- TimeoutException - Exception Class in org.jgroups
-
Thrown if members fail to respond in time.
- TimeoutException() - Constructor for exception class org.jgroups.TimeoutException
- TimeoutException(String) - Constructor for exception class org.jgroups.TimeoutException
- timer - Variable in class org.jgroups.protocols.TP
-
================================== Timer thread pool =================================
- timer - Variable in class org.jgroups.stack.GossipRouter
- TIMER_NUM_THREADS - Static variable in class org.jgroups.Global
- timer_thread_factory - Variable in class org.jgroups.protocols.TP
- TimeScheduler - Class in org.jgroups.util
-
Fixed-delay invalid input: '&' fixed-rate single thread scheduler
- TimeScheduler() - Constructor for class org.jgroups.util.TimeScheduler
-
Create a scheduler that executes tasks in dynamically adjustable intervals
- TimeScheduler(int) - Constructor for class org.jgroups.util.TimeScheduler
- TimeScheduler(ThreadFactory) - Constructor for class org.jgroups.util.TimeScheduler
- TimeScheduler(ThreadFactory, int) - Constructor for class org.jgroups.util.TimeScheduler
- TimeScheduler.Task - Interface in org.jgroups.util
-
The interface that submitted tasks must implement
- TMP_VIEW - Static variable in class org.jgroups.Event
- toArray() - Method in class org.jgroups.util.SizeBoundedQueue
- toArray() - Method in class org.jgroups.util.UnmodifiableVector
- toArray(Object[]) - Method in class org.jgroups.util.SizeBoundedQueue
- toArray(Object[]) - Method in class org.jgroups.util.UnmodifiableVector
- toByteArray() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Creates a newly allocated byte array.
- TOKEN_ATTR - Static variable in class org.jgroups.auth.MD5Token
- TOKEN_ATTR - Static variable in class org.jgroups.auth.SimpleToken
- TOKEN_ATTR - Static variable in class org.jgroups.auth.X509Token
- TOKEN_TYPE - Static variable in class org.jgroups.auth.MD5Token
- Topology - Class in org.jgroups.demos
-
Demonstrates the membership service.
- Topology() - Constructor for class org.jgroups.demos.Topology
- tossWeightedCoin(double) - Static method in class org.jgroups.util.Util
-
Tosses a coin weighted with probability and returns true or false.
- toString() - Method in class org.jgroups.BlockEvent
- toString() - Method in class org.jgroups.blocks.BasicConnectionTable
- toString() - Method in class org.jgroups.blocks.DistributedQueue
- toString() - Method in class org.jgroups.blocks.GroupRequest
- toString() - Method in exception class org.jgroups.blocks.LockingException
- toString() - Method in class org.jgroups.blocks.MethodCall
- toString() - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- toString() - Method in class org.jgroups.blocks.ReplicatedTree.Node
- toString() - Method in class org.jgroups.blocks.ReplicatedTree
- toString() - Method in class org.jgroups.blocks.RequestCorrelator.Header
- toString() - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- toString() - Method in class org.jgroups.blocks.VotingAdapter.VoteResult
- toString() - Method in exception class org.jgroups.ChannelClosedException
- toString() - Method in exception class org.jgroups.ChannelNotConnectedException
- toString() - Method in class org.jgroups.conf.ClassConfigurator
- toString() - Method in class org.jgroups.demos.DrawCommand
- toString() - Method in class org.jgroups.demos.wb.Node
- 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() - 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.mux.MuxHeader
- toString() - Method in class org.jgroups.mux.ServiceInfo
- toString() - Method in exception class org.jgroups.persistence.CannotConnectException
- toString() - Method in exception class org.jgroups.persistence.CannotCreateSchemaException
- toString() - Method in exception class org.jgroups.persistence.CannotPersistException
- toString() - Method in exception class org.jgroups.persistence.CannotRemoveException
- toString() - Method in exception 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.CAUSAL.CausalNewViewHeader
- toString() - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- toString() - Method in class org.jgroups.protocols.DUMMY_TP
- toString() - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- toString() - Method in class org.jgroups.protocols.FC.FcHeader
- toString() - Method in class org.jgroups.protocols.FD_ALL.Header
- 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.FD.FdHeader
- toString() - Method in class org.jgroups.protocols.FlushRsp
- toString() - Method in class org.jgroups.protocols.FragHeader
- toString() - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
- toString() - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Get the string representation of the address.
- toString() - Method in class org.jgroups.protocols.JMS
-
Get the string representation of the protocol.
- toString() - Method in class org.jgroups.protocols.LOOPBACK
- toString() - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- toString() - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- toString() - Method in class org.jgroups.protocols.pbcast.GmsImpl.Request
- toString() - Method in class org.jgroups.protocols.pbcast.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.STABLE.StableHeader
- toString() - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- toString() - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- toString() - Method in class org.jgroups.protocols.PERF_TP
- toString() - Method in class org.jgroups.protocols.PingHeader
- toString() - Method in class org.jgroups.protocols.PingRsp
- toString() - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- toString() - Method in class org.jgroups.protocols.SFC.Header
- toString() - Method in class org.jgroups.protocols.SHARED_LOOPBACK
- toString() - Method in class org.jgroups.protocols.SMACK.SmackHeader
- toString() - Method in class org.jgroups.protocols.TcpHeader
- toString() - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- toString() - Method in class org.jgroups.protocols.TP
-
debug only
- toString() - Method in class org.jgroups.protocols.TpHeader
- toString() - Method in class org.jgroups.protocols.TRACE
- toString() - Method in class org.jgroups.protocols.TransportedVectorTime
-
Returns String representation of this vector timestamp
- toString() - Method in class org.jgroups.protocols.TUNNEL
- toString() - Method in class org.jgroups.protocols.TunnelHeader
- toString() - Method in class org.jgroups.protocols.UdpHeader
- toString() - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- toString() - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- toString() - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- toString() - Method in class org.jgroups.SetStateEvent
- 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.ExponentialInterval
- toString() - Method in class org.jgroups.stack.GossipData
- toString() - Method in class org.jgroups.stack.IpAddress
- toString() - Method in class org.jgroups.stack.NakReceiverWindow
- toString() - Method in class org.jgroups.stack.Retransmitter
- toString() - Method in class org.jgroups.stack.RouterStub
- toString() - Method in class org.jgroups.stack.StateTransferInfo
- toString() - Method in exception class org.jgroups.SuspectedException
- toString() - Method in class org.jgroups.SuspectEvent
- toString() - Method in exception class org.jgroups.TimeoutException
- toString() - Method in class org.jgroups.UnblockEvent
- toString() - Method in class org.jgroups.util.AckCollector
- toString() - Method in class org.jgroups.util.AgeOutCache
- toString() - Method in class org.jgroups.util.Buffer
- toString() - Method in class org.jgroups.util.Digest.Entry
- toString() - Method in class org.jgroups.util.Digest
- toString() - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Converts the buffer's contents into a string decoding bytes using the platform's default character set.
- toString() - Method in class org.jgroups.util.FIFOMessageQueue
- toString() - Method in class org.jgroups.util.Headers
- toString() - Method in class org.jgroups.util.Promise
- toString() - Method in class org.jgroups.util.Queue
-
prints the size of the queue
- toString() - Method in exception class org.jgroups.util.QueueClosedException
- toString() - Method in class org.jgroups.util.Range
- toString() - Method in class org.jgroups.util.ResponseCollector
- toString() - Method in class org.jgroups.util.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.SeqnoTable
- toString() - Method in class org.jgroups.util.ThreadPool
- toString() - Method in class org.jgroups.util.Triple
- toString() - Method in class org.jgroups.util.Tuple
- toString() - Method in class org.jgroups.util.UnmodifiableVector
- toString() - Method in class org.jgroups.View
- toString() - Method in class org.jgroups.ViewId
- toString(boolean) - Method in class org.jgroups.JChannel
- toString(boolean) - Method in class org.jgroups.jmx.JChannel
- toString(boolean) - Method in interface org.jgroups.jmx.JChannelMBean
- toString(int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Deprecated.This method does not properly convert bytes into characters. As of JDK 1.1, the preferred way to do this is via the
toString(String enc)
method, which takes an encoding-name argument, or thetoString()
method, which uses the platform's default character encoding. - toString(String) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Converts the buffer's contents into a string by decoding the bytes using the specified
charsetName
. - 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
- TotalOrder - Class in org.jgroups.demos
-
Originally written to be a demo for TOTAL order (code to be written by a student).
- TotalOrder(String, long, int, int, String, int) - Constructor for class org.jgroups.demos.TotalOrder
- TotalPayload(int) - Constructor for class org.jgroups.demos.TotalTokenDemo.TotalPayload
- TotalTokenDemo - Class in org.jgroups.demos
-
Demonstration of TOTAL_TOKEN protocol stack implementing total order.
- TotalTokenDemo(String) - Constructor for class org.jgroups.demos.TotalTokenDemo
- TotalTokenDemo.TotalPayload - Class in org.jgroups.demos
- TP - Class in org.jgroups.jmx.protocols
- TP - Class in org.jgroups.protocols
-
Generic transport - specific implementations should extend this abstract class.
- TP() - Constructor for class org.jgroups.jmx.protocols.TP
- TP() - Constructor for class org.jgroups.protocols.TP
-
Creates the TP protocol, and initializes the state variables, does however not start any sockets or threads.
- TP(Protocol) - Constructor for class org.jgroups.jmx.protocols.TP
- TP.ProbeHandler - Interface in org.jgroups.protocols
- TP.ProtocolAdapter - Class in org.jgroups.protocols
- TpHeader - Class in org.jgroups.protocols
-
Generic transport header, used by TP.
- TpHeader() - Constructor for class org.jgroups.protocols.TpHeader
- TpHeader(String) - Constructor for class org.jgroups.protocols.TpHeader
- TPMBean - Interface in org.jgroups.jmx.protocols
- TRACE - Class in org.jgroups.protocols
- TRACE() - Constructor for class org.jgroups.protocols.TRACE
- transport - Variable in class org.jgroups.blocks.GroupRequest
- transport - Variable in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.
- transport - Variable in class org.jgroups.blocks.RequestCorrelator
-
The protocol layer to use to pass up/down messages.
- Transport - Interface in org.jgroups
-
Defines a very small subset of the functionality of a channel, essentially only the methods for sending and receiving messages.
- transport_adapter - Variable in class org.jgroups.blocks.MessageDispatcher
- TransportedVectorTime - Class in org.jgroups.protocols
-
Lighweight representation of the VectorTime clock suitable for network transport
- TransportedVectorTime() - Constructor for class org.jgroups.protocols.TransportedVectorTime
- TransportedVectorTime(int, int[]) - Constructor for class org.jgroups.protocols.TransportedVectorTime
-
Constructs TransportedVectorTime with sender index and vector values
- trim(double) - Static method in class org.jgroups.debug.Profiler
- trimToSize() - Method in class org.jgroups.util.UnmodifiableVector
- Triple<V1,
V2, - Class in org.jgroups.utilV3> -
Holds 3 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate holder object for the values, and don't want to pass the values as a list or array.
- Triple(V1, V2, V3) - Constructor for class org.jgroups.util.Triple
- TUNNEL - Class in org.jgroups.protocols
-
Replacement for UDP.
- TUNNEL() - Constructor for class org.jgroups.protocols.TUNNEL
- TunnelHeader - Class in org.jgroups.protocols
- TunnelHeader() - Constructor for class org.jgroups.protocols.TunnelHeader
- TunnelHeader(String) - Constructor for class org.jgroups.protocols.TunnelHeader
- Tuple<V1,
V2> - Class in org.jgroups.util -
Holds 2 values, useful when we have a map with a key, but more than 1 value and we don't want to create a separate holder object for the values, and don't want to pass the values as a list or array.
- Tuple(V1, V2) - Constructor for class org.jgroups.util.Tuple
- TwoPhaseVoteWrapper(TwoPhaseVotingListener) - Constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
- TwoPhaseVotingAdapter - Class in org.jgroups.blocks
-
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 in org.jgroups.blocks
- TwoPhaseVotingAdapter.TwoPhaseWrapper - Class in org.jgroups.blocks
-
Wrapper of the decree to voting decree.
- TwoPhaseVotingListener - Interface in org.jgroups.blocks
-
Implementations of this interface can participate in two-phase voting process.
- TwoPhaseWrapper(Object) - Constructor for class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseWrapper
- type - Variable in class org.jgroups.blocks.RequestCorrelator.Header
-
Type of header: request or reply
- type - Variable in class org.jgroups.protocols.PingHeader
- type2Str(byte) - Static method in class org.jgroups.protocols.pbcast.NakAckHeader
- type2Str(byte) - Static method in class org.jgroups.protocols.UNICAST.UnicastHeader
- type2String(byte) - Static method in class org.jgroups.protocols.FD_SOCK.FdHeader
- type2String(int) - Static method in class org.jgroups.Event
- type2String(int) - Static method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- type2String(int) - Static method in class org.jgroups.stack.GossipRouter
- types - Variable in class org.jgroups.blocks.MethodCall
-
The class types, e.g., new Class[]{String.class, int.class}.
- TYPES - Static variable in class org.jgroups.blocks.MethodCall
-
Use class information.
- typeToString(int) - Static method in class org.jgroups.mux.ServiceInfo
U
- UCAST_RECEIVER_THREAD_NAME - Static variable in class org.jgroups.protocols.UDP.UcastReceiver
- UcastReceiver() - Constructor for class org.jgroups.protocols.UDP.UcastReceiver
- UDP - Class in org.jgroups.jmx.protocols
- UDP - Class in org.jgroups.protocols
-
IP multicast transport based on UDP.
- UDP() - Constructor for class org.jgroups.jmx.protocols.UDP
- UDP() - Constructor for class org.jgroups.protocols.UDP
-
Creates the UDP protocol, and initializes the state variables, does however not start any sockets or threads.
- UDP(Protocol) - Constructor for class org.jgroups.jmx.protocols.UDP
- UDP_IP_TTL - Static variable in class org.jgroups.Global
- UDP_MCAST_ADDR - Static variable in class org.jgroups.Global
- UDP_MCAST_PORT - Static variable in class org.jgroups.Global
- UDP.UcastReceiver - Class in org.jgroups.protocols
- UdpHeader - Class in org.jgroups.protocols
- UdpHeader() - Constructor for class org.jgroups.protocols.UdpHeader
- UdpHeader(String) - Constructor for class org.jgroups.protocols.UdpHeader
- UDPMBean - Interface in org.jgroups.jmx.protocols
- unblock() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- unblock() - Method in class org.jgroups.blocks.MembershipListenerAdapter
- unblock() - Method in class org.jgroups.blocks.ReplicatedHashMap
- unblock() - Method in class org.jgroups.demos.Draw
- unblock() - Method in interface org.jgroups.ExtendedMembershipListener
-
Called after the FLUSH protocol has unblocked previously blocked senders, and messages can be sent again.
- unblock() - Method in class org.jgroups.ExtendedReceiverAdapter
- unblock() - Method in class org.jgroups.jmx.protocols.FC
- unblock() - Method in interface org.jgroups.jmx.protocols.FCMBean
- unblock() - Method in class org.jgroups.jmx.protocols.SFC
- unblock() - Method in interface org.jgroups.jmx.protocols.SFCMBean
- unblock() - Method in class org.jgroups.protocols.FC
-
Allows to unblock a blocked sender from an external program, e.g.
- unblock() - Method in class org.jgroups.protocols.SFC
- UNBLOCK - Static variable in class org.jgroups.Event
- UnblockEvent - Class in org.jgroups
-
Trivial object that represents a block event.
- UnblockEvent() - Constructor for class org.jgroups.UnblockEvent
- UNICAST - Class in org.jgroups.jmx.protocols
- UNICAST - Class in org.jgroups.protocols
-
Reliable unicast layer.
- UNICAST() - Constructor for class org.jgroups.jmx.protocols.UNICAST
- UNICAST() - Constructor for class org.jgroups.protocols.UNICAST
- UNICAST(Protocol) - Constructor for class org.jgroups.jmx.protocols.UNICAST
- UNICAST.UnicastHeader - Class in org.jgroups.protocols
- UnicastHeader() - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
- UnicastHeader(byte, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
- UnicastHeader(byte, long, long) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
- UnicastHeader(byte, long, long, boolean) - Constructor for class org.jgroups.protocols.UNICAST.UnicastHeader
- UNICASTMBean - Interface in org.jgroups.jmx.protocols
- unlock(Object, Object) - Method in class org.jgroups.blocks.DistributedLockManager
-
Unlocks an object with
lockId
on behalf of the specifiedowner
. - unlock(Object, Object) - Method in interface org.jgroups.blocks.LockManager
-
Release lock on
obj
owned by specifiedowner
. - unlock(Object, Object, boolean) - Method in class org.jgroups.blocks.DistributedLockManager
-
Unlocks an object with
lockId
on behalf of the specifiedowner
. - unlock(Object, Object, boolean) - Method in interface org.jgroups.blocks.LockManager
-
Release lock on
obj
owned by specifiedowner
. - unlock(Object, Object, boolean, long) - Method in class org.jgroups.blocks.DistributedLockManager
- unlock(Object, Object, long) - Method in class org.jgroups.blocks.DistributedLockManager
- unmodifiableVector(Vector<? extends T>) - Static method in class org.jgroups.util.Util
- UnmodifiableVector - Class in org.jgroups.util
-
Vector which cannot be modified
- UnmodifiableVector(Vector) - Constructor for class org.jgroups.util.UnmodifiableVector
- unregister(String, Address) - Method in class org.jgroups.stack.GossipClient
- unregister(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
-
Unregisters object_name and everything under it
- UNREGISTER - Static variable in class org.jgroups.stack.GossipRouter
- unregisterChannel(MBeanServer, String) - Static method in class org.jgroups.jmx.JmxConfigurator
- unregisterChannel(MBeanServer, ObjectName) - Static method in class org.jgroups.jmx.JmxConfigurator
- unregisterListener(Serializable) - Method in class org.jgroups.blocks.PullPushAdapter
-
Deprecated.Removes a message listener to a given identifier from the message listeners map.
- unregisterProbeHandler(TP) - Method in class org.jgroups.blocks.RequestCorrelator
- unregisterProbeHandler(TP.ProbeHandler) - Method in class org.jgroups.protocols.TP
- unregisterProtocols(MBeanServer, JChannel, String) - Static method in class org.jgroups.jmx.JmxConfigurator
- unsetThreadNames() - Method in class org.jgroups.protocols.TP
- unsetThreadNames() - Method in class org.jgroups.protocols.UDP
- unstable_msgs - Variable in class org.jgroups.protocols.FlushRsp
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ClientGmsImpl
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.CoordGmsImpl
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.GmsImpl
- unsuspect(Address) - Method in class org.jgroups.protocols.pbcast.ParticipantGmsImpl
-
Removes previously suspected member from list of currently suspected members
- unsuspect(Address) - Method in class org.jgroups.util.AckCollector
- UNSUSPECT - Static variable in class org.jgroups.Event
- up(Event) - Method in class org.jgroups.JChannel
-
Callback method
Called by the ProtocolStack when a message is received. - up(Event) - Method in class org.jgroups.mux.Multiplexer
-
Remove mux header and dispatch to correct MuxChannel
- up(Event) - Method in class org.jgroups.protocols.AUTH
-
An event was received from the layer below.
- up(Event) - Method in class org.jgroups.protocols.BARRIER
- up(Event) - Method in class org.jgroups.protocols.BSH
- up(Event) - Method in class org.jgroups.protocols.CAUSAL
-
Process an upward event.
- 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_JOIN_REQ
- up(Event) - Method in class org.jgroups.protocols.DELAY
- up(Event) - Method in class org.jgroups.protocols.DISCARD_PAYLOAD
- up(Event) - Method in class org.jgroups.protocols.DISCARD
- up(Event) - Method in class org.jgroups.protocols.Discovery
-
An event was received from the layer below.
- up(Event) - Method in class org.jgroups.protocols.DUPL
- up(Event) - Method in class org.jgroups.protocols.ENCRYPT
- up(Event) - Method in class org.jgroups.protocols.EXAMPLE
- up(Event) - Method in class org.jgroups.protocols.FC
- up(Event) - Method in class org.jgroups.protocols.FD_ALL
- up(Event) - Method in class org.jgroups.protocols.FD_ICMP
- up(Event) - Method in class org.jgroups.protocols.FD_SIMPLE
- up(Event) - Method in class org.jgroups.protocols.FD_SOCK
- up(Event) - Method in class org.jgroups.protocols.FD
- up(Event) - Method in class org.jgroups.protocols.FRAG
-
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
- up(Event) - Method in class org.jgroups.protocols.FRAG2
-
If event is a message, if it is fragmented, re-assemble fragments into big message and pass up the stack.
- up(Event) - Method in class org.jgroups.protocols.HDRS
- up(Event) - Method in class org.jgroups.protocols.HTOTAL
- up(Event) - Method in class org.jgroups.protocols.MERGE2
- up(Event) - Method in class org.jgroups.protocols.MERGE3
- up(Event) - Method in class org.jgroups.protocols.MERGEFAST
- up(Event) - Method in class org.jgroups.protocols.MPING
- up(Event) - Method in class org.jgroups.protocols.PARTITION
- up(Event) - Method in class org.jgroups.protocols.pbcast.FLUSH
- up(Event) - Method in class org.jgroups.protocols.pbcast.GMS
- up(Event) - Method in class org.jgroups.protocols.pbcast.NAKACK
-
Callback.
- up(Event) - Method in class org.jgroups.protocols.pbcast.STABLE
- up(Event) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER
- up(Event) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER
- up(Event) - Method in class org.jgroups.protocols.PERF_TP
- up(Event) - Method in class org.jgroups.protocols.PING
- up(Event) - Method in class org.jgroups.protocols.SEQUENCER
- up(Event) - Method in class org.jgroups.protocols.SFC
- up(Event) - Method in class org.jgroups.protocols.SHUFFLE
-
Adds upcoming messages to the
messages Listinvalid input: '<'\code> where the
messagesHandlerinvalid input: '<'\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.STATS
- up(Event) - Method in class org.jgroups.protocols.TP.ProtocolAdapter
- up(Event) - Method in class org.jgroups.protocols.TP
-
handle the UP event.
- up(Event) - Method in class org.jgroups.protocols.TRACE
- up(Event) - Method in class org.jgroups.protocols.UNICAST
- up(Event) - Method in class org.jgroups.protocols.VERIFY_SUSPECT
- up(Event) - Method in class org.jgroups.protocols.VIEW_SYNC
- up(Event) - Method in class org.jgroups.stack.Protocol
-
An event was received from the layer below.
- up(Event) - Method in class org.jgroups.stack.ProtocolStack
- up(Event) - Method in interface org.jgroups.UpHandler
-
Invoked for all channel events except connection management and state transfer.
- up_handler - Variable in class org.jgroups.Channel
- up_prot - Variable in class org.jgroups.stack.Protocol
- update(Graphics) - Method in class org.jgroups.demos.wb.GraphPanel
- update_mode - Variable in class org.jgroups.blocks.ReplicatedHashMap
-
Whether updates across the cluster should be asynchronous (default) or synchronous)
- UpdateException - Exception Class in org.jgroups.blocks
- UpdateException(String) - Constructor for exception class org.jgroups.blocks.UpdateException
- updatePort(int) - Method in class org.jgroups.util.PortsManager
-
Updates the timestamp for the given port
- UpHandler - Interface in org.jgroups
-
Provides a way of taking over a channel's tasks.
- upThreadEnabled() - Method in class org.jgroups.stack.Protocol
-
Deprecated.up_thread was removed
- URGENT_CREDIT_REQUEST - Static variable in class org.jgroups.protocols.SFC.Header
- use_gui - Variable in class org.jgroups.protocols.DISCARD
- use_numbering - Variable in class org.jgroups.util.DefaultThreadFactory
- USER_DEFINED - Static variable in class org.jgroups.Event
- UserInfoDialog - Class in org.jgroups.demos.wb
- UserInfoDialog(Frame) - Constructor for class org.jgroups.demos.wb.UserInfoDialog
- Util - Class in org.jgroups.util
-
Collection of various utility routines that can not be assigned to other classes.
- Util() - Constructor for class org.jgroups.util.Util
V
- value() - Element in annotation type org.jgroups.annotations.GuardedBy
- valueChanged(TreeSelectionEvent) - Method in class org.jgroups.demos.DistributedTreeDemo
- values() - Method in class org.jgroups.util.Queue
-
Returns all the elements of the queue
- values() - Method in class org.jgroups.util.RspList
- VERIFY_SUSPECT - Class in org.jgroups.protocols
-
Catches SUSPECT events traveling up the stack.
- VERIFY_SUSPECT() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT
- VERIFY_SUSPECT.VerifyHeader - Class in org.jgroups.protocols
- VerifyHeader() - Constructor for class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- version - Static variable in class org.jgroups.Version
- Version - Class in org.jgroups
-
We're using the scheme described at http://www.jboss.com/index.html?module=bbinvalid input: '&op'=viewtopicinvalid input: '&t'=77231 for major, minor and micro version numbers.
- Version() - Constructor for class org.jgroups.Version
- vid - Variable in class org.jgroups.View
- view - Variable in class org.jgroups.protocols.TP
- View - Class in org.jgroups
-
A view is a local representation of the current membership of a group.
- View() - Constructor for class org.jgroups.View
-
creates an empty view, should not be used
- View(Address, long, Vector<Address>) - Constructor for class org.jgroups.View
-
Creates a new view
- View(ViewId, Vector<Address>) - Constructor for class org.jgroups.View
-
Creates a new view
- VIEW - Static variable in class org.jgroups.Channel
- VIEW - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- VIEW_ACK - Static variable in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- VIEW_CHANGE - Static variable in class org.jgroups.Event
- VIEW_SYNC - Class in org.jgroups.jmx.protocols
- VIEW_SYNC - Class in org.jgroups.protocols
-
Periodically sends the view to the group.
- VIEW_SYNC - Static variable in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- VIEW_SYNC() - Constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
- VIEW_SYNC() - Constructor for class org.jgroups.protocols.VIEW_SYNC
- VIEW_SYNC(Protocol) - Constructor for class org.jgroups.jmx.protocols.VIEW_SYNC
- VIEW_SYNC_REQ - Static variable in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- VIEW_SYNC.ViewSyncHeader - Class in org.jgroups.protocols
- VIEW_SYNCMBean - Interface in org.jgroups.jmx.protocols
- viewAccepted(View) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- viewAccepted(View) - Method in class org.jgroups.blocks.DistributedLockManager
-
Remove all locks held by members who left the previous view
- 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.ReplicatedHashMap
- viewAccepted(View) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- 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.applets.DrawApplet
- viewAccepted(View) - Method in class org.jgroups.demos.ChatCore
- viewAccepted(View) - Method in class org.jgroups.demos.Draw
- viewAccepted(View) - Method in class org.jgroups.demos.QuoteClient
- viewAccepted(View) - Method in class org.jgroups.demos.QuoteServer
- viewAccepted(View) - Method in class org.jgroups.demos.Topology
- viewAccepted(View) - Method in class org.jgroups.demos.ViewDemo
- viewAccepted(View) - Method in class org.jgroups.demos.wb.Whiteboard
- viewAccepted(View) - Method in class org.jgroups.ExtendedReceiverAdapter
- viewAccepted(View) - Method in interface org.jgroups.MembershipListener
-
Called when a change in membership has occurred.
- viewAccepted(View) - Method in class org.jgroups.ReceiverAdapter
- viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedHashtable.Notification
-
Deprecated.
- viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedQueue.Notification
- viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.DistributedTree.ViewListener
- viewChange(Vector, Vector) - Method in interface org.jgroups.blocks.ReplicatedHashtable.Notification
-
Deprecated.
- viewChange(Vector, Vector) - Method in class org.jgroups.demos.DistributedHashtableDemo
- viewChange(Vector, Vector) - Method in class org.jgroups.demos.DistributedQueueDemo
- viewChange(View) - Method in class org.jgroups.blocks.GroupRequest
-
Any member of 'membership' that is not in the new view is flagged as SUSPECTED.
- viewChange(View) - Method in interface org.jgroups.blocks.ReplicatedTree.ReplicatedTreeListener
- viewChange(View) - Method in interface org.jgroups.blocks.RspCollector
- viewChange(View, Vector<Address>, Vector<Address>) - Method in interface org.jgroups.blocks.ReplicatedHashMap.Notification
- viewChange(View, Vector, Vector) - Method in class org.jgroups.demos.ReplicatedHashMapDemo
- ViewDemo - Class in org.jgroups.demos
-
Demos the reception of views using a PullPushAdapter.
- ViewDemo() - Constructor for class org.jgroups.demos.ViewDemo
- viewHandlerSize() - Method in class org.jgroups.protocols.pbcast.GMS
- ViewId - Class in org.jgroups
-
ViewIds are used for ordering views (each view has a ViewId and a list of members).
- ViewId() - Constructor for class org.jgroups.ViewId
- ViewId(Address) - Constructor for class org.jgroups.ViewId
-
Creates a ViewID with the coordinator address and a Lamport timestamp of 0.
- ViewId(Address, long) - Constructor for class org.jgroups.ViewId
-
Creates a ViewID with the coordinator address and the given Lamport timestamp.
- ViewSyncHeader() - Constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- ViewSyncHeader(int, View) - Constructor for class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- vote(Object) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter.TwoPhaseVoteWrapper
- vote(Object) - Method in interface org.jgroups.blocks.VotingListener
-
Each member is able to vote with
true
orfalse
messages. - vote(Object, int, long) - Method in class org.jgroups.blocks.VotingAdapter
-
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
- vote(Object, int, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.VotingAdapter
-
Performs actual voting on the VoteChannel using the JGroups facilities for communication.
- vote(Object, long) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
-
Performs the two-phase voting on the decree.
- vote(Object, long) - Method in class org.jgroups.blocks.VotingAdapter
-
Vote on the specified decree requiring all nodes to vote.
- vote(Object, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.TwoPhaseVotingAdapter
-
Performs the two-phase voting on the decree.
- vote(Object, long, VoteResponseProcessor) - Method in class org.jgroups.blocks.VotingAdapter
-
Vote on the specified decree requiring all nodes to vote.
- 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.
- VoteException - Exception Class in org.jgroups.blocks
-
This exception is thrown when voting listener cannot vote on the specified decree.
- VoteException(String) - Constructor for exception class org.jgroups.blocks.VoteException
- VoteResponseProcessor - Interface in org.jgroups.blocks
-
VoteResultProcessor Applications that use the VotingAdapter and/or TwoPhaseVotingAdapter can pass an implementation of this down the vote calls, to intercept processing of the VoteResults returned by other nodes.
- VoteResult() - Constructor for class org.jgroups.blocks.VotingAdapter.VoteResult
- VotingAdapter - Class in org.jgroups.blocks
-
Voting adapter provides a voting functionality for an application.
- VotingAdapter(PullPushAdapter, Serializable) - Constructor for class org.jgroups.blocks.VotingAdapter
- VotingAdapter(Channel) - Constructor for class org.jgroups.blocks.VotingAdapter
-
Creates an instance of the VoteChannel that uses JGroups for communication between group members.
- VotingAdapter.FailureVoteResult - Class in org.jgroups.blocks
-
Class that represents a result of local voting on the failed node.
- VotingAdapter.VoteResult - Class in org.jgroups.blocks
-
This class represents the result of local voting.
- VotingListener - Interface in org.jgroups.blocks
-
Implemetations of this interface are able to participate in voting process.
W
- waitForAllAcks() - Method in class org.jgroups.util.AckCollector
- waitForAllAcks(long) - Method in class org.jgroups.util.AckCollector
- waitForAllResponses(long) - Method in class org.jgroups.util.ResponseCollector
-
Waits until all responses have been received, or until a timeout has elapsed.
- waitForDiscoveryRequestReception() - Method in class org.jgroups.protocols.PING
- waitUntilAllAcksReceived(long) - Method in class org.jgroups.stack.AckMcastSenderWindow
-
Waits until all outstanding messages have been ACKed by all receivers.
- waitUntilClosed(long) - Method in class org.jgroups.util.Queue
-
Waits until the queue has been closed.
- waitUntilDone() - Method in class org.jgroups.util.ReusableThread
- wasReceived() - Method in class org.jgroups.util.Rsp
- wasSuspected() - Method in class org.jgroups.util.Rsp
- Whiteboard - Class in org.jgroups.demos.wb
-
Shared whiteboard: members are represented by rectangles that contain their names and the OS/arch of the machine they are working on.
- Whiteboard() - Constructor for class org.jgroups.demos.wb.Whiteboard
- Whiteboard(String) - Constructor for class org.jgroups.demos.wb.Whiteboard
- WHO_HAS_SOCK - Static variable in class org.jgroups.protocols.FD_SOCK.FdHeader
- width - Variable in class org.jgroups.demos.wb.Node
- windowActivated(WindowEvent) - Method in class org.jgroups.demos.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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- 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.ReplicatedHashMapDemo
- windowOpened(WindowEvent) - Method in class org.jgroups.demos.Topology
- wouldBeNewCoordinator(Address) - Method in class org.jgroups.protocols.pbcast.GMS
-
Checks whether the potential_new_coord would be the new coordinator (2nd in line)
- write(byte[], int, int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Writes
len
bytes from the specified byte array starting at offsetoff
to this byte array output stream. - write(byte[], int, int) - Method in class org.jgroups.util.ExposedDataOutputStream
-
Writes
len
bytes from the specified byte array starting at offsetoff
to the underlying output stream. - write(int) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
- write(int) - Method in class org.jgroups.util.ExposedDataOutputStream
-
Writes the specified byte (the low eight bits of the argument
b
) to the underlying output stream. - write(Externalizable, ObjectOutput) - Static method in class org.jgroups.util.Marshaller
-
Writes an object to the ObjectOutput stream.
- write(OutputStream, byte[], long) - Method in class org.jgroups.util.TimedWriter
-
Writes data to an output stream.
- write(OutputStream, int, long) - Method in class org.jgroups.util.TimedWriter
- writeAddress(Address, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeAddresses(Collection, DataOutputStream) - Static method in class org.jgroups.util.Util
-
Writes a Vector of Addresses.
- writeAuthToken(AuthToken, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeByteBuffer(byte[], DataOutputStream) - Static method in class org.jgroups.util.Util
- writeClassDescriptor(ObjectStreamClass) - Method in class org.jgroups.util.MagicObjectOutputStream
- writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.MethodCall
- writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.PullPushAdapter.PullHeader
-
Deprecated.
- writeExternal(ObjectOutput) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- writeExternal(ObjectOutput) - Method in class org.jgroups.MergeView
- writeExternal(ObjectOutput) - Method in class org.jgroups.Message
- writeExternal(ObjectOutput) - Method in class org.jgroups.mux.MuxHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.mux.ServiceInfo
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.AuthHeader
- 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.CAUSAL.CausalNewViewHeader
-
Manual serialization
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.FC.FcHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.FD_ALL.Header
- 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.FD.FdHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.FragHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.JMS.JMSAddress
-
Write the object to external output.
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.MERGE3.CoordAnnouncement
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.MERGEFAST.MergefastHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- 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.STABLE.StableHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.PingHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.SFC.Header
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.SMACK.SmackHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.TcpHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.TpHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.TunnelHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.UdpHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- writeExternal(ObjectOutput) - Method in class org.jgroups.stack.IpAddress
- writeExternal(ObjectOutput) - Method in class org.jgroups.util.Digest.Entry
- writeExternal(ObjectOutput) - Method in class org.jgroups.util.Digest
- writeExternal(ObjectOutput) - Method in class org.jgroups.util.Range
- writeExternal(ObjectOutput) - Method in class org.jgroups.View
- writeExternal(ObjectOutput) - Method in class org.jgroups.ViewId
- writeFully(ByteBuffer, WritableByteChannel) - Static method in class org.jgroups.util.Util
-
if we were to register for OP_WRITE and send the remaining data on readyOps for this channel we have to either block the caller thread or queue the message buffers that may arrive while waiting for OP_WRITE.
- writeGenericStreamable(Streamable, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeObject(Object, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeStreamable(Streamable, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeString(String, DataOutputStream) - Static method in class org.jgroups.util.Util
- writeTo(DataOutputStream) - Method in class org.jgroups.auth.FixedMembershipToken
-
Required to serialize the object to pass across the wire
- writeTo(DataOutputStream) - Method in class org.jgroups.auth.MD5Token
- writeTo(DataOutputStream) - Method in class org.jgroups.auth.SimpleToken
-
Required to serialize the object to pass across the wire
- writeTo(DataOutputStream) - Method in class org.jgroups.auth.X509Token
- writeTo(DataOutputStream) - Method in class org.jgroups.blocks.RequestCorrelator.Header
- writeTo(DataOutputStream) - Method in class org.jgroups.demos.DrawCommand
- writeTo(DataOutputStream) - Method in class org.jgroups.MergeView
- writeTo(DataOutputStream) - Method in class org.jgroups.Message
-
Streams all members (dest and src addresses, buffer and headers) to the output stream.
- writeTo(DataOutputStream) - Method in class org.jgroups.mux.MuxHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.mux.ServiceInfo
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.AuthHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.CAUSAL.CausalHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.CAUSAL.CausalNewViewHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.CAUSAL.MissingIndexesMessage
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.COMPRESS.CompressHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.DISCARD.DiscardHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.ENCRYPT.EncryptHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FC.FcHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD_ALL.Header
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD_SIMPLE.FdHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD_SOCK.FdHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FD.FdHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.FragHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.HTOTAL.HTotalHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.JMS.JMSAddress
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.FLUSH.FlushHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.GMS.GmsHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.JoinRsp
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.NakAckHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.STABLE.StableHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.STATE_TRANSFER.StateHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.pbcast.STREAMING_STATE_TRANSFER.StateHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.PingHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.PingRsp
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.SEQUENCER.SequencerHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.SFC.Header
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.SMACK.SmackHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.TcpHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.TpHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.TunnelHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.UdpHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.UNICAST.UnicastHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.VERIFY_SUSPECT.VerifyHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.protocols.VIEW_SYNC.ViewSyncHeader
- writeTo(DataOutputStream) - Method in class org.jgroups.stack.GossipData
- writeTo(DataOutputStream) - Method in class org.jgroups.stack.IpAddress
- writeTo(DataOutputStream) - Method in class org.jgroups.util.Digest.Entry
- writeTo(DataOutputStream) - Method in class org.jgroups.util.Digest
- writeTo(DataOutputStream) - Method in class org.jgroups.util.Range
- writeTo(DataOutputStream) - Method in interface org.jgroups.util.Streamable
-
Write the entire state of the current object (including superclasses) to outstream.
- writeTo(DataOutputStream) - Method in class org.jgroups.View
- writeTo(DataOutputStream) - Method in class org.jgroups.ViewId
- writeTo(OutputStream) - Method in class org.jgroups.util.ExposedByteArrayOutputStream
-
Writes the complete contents of this byte array output stream to the specified output stream argument, as if by calling the output stream's write method using
out.write(buf, 0, count)
. - wrongMethod(String) - Method in class org.jgroups.protocols.pbcast.GmsImpl
X
- x - Variable in class org.jgroups.demos.wb.Node
- X509Token - Class in org.jgroups.auth
-
This is an example of using a preshared token that is encrypted using an X509 certificate for authentication purposes.
- X509Token() - Constructor for class org.jgroups.auth.X509Token
- xloc - Variable in class org.jgroups.demos.wb.Node
- XMIT_REQ - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
- XMIT_RSP - Static variable in class org.jgroups.protocols.pbcast.NakAckHeader
- XmlConfigurator - Class in org.jgroups.conf
- XmlConfigurator(String) - Constructor for class org.jgroups.conf.XmlConfigurator
- XmlConfigurator(String, ProtocolData[]) - Constructor for class org.jgroups.conf.XmlConfigurator
Y
_
- _add(Object) - Method in class org.jgroups.blocks.DistributedQueue
- _add(String) - Method in class org.jgroups.blocks.DistributedTree
- _add(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
- _addAll(Collection) - Method in class org.jgroups.blocks.DistributedQueue
- _addAtHead(Object) - Method in class org.jgroups.blocks.DistributedQueue
- _clear() - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- _clear() - Method in class org.jgroups.blocks.ReplicatedHashMap
- _clear() - Method in interface org.jgroups.blocks.ReplicatedMap
- _close(boolean, boolean) - Method in class org.jgroups.JChannel
-
Disconnects and closes the channel.
- _private_reset() - Method in class org.jgroups.blocks.DistributedQueue
- _put(Object, Object) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- _put(String, String, Object) - Method in class org.jgroups.blocks.ReplicatedTree
- _put(String, HashMap) - Method in class org.jgroups.blocks.ReplicatedTree
- _put(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _put(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _putAll(Map) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- _putAll(Map) - Method in class org.jgroups.blocks.ReplicatedHashtable
-
Deprecated.
- _putAll(Map<? extends K, ? extends V>) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _putAll(Map<? extends K, ? extends V>) - Method in interface org.jgroups.blocks.ReplicatedMap
- _putIfAbsent(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _putIfAbsent(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _remove() - Method in class org.jgroups.blocks.DistributedQueue
- _remove(Object) - Method in class org.jgroups.blocks.DistributedHashtable
-
Deprecated.
- _remove(Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _remove(Object) - Method in interface org.jgroups.blocks.ReplicatedMap
- _remove(Object, Object) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _remove(Object, Object) - Method in interface org.jgroups.blocks.ReplicatedMap
- _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
- _replace(K, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _replace(K, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _replace(K, V, V) - Method in class org.jgroups.blocks.ReplicatedHashMap
- _replace(K, V, V) - Method in interface org.jgroups.blocks.ReplicatedMap
- _reset() - Method in class org.jgroups.blocks.DistributedQueue
- _reset(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
-
similar to set, but does not error if node does not exist, but rather does an add instead
- _set(String, Serializable) - Method in class org.jgroups.blocks.DistributedTree
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
IpAddress.compareTo(org.jgroups.Address)
instead