All Classes Interface Summary Class Summary Exception Summary Annotation Types Summary
Class |
Description |
AckCollector |
|
AckMcastReceiverWindow |
Keeps track of messages received from various senders.
|
AckMcastSenderWindow |
Keeps track of ACKs from receivers for each message.
|
AckMcastSenderWindow.RetransmitCommand |
Called by retransmitter thread whenever a message needs to be re-sent
to a destination.
|
AckReceiverWindow |
Counterpart of AckSenderWindow.
|
AckSenderWindow |
ACK-based sliding window for a sender.
|
AckSenderWindow.RetransmitCommand |
|
Address |
Abstract address.
|
AgeOutCache<K> |
Cache which removes its elements after a certain time
|
AgeOutCache.Handler<K> |
|
AUTH |
The AUTH protocol adds a layer of authentication to JGroups
|
AuthHeader |
AuthHeader is a holder object for the token that is passed from the joiner to the coordinator
|
AuthToken |
Abstract AuthToken class used by implementations of AUTH, e.g.
|
AUTOCONF |
Senses the network configuration when it is initialized (in init()) and sends a CONFIG event up
and down the stack.
|
BARRIER |
JMX wrapper for BARRIER protocol.
|
BARRIER |
All messages up the stack have to go through a barrier (read lock, RL).
|
BARRIERMBean |
JMX interface for BARRIER protocol.
|
BasicConnectionTable |
Shared class for TCP connection tables.
|
BasicConnectionTable.ConnectionListener |
Used to be notified about connection establishment and teardown.
|
BasicConnectionTable.Receiver |
Used for message reception.
|
BasicTCP |
Shared base class for tcpip protocols
|
BlockEvent |
Trivial object that represents a block event.
|
BoundedList<T> |
A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.
|
BSH |
|
BSH.BshHeader |
|
Buffer |
Buffer with an offset and length.
|
CannotConnectException |
|
CannotCreateSchemaException |
|
CannotPersistException |
|
CannotRemoveException |
|
CannotRetrieveException |
|
CAUSAL |
Implements casual ordering layer using vector clocks.
|
CAUSAL.CausalHeader |
|
CAUSAL.CausalNewViewHeader |
|
CAUSAL.MissingIndexesMessage |
|
CausalDemo |
Simple causal demo where each member bcast a consecutive letter from the
alphabet and picks the next member to transmit the next letter.
|
Channel |
A channel represents a group communication endpoint (like BSD datagram sockets).
|
ChannelClosedException |
Thrown if an operation is attemped on a closed channel.
|
ChannelException |
This class represents the super class for all exception types thrown by
JGroups.
|
ChannelFactory |
A channel factory that removes hardwiring of calls to create JGroups
channels.
|
ChannelListener |
Allows a listener to be notified when important channel events occur.
|
ChannelListenerAdapter |
|
ChannelNotConnectedException |
Thrown if an operation is attemped on an unconnected channel.
|
Chat |
|
ChatCore |
|
ClassConfigurator |
This class will be replaced with the class that read info
from the magic number configurator that reads info from the xml file.
|
ClassMap |
Maintains mapping between magic number and class
|
ClientGmsImpl |
Client part of GMS.
|
Command |
The Command patttern (see Gamma et al.).
|
COMPRESS |
Compresses the payload of a message.
|
COMPRESS.CompressHeader |
|
Configurator |
The task if this class is to setup and configure the protocol stack.
|
Configurator.ProtocolConfiguration |
Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g.
|
ConfiguratorFactory |
The ConfigurationFactory is a factory that returns a protocol stack configurator.
|
ConnectionTable |
Manages incoming and outgoing TCP connections.
|
ConnectionTableNIO |
Manages incoming and outgoing TCP connections.
|
ConnectionTableNIO.MyFuture |
|
ConnectionTableNIO.SelectorWriteHandler |
|
ConnectionTableNIO.WriteRequest |
|
ContextObjectInputStream |
ObjectInputStream which sets a contact classloader for reading bytes into objects.
|
CoordGmsImpl |
Coordinator role of the Group MemberShip (GMS) protocol.
|
DBPersistenceManager |
Class will be utilized
|
DefaultThreadFactory |
Thread factory mainly responsible for naming of threads.
|
DELAY |
Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n
where n is determined by the user).
|
DELAY_JOIN_REQ |
Discards 2 JOIN-REQs then accepts 1, then discards 2 more and so on
|
Digest |
A message digest, which is used by the PBCAST layer for gossiping (also used by NAKACK for
keeping track of current seqnos for all members).
|
Digest.Entry |
Class keeping track of the lowest and highest sequence numbers delivered, and the highest
sequence numbers received, per member.
|
DirectExecutor |
|
DISCARD |
Discards up or down messages based on a percentage; e.g., setting property 'up' to 0.1 causes 10%
of all up messages to be discarded.
|
DISCARD_PAYLOAD |
Discards a message whose sequence number (in the payload, as a Long) matches seqno 2 times,
before passing it up.
|
DISCARD.DiscardHeader |
|
Discovery |
|
Discovery |
The Discovery protocol layer retrieves the initial membership (used by the GMS when started
by sending event FIND_INITIAL_MBRS down the stack).
|
DiscoveryMBean |
|
DistributedHashtable |
Deprecated.
|
DistributedHashtable.Notification |
|
DistributedHashtableDemo |
Uses the DistributedHashtable building block.
|
DistributedLockManager |
Distributed lock manager is responsible for maintaining the lock information
consistent on all participating nodes.
|
DistributedLockManager.AcquireLockDecree |
This class represents the lock to be released.
|
DistributedLockManager.LockDecree |
This class represents the lock
|
DistributedLockManager.MultiLockDecree |
This class represents the lock that has to be marked as multilocked
|
DistributedLockManager.ReleaseLockDecree |
This class represents the lock to be released.
|
DistributedQueue |
Provides the abstraction of a java.util.LinkedList that is replicated at several
locations.
|
DistributedQueue.Notification |
|
DistributedQueueDemo |
Uses the DistributedQueue building block.
|
DistributedTree |
A tree-like structure that is replicated across several members.
|
DistributedTree.DistributedTreeListener |
|
DistributedTree.ViewListener |
|
DistributedTreeDemo |
Demo showing the DistributedTree class.
|
Draw |
Shared whiteboard, each new instance joins the same group.
|
Draw2Channels |
Same as Draw but using 2 channels: one for view changes (control channel) and the other one for drawing
(data channel).
|
DrawApplet |
|
DrawCommand |
Encapsulates information about a draw command.
|
DrawMultiplexer |
|
DrawRepl |
Replicates the whiteboard demo by intercepting central AWT event queue and mcasting events to
all members.
|
DUMMY_TP |
Dummy transport, returns a fake local address and responds to CONNECT.
|
DUPL |
Duplicates outgoing or incoming messages by copying them
|
ENCRYPT |
ENCRYPT layer.
|
ENCRYPT.EncryptHeader |
|
Event |
Used for inter-stack and intra-stack communication.
|
EXAMPLE |
Example of a protocol layer.
|
ExitEvent |
Trivial object that represents an exit event.
|
ExponentialInterval |
|
ExposedBufferedInputStream |
|
ExposedBufferedOutputStream |
|
ExposedByteArrayInputStream |
|
ExposedByteArrayOutputStream |
Extends ByteArrayOutputStream, but exposes the internal buffer.
|
ExposedDataOutputStream |
|
ExtendedMembershipListener |
|
ExtendedMessageListener |
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 |
Extends Receiver, plus the partial state transfer methods.
|
ExtendedReceiverAdapter |
|
FC |
|
FC |
Simple flow control protocol based on a credit system.
|
FC.FcHeader |
|
FCMBean |
|
FD |
|
FD |
Failure detection based on simple heartbeat protocol.
|
FD_ALL |
|
FD_ALL |
Failure detection based on simple heartbeat protocol.
|
FD_ALL.Header |
|
FD_ALLMBean |
|
FD_ICMP |
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_PING |
Protocol which uses an executable (e.g.
|
FD_PING.Pinger |
|
FD_SIMPLE |
Simple failure detection protocol.
|
FD_SIMPLE.FdHeader |
|
FD_SOCK |
|
FD_SOCK |
Failure detection protocol based on sockets.
|
FD_SOCK.FdHeader |
|
FD_SOCKMBean |
|
FD.FdHeader |
|
FDMBean |
|
FIFOMessageQueue<K,V> |
Blocking queue which can only process 1 message per service concurrently, establishing FIFO order per sender.
|
FilePersistenceManager |
|
FixedMembershipToken |
The FixedMemberShipToken object predefines a list of IP addresses and Ports that can join the group.
|
FLUSH |
|
FLUSH |
Flush, as it name implies, forces group members to flush their pending
messages while blocking them to send any additional messages.
|
FLUSH.FlushHeader |
|
FLUSHMBean |
|
FlushRsp |
|
FRAG |
|
FRAG |
Fragmentation layer.
|
FRAG2 |
|
FRAG2 |
Fragmentation layer.
|
FRAG2MBean |
|
FragHeader |
|
FRAGMBean |
|
GetNetworkInterfaces |
Lists all network interfaces on a system
|
GetStateEvent |
Represents a GetState event.
|
Global |
Globals used by JGroups packages.
|
GMS |
|
GMS |
Group membership protocol.
|
GMS.GmsHeader |
|
GmsImpl |
|
GmsImpl.Request |
|
GMSMBean |
|
Gossip |
Demos that tries to graphically illustrating the gossip (or pbcast) protocol: every sender periodically sends
a DRAW command to a random subset of the group members.
|
Gossip |
|
GossipClient |
Local stub for clients to access one (or more) GossipRouters.
|
GossipData |
Encapsulates data sent between GossipRouter and GossipClient
|
GossipRouter |
Router for TCP based group comunication (using layer TCP instead of UDP).
|
GraphPanel |
|
GroupRequest |
Sends a message to all members of the group and waits for all responses (or timeout).
|
GuardedBy |
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.
|
HDRS |
Example of a protocol layer.
|
Header |
Abstract base class for all headers to be added to a Message.
|
Headers |
Open addressing based implementation of a hashmap (not supporting the Map interface though) for message
headers.
|
HTOTAL |
Implementation of UTO-TCP as designed by EPFL.
|
HTOTAL.HTotalHeader |
|
Immutable |
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.
|
Interval |
Interface which returns a time series, one value at a time calling next()
|
IpAddress |
Network-dependent address (Internet).
|
JChannel |
JChannel is a pure Java implementation of Channel.
|
JChannel |
|
JChannelFactory |
JChannelFactory creates pure Java implementations of the Channel
interface.
|
JChannelFactory |
|
JChannelFactoryMBean |
|
JChannelMBean |
|
JMS |
Implementation of the transport protocol using the Java Message Service (JMS).
|
JMS.JMSAddress |
Simple Address representing the JMS node ID or JMS topic group.
|
JmxConfigurator |
|
JoinRsp |
Result of a JOIN request (sent by the GMS client).
|
KeyStoreGenerator |
Generates a keystore file that has a SecretKey in it.
|
LazyThreadFactory |
Lazily names threads: whenever the address or cluster name is changed, all threads are renamed
|
LockingException |
|
LockManager |
LockManager represents generic lock manager that allows
obtaining and releasing locks on objects.
|
LockMultiLockedException |
|
LockNotGrantedException |
This exception indicated that lock manager refused to give a lock on
some resource.
|
LockNotReleasedException |
This exception indicated that lock manager refused to release a lock on
some resource.
|
LOOPBACK |
Makes copies of outgoing messages, swaps sender and receiver and sends the message back up the stack.
|
MagicNumberReader |
|
MagicObjectInputStream |
Uses magic numbers for class descriptors
|
MagicObjectOutputStream |
Uses magic numbers for class descriptors
|
Marshaller |
Title: JGroups Communications
Description: Contact me at mail@filip.net
Copyright: Copyright (c) 2002
Company: www.filip.net
|
MD5Token |
This is an example of using a preshared token that is encrypted using an MD5/SHA hash for authentication purposes.
|
Membership |
Class to keep track of Addresses.
|
MembershipListener |
Allows a listener to be notified when group membership changes.
|
MembershipListenerAdapter |
|
MERGE2 |
|
MERGE2 |
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
|
MERGE2MBean |
|
MERGE3 |
Protocol to discover subgroups; e.g., existing due to a network partition (that healed).
|
MERGE3.CoordAnnouncement |
|
MergeData |
Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW
(handleMergeView()).
|
MERGEFAST |
The coordinator attaches a small header to each (or every nth) message.
|
MERGEFAST.MergefastHeader |
|
MergeView |
A view that is sent as a result of a merge.
|
Message |
A Message encapsulates data sent to members of a group.
|
MessageDialog |
|
MessageDispatcher |
Provides synchronous and asynchronous message sending with request-response
correlation; i.e., matching responses with the original request.
|
MessageListener |
Allows a listener to be notified when a message arrives.
|
MessageListenerAdapter |
This class provides multiplexing possibilities for MessageListener
instances.
|
MethodCall |
A method call is the JGroups representation of a remote method.
|
MethodLookup |
|
MPING |
|
MPING |
Uses its own IP multicast socket to send and receive discovery requests/responses.
|
MPINGMBean |
|
Multiplexer |
The multiplexer allows multiple channel interfaces to be associated with one
underlying instance of JChannel.
|
MutableDigest |
A mutable version of Digest (which is immutable
|
MuxChannel |
Multiplexer channel is a lightweight version of a regular channel where
multiple MuxChannel(s) share the same underlying regular channel.
|
MuxHeader |
Header used for multiplexing and de-multiplexing between service components on top of a Multiplexer (Channel)
|
NAKACK |
|
NAKACK |
Negative AcKnowledgement layer (NAKs).
|
NakAckHeader |
|
NAKACKMBean |
|
NakReceiverWindow |
Keeps track of messages according to their sequence numbers.
|
NakReceiverWindow.Listener |
|
NBMessageForm_NIO |
NBMessageForm - Message form for non-blocking message reads.
|
Node |
|
NotificationBus |
This class provides notification sending and handling capability.
|
NotificationBus.Consumer |
|
NotificationBusDemo |
Demoes the NotificationBus (without caching).
|
OutgoingBufferPool |
Maintains a pool of ExposedDataOutputStreams.
|
ParticipantGmsImpl |
|
PARTITION |
|
PARTITION |
Protocol to simulate a partition.
|
PARTITIONMBean |
|
PERF_TP |
Measures the time for a message to travel from the channel to the transport
|
PersistenceFactory |
|
PersistenceManager |
|
PING |
|
PING |
The PING protocol layer retrieves the initial membership (used by the GMS when started
by sending event FIND_INITIAL_MBRS down the stack).
|
PingHeader |
|
PINGMBean |
|
PingRsp |
|
PlainConfigurator |
A ProtocolStackConfigurator for the old style properties.
|
PortsManager |
Maintains a list of ports used on this host, associated with time stamps.
|
Profiler |
Allows to time execution of 'named' statements, counts number of times called and total
execution time.
|
Profiler.Entry |
|
Promise<T> |
Allows a thread to submit an asynchronous request and to wait for the result.
|
Protocol |
|
Protocol |
The Protocol class provides a set of common services for protocol layers.
|
ProtocolData |
|
ProtocolMBean |
|
ProtocolParameter |
Data holder for protocol data
|
ProtocolStack |
A ProtocolStack manages a number of protocols layered above each other.
|
ProtocolStackConfigurator |
|
ProtocolTester |
Generic class to test one or more protocol layers directly.
|
Proxy |
Redirects incoming TCP connections to other hosts/ports.
|
PullPushAdapter |
Deprecated.
|
PullPushAdapter.PullHeader |
|
Queue |
Elements are added at the tail and removed from the head.
|
QueueClosedException |
|
QuoteClient |
Used in conjunction with QuoteServer: a client is member of a group of quote servers which replicate
stock quotes among themselves.
|
QuoteServer |
Example of a replicated quote server.
|
Range |
|
Receiver |
Defines the callbacks that are invoked when messages, views etc are received on a channel
|
ReceiverAdapter |
|
ReplicatedHashMap<K extends java.io.Serializable,V extends java.io.Serializable> |
Subclass of a ConcurrentHashMap with replication of the contents across a cluster.
|
ReplicatedHashMap.Notification<K extends java.io.Serializable,V extends java.io.Serializable> |
|
ReplicatedHashMapDemo |
Uses the ReplicatedHashMap building block, which subclasses java.util.HashMap and overrides
the methods that modify the hashmap (e.g.
|
ReplicatedHashtable |
Deprecated.
|
ReplicatedHashtable.Notification |
|
ReplicatedHashtable.StateTransferListener |
|
ReplicatedMap<K extends java.io.Serializable,V extends java.io.Serializable> |
|
ReplicatedTree |
A tree-like structure that is replicated across several members.
|
ReplicatedTree.Node |
|
ReplicatedTree.ReplicatedTreeListener |
|
ReplicatedTreeDemo |
Graphical view of a ReplicatedTree
|
RequestCorrelator |
Framework to send requests and receive matching responses (matching on
request ID).
|
RequestCorrelator.Header |
The header for RequestCorrelator messages
|
RequestHandler |
|
ResponseCollector<T> |
Similar to AckCollector, but collects responses, not just acks.
|
Retransmitter |
Maintains a pool of sequence numbers of messages that need to be retransmitted.
|
Retransmitter.RetransmitCommand |
Retransmit command (see Gamma et al.) used to retrieve missing messages
|
ReusableThread |
Reusable thread class.
|
RouterStub |
Client stub that talks to a remote GossipRouter
|
RouterStub.ConnectionListener |
|
RpcDispatcher |
This class allows a programmer to invoke remote methods in all (or single)
group members and optionally wait for the return value(s).
|
RpcDispatcher.Marshaller |
|
RpcDispatcher.Marshaller2 |
|
RpcDispatcher.MarshallerAdapter |
Used to provide a Marshaller2 interface to a Marshaller.
|
Rsp |
class that represents a response from a communication
|
RspCollector |
|
RspFilter |
Interface defining when a group request is done.
|
RspList |
Contains responses from all members.
|
Scheduler |
Implementation of a priority scheduler.
|
Scheduler.Task |
|
SchedulerListener |
|
SendDialog |
|
SeqnoTable |
Maintains the highest received and highest delivered seqno per member
|
SEQUENCER |
|
SEQUENCER |
Implementation of total order protocol using a sequencer.
|
SEQUENCER.SequencerHeader |
|
SEQUENCERMBean |
|
ServiceInfo |
Class used for service state communication between Multiplexers
|
SetStateEvent |
Encapsulates a state returned by Channel.receive() , as requested by
Channel.getState(s) previously.
|
SFC |
|
SFC |
Simple flow control protocol.
|
SFC.Header |
|
SFCMBean |
|
SHARED_LOOPBACK |
Loopback transport shared by all channels within the same VM.
|
SHUFFLE |
This layer shuffles upcoming messages, put it just above your bottom layer.
|
ShutdownRejectedExecutionHandler |
ShutdownRejectedExecutionHandler is a decorator RejectedExecutionHandler used
in all JGroups ThreadPoolExecutor(s).
|
SimpleToken |
This is an example of using a preshared token for authentication purposes.
|
Simulator |
Tests one or more protocols independently.
|
Simulator.Receiver |
|
SIZE |
Protocol which prints out the real size of a message.
|
SizeBoundedQueue |
Queue as described in http://jira.jboss.com/jira/browse/JGRP-376.
|
SMACK |
Simple Multicast ACK protocol.
|
SMACK.SmackHeader |
|
STABLE |
|
STABLE |
Computes the broadcast messages that are stable; i.e., have been received by all members.
|
STABLE.StableHeader |
|
STABLEMBean |
|
STATE_TRANSFER |
|
STATE_TRANSFER |
New STATE_TRANSFER protocol based on PBCAST.
|
STATE_TRANSFER.StateHeader |
Wraps data for a state request/response.
|
STATE_TRANSFERMBean |
|
StateTransferException |
StateTransferException is thrown to indicate failure of
state transfer between cluster members.
|
StateTransferInfo |
Contains parameters for state transfer.
|
StaticInterval |
Manages retransmission timeouts.
|
STATS |
|
STATS |
Provides various stats
|
STATSMBean |
|
Streamable |
Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly
serialization
|
STREAMING_STATE_TRANSFER |
|
STREAMING_STATE_TRANSFER |
STREAMING_STATE_TRANSFER , as its name implies, allows a
streaming state transfer between two channel instances.
|
STREAMING_STATE_TRANSFER.StateHeader |
|
STREAMING_STATE_TRANSFERMBean |
|
StreamingGetStateEvent |
Represents an event returned by channel.receive() , as a result
of another channel instance requesting a state from this channel.
|
StreamingSetStateEvent |
Represents an event returned by channel.receive() , as requested by
channel.getState() previously.
|
SuspectedException |
Thrown if a message is sent to a suspected member.
|
SuspectEvent |
Represents a suspect event.
|
TCP |
|
TCP |
TCP based protocol.
|
TCP_NIO |
|
TCP_NIO |
Transport using NIO
|
TCP_NIOMBean |
|
TCPGOSSIP |
|
TCPGOSSIP |
The TCPGOSSIP protocol layer retrieves the initial membership (used by the GMS when started
by sending event FIND_INITIAL_MBRS down the stack).
|
TCPGOSSIPMBean |
|
TcpHeader |
|
TCPMBean |
|
TCPPING |
|
TCPPING |
The TCPPING protocol layer retrieves the initial membership in answer to the GMS's
FIND_INITIAL_MBRS event.
|
TCPPINGMBean |
|
ThreadDecorator |
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 |
|
ThreadManager |
An object that manages threads and provides callbacks to a
ThreadDecorator to allow it to alter their state.
|
ThreadManagerThreadPoolExecutor |
ThreadPoolExecutor subclass that implements @{link ThreadManager}.
|
ThreadPool |
Maintains a set of ReusableThreads.
|
TimedWriter |
Waits until the buffer has been written to the output stream, or until timeout msecs have elapsed,
whichever comes first.
|
TimeoutException |
Thrown if members fail to respond in time.
|
TimeScheduler |
Fixed-delay & fixed-rate single thread scheduler
|
TimeScheduler.Task |
The interface that submitted tasks must implement
|
Topology |
Demonstrates the membership service.
|
TotalOrder |
Originally written to be a demo for TOTAL order (code to be written by a student).
|
TotalTokenDemo |
Demonstration of TOTAL_TOKEN protocol stack implementing total
order.
|
TotalTokenDemo.TotalPayload |
|
TP |
|
TP |
Generic transport - specific implementations should extend this abstract class.
|
TP.ProbeHandler |
|
TP.ProtocolAdapter |
|
TpHeader |
Generic transport header, used by TP.
|
TPMBean |
|
TRACE |
|
Transport |
Defines a very small subset of the functionality of a channel,
essentially only the methods for sending and receiving messages.
|
TransportedVectorTime |
Lighweight representation of the VectorTime clock suitable for network transport
|
Triple<V1,V2,V3> |
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.
|
TUNNEL |
Replacement for UDP.
|
TunnelHeader |
|
Tuple<V1,V2> |
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.
|
TwoPhaseVotingAdapter |
This adapter introduces simple two-phase voting on a specified decree.
|
TwoPhaseVotingAdapter.TwoPhaseVoteWrapper |
|
TwoPhaseVotingAdapter.TwoPhaseWrapper |
Wrapper of the decree to voting decree.
|
TwoPhaseVotingListener |
Implementations of this interface can participate in two-phase voting process.
|
UDP |
|
UDP |
IP multicast transport based on UDP.
|
UdpHeader |
|
UDPMBean |
|
UnblockEvent |
Trivial object that represents a block event.
|
UNICAST |
|
UNICAST |
Reliable unicast layer.
|
UNICAST.UnicastHeader |
|
UNICASTMBean |
|
UnmodifiableVector |
Vector which cannot be modified
|
UpdateException |
|
UpHandler |
Provides a way of taking over a channel's tasks.
|
UserInfoDialog |
|
Util |
Collection of various utility routines that can not be assigned to other classes.
|
VERIFY_SUSPECT |
Catches SUSPECT events traveling up the stack.
|
VERIFY_SUSPECT.VerifyHeader |
|
Version |
We're using the scheme described at http://www.jboss.com/index.html?module=bb&op=viewtopic&t=77231
for major, minor and micro version numbers.
|
View |
A view is a local representation of the current membership of a group.
|
VIEW_SYNC |
|
VIEW_SYNC |
Periodically sends the view to the group.
|
VIEW_SYNC.ViewSyncHeader |
|
VIEW_SYNCMBean |
|
ViewDemo |
Demos the reception of views using a PullPushAdapter.
|
ViewId |
ViewIds are used for ordering views (each view has a ViewId and a list of members).
|
VoteException |
This exception is thrown when voting listener cannot vote on the
specified decree.
|
VoteResponseProcessor |
VoteResultProcessor
Applications that use the VotingAdapter and/or TwoPhaseVotingAdapter can pass an implementation of this down the vote
calls, to intercept processing of the VoteResults returned by other nodes.
|
VotingAdapter |
Voting adapter provides a voting functionality for an application.
|
VotingAdapter.FailureVoteResult |
Class that represents a result of local voting on the failed node.
|
VotingAdapter.VoteResult |
This class represents the result of local voting.
|
VotingListener |
Implemetations of this interface are able to participate in voting process.
|
Whiteboard |
Shared whiteboard: members are represented by rectangles that contain their names and the OS/arch of
the machine they are working on.
|
X509Token |
This is an example of using a preshared token that is encrypted using an X509 certificate for authentication purposes.
|
XmlConfigurator |
|