Class Summary | |
---|---|
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. |
AUTOCONF | Senses the network configuration when it is initialized (in init()) and sends a CONFIG event up and down the stack. |
BlockEvent | Trivial object that represents a block event. |
BoundedList | A bounded subclass of List, oldest elements are removed once max capacity is exceeded |
BSH | Beanshell (www.beanshell.org) interpreter class. |
BSH.BshHeader | |
Buffer | Buffer with an offset and length. |
CAUSAL | Implements casual ordering layer using vector clocks. |
CAUSAL.CausalHeader | |
CannotConnectException | |
CannotCreateSchemaException | |
CannotPersistException | |
CannotRemoveException | |
CannotRetrieveException | |
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 takes care of creation of channel implementations. |
ChannelListener | Allows a listener to be notified when important channel events occur. |
ChannelNotConnectedException | Thrown if an operation is attemped on an unconnected channel. |
Chat | Simple chat demo |
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 |
ClassPathEntityResolver | |
ClientGmsImpl | Client part of GMS. |
ClientGmsImpl | Client part of GMS. |
Command | The Command patttern (see Gamma et al.). |
CondVar | Class that checks on a condition and - if condition doesn't match the expected result - waits until the result matches the expected result, or a timeout occurs. |
Configurator | The task if this class is to setup and configure the protocol stack. |
ConfiguratorFactory | The ConfigurationFactory is a factory that returns a protocol stack configurator. |
Configurator.ProtocolConfiguration | Parses and encapsulates the specification for 1 protocol of the protocol stack, e.g. |
ConnectionTable | Manages incoming and outgoing TCP connections. |
ConnectionTableNIO | Manages incoming and outgoing TCP connections. |
ConnectionTableNIO.SelectorWriteHandler | |
ConnectionTableNIO.WriteRequest | |
ConnectionTable.ConnectionListener | Used to be notified about connection establishment and teardown. |
ConnectionTable.Receiver | Used for message reception. |
ContextObjectInputStream | ObjectInputStream which sets a contact classloader for reading bytes into objects. |
CoordGmsImpl | |
CoordGmsImpl | Coordinator role of the Group MemberShip (GMS) protocol. |
COMPRESS | Compresses the payload of a message. |
COMPRESS.CompressHeader | |
DBPersistenceManager | Class will be utilized |
Debugger | The Debugger displays a graphical view of the protocol stack by showing all the protocols and the events in them. |
DEADLOCK | Tests the deadlock detection mechanism of RequestCorrelator. |
DELAY | Delays incoming/outgoing messages by a random number of milliseconds (range between 0 and n where n is determined by the user). |
Digest | Message digest, collecting the highest sequence number seen so far for each member, plus the messages that have higher seqnos than the ones given. |
Digest | 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 |
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 | Provides the abstraction of a java.util.Hashtable that is replicated at several locations. |
DistributedHashtableDemo | Uses the DistributedHashtable building block. |
DistributedHashtable.Notification | |
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. |
DistributedQueueDemo | Uses the DistributedQueue building block. |
DistributedQueue.Notification | |
DistributedTree | A tree-like structure that is replicated across several members. |
DistributedTreeDemo | Demo showing the DistributedTree class. |
DistributedTree.DistributedTreeListener | |
DistributedTree.ViewListener | |
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. |
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. |
DrawRepl | Replicates the whiteboard demo by intercepting central AWT event queue and mcasting events to all members. |
DUMMY | |
DUMMY_TP | Dummy transport, returns a fake local address and responds to CONNECT with CONNECT_OK. |
ENCRYPT | ENCRYPT layer. |
ENCRYPT1_4 | ENCRYPT1_4 layer. |
ENCRYPT1_4.EncryptHeader | |
ENCRYPT.EncryptHeader | |
Event | Used for inter-stack and intra-stack communication. |
ExitEvent | Trivial object that represents an exit event. |
ExposedBufferedInputStream | |
ExposedBufferedOutputStream | |
ExposedByteArrayInputStream | |
ExposedByteArrayOutputStream | Extends ByteArrayOutputStream, but exposes the internal buffer. |
ExposedDataOutputStream | |
EXAMPLE | Example of a protocol layer. |
FC | |
FC | Simple flow control protocol based on a credit system. |
FCMBean | |
FC.FcHeader | |
FD | |
FD | Failure detection based on simple heartbeat protocol. |
FD | Passive failure detection protocol. |
FDMBean | |
FD.FdHeader | |
FD_PID | Process-ID based FD protocol. |
FD_PID.FdHeader | |
FD_PROB |
Probabilistic failure detection protocol based on "A Gossip-Style Failure Detection Service"
by Renesse, Minsky and Hayden. Each member maintains a list of all other members: for each member P, 2 data are maintained, a heartbeat counter and the time of the last increment of the counter. |
FD_PROB.FdHeader | |
FD_SIMPLE | Simple failure detection protocol. |
FD_SIMPLE.FdHeader | |
FD_SOCK | |
FD_SOCK | Failure detection protocol based on sockets. |
FD_SOCKMBean | |
FD_SOCK.FdHeader | |
FilePersistenceManager | |
FlushRsp | |
FLOWCONTROL | Title: Flow control layer Description: This layer limits the number of sent messages without a receive of an own message to MAXSENTMSGS, just put this layer above GMS and you will get a more Copyright: Copyright (c) 2000 Company: Computer Network Laboratory |
FLOW_CONTROL | FLOW_CONTROL provides end-end congestion control and flow control. |
FLUSH | The task of the FLUSH protocol is to flush all pending messages out of the system. |
FragHeader | |
FRAG | |
FRAG | Fragmentation layer. |
FRAG2 | |
FRAG2 | Fragmentation layer. |
FRAG2MBean | |
FRAGMBean | |
GetNetworkInterfaces | Lists all network interfaces on a system |
GetStateEvent | Represents a GetState event. |
Global | Globals used by JGroups packages. |
GmsImpl | |
GmsImpl | |
GMS | |
GMS | Group membership protocol. |
GMS | Group membership protocol. |
GMSMBean | |
GMS.GmsHeader | |
GMS.Request | |
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) GossipServers. |
GossipData | Encapsulates data sent between GossipServer and GossipClient |
GossipRouter | Router for TCP based group comunication (using layer TCP instead of UDP). |
GossipServer | Maintains a cache of member addresses for each group. |
GraphPanel | |
GroupRequest | Sends a message to all members of the group and waits for all responses (or timeout). |
HDRS | Example of a protocol layer. |
Header | Abstract base class for all headers to be added to a Message. |
HTOTAL | Implementation of UTO-TCP as designed by EPFL. |
HTOTAL.HTotalHeader | |
Interval | Manages retransmission timeouts. |
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.
|
JChannelMBean | |
JmxConfigurator | |
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. |
JoinRsp | |
KeyStoreGenerator | Generates a keystore file that has a SecretKey in it. |
Link | Implements a physical link between 2 parties (point-to-point connection). |
LinkedListQueue | LinkedListQueue implementation based on java.util.Queue. |
Link.Receiver | |
List | Doubly-linked list. |
LockingException | |
LockManager |
LockManager represents generic lock manager that allows
obtaining and releasing locks on objects.
|
LockMultiLockedException | Thrown by the DistributedLockManager method if a lock is only locally released, because it is locked by multiple DistributedLockManagers. |
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. |
LogicalAddress | Logical address that spans the lifetime of a member. |
LogicalLink | Implements a logical point-to-point link between 2 entities consisting of a number of physical links. |
LogicalLink.AllLinksDown | |
LogicalLink.NoLinksAvailable | |
LogicalLink.Receiver | |
LOOPBACK | Makes copies of outgoing messages, swaps sender and receiver and sends the message back up the stack. |
LOSS | Example of a protocol layer. |
MagicNumberReader | Reads and maintains mapping between magic numbers and classes |
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 |
Membership | Class to keep track of Addresses. |
MembershipListener | Allows a listener to be notified when group membership changes. |
MembershipListenerAdapter | This class provides multiplexing possibilities for MembershipListener instances. |
MergeData | Encapsulates data sent with a MERGE_RSP (handleMergeResponse()) and INSTALL_MERGE_VIEW (handleMergeView()). |
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. |
MessageProtocol |
Based on Protocol, but incorporates RequestCorrelator and GroupRequest: the latter can
be used to mcast messages to all members and receive their reponses. A protocol based on this template can send messages to all members and receive all, a single, n, or none responses. |
MessageProtocolEXAMPLE | |
MethodCall | A method call is the JGroups representation of a remote method. |
MethodLookup | |
MERGE | Simple and stupid MERGE protocol (does not take into account state transfer). |
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 | |
MERGEFAST | The coordinator attaches a small header to each (or every nth) message. |
MERGEFAST.MergefastHeader | |
MERGE.MergeHeader | |
MPING | |
MPING | Uses its own IP multicast socket to send and receive discovery requests/responses. |
MPINGMBean | |
NAKACK | |
NAKACK | Negative AcKnowledgement layer (NAKs), paired with positive ACKs. |
NAKACK | Negative AcKnowledgement layer (NAKs). |
NAKACKMBean | |
NakAckHeader | |
NakAckHeader | |
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. |
NotificationBusDemo | Demoes the NotificationBus (without caching). |
NotificationBus.Consumer | |
NullReadWriteLock | |
NullSync | |
PARTITIONER | This layer can be put on top of the bottommost layer and is useful to simulate partitions. |
PARTITIONER.PartitionerHeader | The Partitioner header normally (type = NORMAL) contains just the partition number that is checked to discard messages received from other partitions. |
ParticipantGmsImpl | |
ParticipantGmsImpl | |
PbcastHeader | |
PBCAST | Implementation of probabilistic broadcast. |
PerfHeader | Inserted by PERF into each message. |
PersistenceFactory | |
PersistenceManager | |
PERF | Measures time taken by each protocol to process a message. |
PERF_TP | Measures the time for a message to travel from the channel to the transport |
PingHeader | |
PingRsp | |
PingSender | Sends num_ping_request GET_MBRS_REQ messages, distributed over timeout ms |
PingWaiter | Class that waits for n PingRsp'es, or m milliseconds to return the initial membership |
PIGGYBACK | Combines multiple messages into a single large one. |
PIGGYBACK.PiggybackHeader | |
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). |
PINGMBean | |
PlainConfigurator | A ProtocolStackConfigurator for the old style properties. |
PrintXMLTree | Title: JGroups Communications Description: Contact me at filip@filip.net Copyright: Copyright (c) 2002 Company: www.filip.net |
Profiler | Allows to time execution of 'named' statements, counts number of times called and total execution time. |
Profiler.Entry | |
Promise | 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 | Data holder for protocol |
ProtocolMBean | |
ProtocolObserver | Interface for the Debugger to receive notifications about a protocol layer. |
ProtocolParameter | Data holder for protocol data |
ProtocolSpecificView | Abstract class for all protocol-specific views, e.g. |
ProtocolStack | A ProtocolStack manages a number of protocols layered above each other. |
ProtocolStackConfigurator | |
ProtocolTester | Generic class to test one or more protocol layers directly. |
ProtocolView | Graphical view of a protocol instance |
Proxy | Redirects incoming TCP connections to other hosts/ports. |
PRINTMETHODS | |
PRINTOBJS | |
PullPushAdapter | Allows a client of Channel to be notified when messages have been received instead of having to actively poll the channel for new messages. |
PullPushAdapter.PullHeader | |
Queue | Elements are added at the tail and removed from the head. |
Queue2 | 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. |
QUEUE | Queuing layer. |
QUEUEView | Shows the internals of the QUEUE protocol. |
QUEUE.Observer | |
Range | |
Receiver | Defines the callbacks that are invoked when messages, views etc are received on a channel |
ReceiverAdapter | |
ReentrantLatch | Enables safely locking and unlocking a shared resource, without blocking the calling threads. |
ReplicatedHashtable | Provides the abstraction of a java.util.Hashtable that is replicated at several locations. |
ReplicatedHashtable.Notification | |
ReplicatedHashtable.StateTransferListener | |
ReplicatedTree | A tree-like structure that is replicated across several members. |
ReplicatedTreeDemo | Graphical view of a ReplicatedTree |
ReplicatedTree.Node | |
ReplicatedTree.ReplicatedTreeListener | |
ReplicationData | Class used for data exchange by ReplicationManager and ReplicationReceiver. |
ReplicationManager |
Class to propagate updates to a number of nodes in various ways:
Note: This class is experimental as of Oct 2002 |
ReplicationReceiver | Implementation of this interface needs to register with ReplicationManager and will receive updates to be applied to its locally replicated data. |
RequestCorrelator | Framework to send requests and receive matching responses (matching on request ID). |
RequestCorrelator.Header | The header for RequestCorrelator messages |
RequestHandler | |
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. |
RingNode | |
RingNodeFlowControl | |
RingToken | |
Router | Router for TCP based group comunication (using layer TCP instead of UDP). |
RouterStub | |
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 | |
RpcProtocol | Base class for group RMC peer protocols. |
RpcProtocolEXAMPLE | |
Rsp | class that represents a response from a communication |
RspCollector | |
RspList | Contains responses from all members. |
Scheduler | Implementation of a priority scheduler. |
SchedulerListener | Provides callback for use with a Scheduler. |
Scheduler.Task | |
SendDialog | |
SetStateEvent |
Encapsulates a state returned by Channel.receive() , as requested by
Channel.getState(s) previously. |
SHUFFLE | This layer shuffles upcoming messages, put it just above your bottom layer. |
Simulator | Tests one or more protocols independently. |
Simulator.Receiver | |
SIZE | Protocol which prints out the real size of a message. |
SMACK | Simple Multicast ACK protocol. |
SMACK.SmackHeader | |
Stack | LIFO stack, with better performance than java.util.Stack (based on List). |
StateTransferInfo | Contains parameters for state transfer. |
Streamable | Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization |
STABLE | |
STABLE | Computes the broadcast messages that are stable; i.e., that have been received by all members. |
STABLE | Computes the broadcast messages that are stable; i.e., have been received by all members. |
STABLEMBean | |
STABLE.StableHeader | |
STATE_TRANSFER | |
STATE_TRANSFER | State transfer layer. |
STATE_TRANSFER | New STATE_TRANSFER protocol based on PBCAST. |
STATE_TRANSFERMBean | |
STATE_TRANSFER.StateHeader | Wraps data for a state request/response. |
STATS | |
STATS | Provides various stats |
STATSMBean | |
SuspectedException | Thrown if a message is sent to a suspected member. |
SuspectEvent | Represents a suspect event. |
TcpHeader | |
TcpRingNode | |
TCP | |
TCP | TCP based protocol. |
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 | |
TCPMBean | |
TCPPING | |
TCPPING | The TCPPING protocol layer retrieves the initial membership in answer to the GMS's FIND_INITIAL_MBRS event. |
TCPPINGMBean | |
TCP_NIO | |
TCP_NIO | |
TCP_NIOMBean | |
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 The scheduler supports varying scheduling intervals by asking the task every time for its next preferred scheduling interval. |
TimeScheduler.CancellableTask | |
TimeScheduler.Task | The interface that submitted tasks must implement |
TokenLostException | |
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 | |
TOTAL | Implements the total ordering layer using a message sequencer The protocol guarantees that all bcast sent messages will be delivered in the same order to all members. |
TOTAL.Header | The header processed by the TOTAL layer and intended for TOTAL inter-stack communication |
TOTAL_OLD | ************************************************************************** class TOTAL_OLD extends Protocol TODO: (more comments) Sequencer based total ordering protocol layer - requires the following layers "below" it in the stack (or layers with equivalent functionality): GMS, FD, PING, UDP, ... |
TOTAL_OLD.TotalHeader | class TotalHeader The header that is prepended to every message passed down through the TOTAL_OLD layer and removed (and processed) from every message passed up through the TOTAL_OLD layer |
TOTAL_TOKEN |
Total order implementation based on The Totem Single-Ring Ordering and Membership Protocol. |
TOTAL_TOKEN.RingTokenHeader | |
TOTAL_TOKEN.TotalTokenHeader | |
TpHeader | Generic transport header, used by TP. |
TP | |
TP | Generic transport - specific implementations should extend this abstract class. |
TPMBean | |
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 |
TRACE | |
TunnelHeader | |
TUNNEL | Replacement for UDP. |
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. |
UdpHeader | |
UdpRingNode | |
UDP | |
UDP | IP multicast transport based on UDP. |
UDPMBean | |
UDP.UcastReceiver | |
UDP_NIO | Multicast transport. |
UDP_NIO.Connector | Manages a multicast and unicast socket on a given interface (NIC). |
UDP_NIO.ConnectorTable | Manages a bunch of Connectors |
UDP_NIO.MulticastReceiver | |
UDP_NIO.MyReceiver | |
UDP_NIO.Unmarshaller | |
UNICAST | |
UNICAST | Reliable unicast layer. |
UNICASTMBean | |
UNICAST.UnicastHeader | |
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. |
VectorTime | Vector timestamp used in CAUSAL order protocol stack |
Version | Holds version information for JGroups. |
VERIFY_SUSPECT | Catches SUSPECT events traveling up the stack. |
VERIFY_SUSPECT.VerifyHeader | |
View | A view is a local representation of the current membership of a group. |
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). |
VIEW_ENFORCER | Used by a client until it becomes a member: all up messages are discarded until a VIEW_CHANGE is encountered. |
VIEW_SYNC | |
VIEW_SYNC | Periodically sends the view to the group. |
VIEW_SYNCMBean | |
VIEW_SYNC.ViewSyncHeader | |
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. |
WANPING | Similar to TCPPING, except that the initial host list is specified as a list of logical pipe names. |
WANPIPE | Logical point-to-point link. |
WANPIPE.WanPipeHeader | |
WanPipeAddress | Logical address for a WAN pipe (logical link) |
Whiteboard | Shared whiteboard: members are represented by rectangles that contain their names and the OS/arch of the machine they are working on. |
Xid | Distributed transaction ID modeled after the JTA spec. |
XmlConfigurator | Uses XML to configure a protocol stack |
XmlValidator |