Uses of Package
org.jgroups.util
-
Packages that use org.jgroups.util Package Description org.jgroups Provides top-level public JGroups classes such as Channel, Message, etc.org.jgroups.auth org.jgroups.blocks Provides building blocks that are layered on top of channels.org.jgroups.blocks.cs This package contains all client-server related interfaces and classesorg.jgroups.blocks.executor org.jgroups.blocks.locking org.jgroups.conf Provides ways to configure a protocol stack.org.jgroups.demos Provides demonstrations of JGroups functionality.org.jgroups.fork org.jgroups.protocols Provides implementations of transport protocols which are responsible for sending and receiving messages to/from the network.org.jgroups.protocols.dns org.jgroups.protocols.pbcast org.jgroups.protocols.relay org.jgroups.protocols.rules org.jgroups.protocols.tom org.jgroups.stack Support for managing protocol stacks.org.jgroups.util Provides useful functionality which cannot be assigned to any particular other package. -
Classes in org.jgroups.util used by org.jgroups Class Description Buffer Buffer with an offset and length.ByteArrayDataInputStream ImplementsDataInput
over a byte[] buffer.MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).Promise Allows a thread to submit an asynchronous request and to wait for the result.SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.SocketFactory Factory to create various types of sockets.StateTransferResult Encapsulates the result of a state transfer.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.auth Class Description Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.blocks Class Description Buffer Buffer with an offset and length.MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).RpcStats Keeps track of stats for sync and async unicasts and multicastsRspList Contains responses from all members.SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.blocks.cs Class Description CondVar A condition variable with methods for (timed) waiting and signallingSocketFactory Factory to create various types of sockets.ThreadFactory TimeService Provides a coarse grained time service. -
Classes in org.jgroups.util used by org.jgroups.blocks.executor Class Description FutureListener A listener that is called back when a future is done.NotifyingFuture A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified when the future completes.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.blocks.locking Class Description Owner Represents an 'owner', which is an address and thread ID -
Classes in org.jgroups.util used by org.jgroups.conf Class Description StackType Triple 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.Tuple 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. -
Classes in org.jgroups.util used by org.jgroups.demos Class Description Owner Represents an 'owner', which is an address and thread IDStreamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.fork Class Description MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s). -
Classes in org.jgroups.util used by org.jgroups.protocols Class Description AckCollector Collects acks from a number of nodes, waits for all acks.AgeOutCache Cache which removes its elements after a certain timeAgeOutCache.Handler AsciiString Simple string implemented as a byte[] array.Average Maintains an approximation of an average of values.AverageMinMax Measures min and max in addition to averageBoundedHashMap Bounded linked hashmap; used by SEQUENCER (and probably soon) FORWARD_TO_COORDBoundedList A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.Buffer Buffer with an offset and length.ByteArrayDataInputStream ImplementsDataInput
over a byte[] buffer.ByteArrayDataOutputStream ImplementsDataOutput
over a byte[] buffer.Credit Maintains credits for a unicast destination.CreditMap Maintains credits for senders, when credits fall below 0, a sender blocks until new credits have been received.ExpiryCache Cache which maintains timestamps for keys, and methods to remove/replace expired keys.FixedSizeBitSet Class copied fromBitSet
.ForwardQueue Forwards messages in FIFO order to a destination.LongTuple A tuple with a long (primitive) first valueMessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).MessageCache A cache associating members and messagesOwner Represents an 'owner', which is an address and thread IDPromise Allows a thread to submit an asynchronous request and to wait for the result.ResponseCollector Similar to AckCollector, but collects responses from cluster members, not just acks.Responses Manages responses for the discovery protocol.RingBuffer Ring buffer of fixed capacity designed for multiple writers but only a single reader.Runner Runs a given function in a loop (in a separate thread) until it is stoppedSeqnoList A bitset of missing messages with a fixed size.SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.SocketFactory Factory to create various types of sockets.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serializationSuppressLog Log (usingSuppressCache
) which suppresses (certain) messages from the same member for a given timeTable A store for elements (typically messages) to be retransmitted or delivered.ThreadFactory TimeScheduler Timer-like interface which allows for execution of tasks.TimeScheduler.Task The interface that dynamic tasks (TimeScheduler.scheduleWithDynamicInterval(org.jgroups.util.TimeScheduler.Task)
) must implementTimeService Provides a coarse grained time service.Tuple 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.UUID Logical address which is unique over space and time. -
Classes in org.jgroups.util used by org.jgroups.protocols.dns Class Description Responses Manages responses for the discovery protocol. -
Classes in org.jgroups.util used by org.jgroups.protocols.pbcast Class Description AckCollector Collects acks from a number of nodes, waits for all acks.AsciiString Simple string implemented as a byte[] array.BlockingInputStream Bounded input stream.BoundedList A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.Buffer Buffer with an offset and length.Digest A message digest containing - for each member - the highest seqno delivered (hd) and the highest seqno received (hr).FixedSizeBitSet Class copied fromBitSet
.LongTuple A tuple with a long (primitive) first valueMergeId ID to uniquely identify a mergeMessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).MutableDigest A mutable version of Digest.ProcessingQueue A queue with many producers and consumers.ProcessingQueue.Handler Promise Allows a thread to submit an asynchronous request and to wait for the result.ResponseCollector Similar to AckCollector, but collects responses from cluster members, not just acks.Responses Manages responses for the discovery protocol.SeqnoList A bitset of missing messages with a fixed size.SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serializationSuppressLog Log (usingSuppressCache
) which suppresses (certain) messages from the same member for a given timeTable A store for elements (typically messages) to be retransmitted or delivered.TimeScheduler Timer-like interface which allows for execution of tasks.TimeScheduler.Task The interface that dynamic tasks (TimeScheduler.scheduleWithDynamicInterval(org.jgroups.util.TimeScheduler.Task)
) must implementTuple 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. -
Classes in org.jgroups.util used by org.jgroups.protocols.relay Class Description ExtendedUUID Subclass ofUUID
accommodating additional data such as a flag and a small hashmap.FlagsUUID Subclass ofUUID
accommodating additional data such as a flag.MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).ResponseCollector Similar to AckCollector, but collects responses from cluster members, not just acks.SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serializationSuppressLog Log (usingSuppressCache
) which suppresses (certain) messages from the same member for a given timeTimeScheduler Timer-like interface which allows for execution of tasks.UUID Logical address which is unique over space and time. -
Classes in org.jgroups.util used by org.jgroups.protocols.rules Class Description BoundedList A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).TimeScheduler Timer-like interface which allows for execution of tasks.Tuple 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. -
Classes in org.jgroups.util used by org.jgroups.protocols.tom Class Description SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serialization -
Classes in org.jgroups.util used by org.jgroups.stack Class Description MessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).Runner Runs a given function in a loop (in a separate thread) until it is stoppedSizeStreamable Interface implementing Streamable and returning the size of the marshalled object.SocketFactory Factory to create various types of sockets.StackType Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serializationThreadFactory TimeScheduler Timer-like interface which allows for execution of tasks. -
Classes in org.jgroups.util used by org.jgroups.util Class Description AckCollector Collects acks from a number of nodes, waits for all acks.AgeOutCache.Handler AsciiString Simple string implemented as a byte[] array.Average Maintains an approximation of an average of values.AverageMinMax Measures min and max in addition to averageBoundedHashMap Bounded linked hashmap; used by SEQUENCER (and probably soon) FORWARD_TO_COORDBuffer Buffer with an offset and length.ByteArrayDataInputStream ImplementsDataInput
over a byte[] buffer.ByteArrayDataOutputStream ImplementsDataOutput
over a byte[] buffer.Condition CondVar A condition variable with methods for (timed) waiting and signallingCredit Maintains credits for a unicast destination.CreditMap Maintains credits for senders, when credits fall below 0, a sender blocks until new credits have been received.DefaultThreadFactory Thread factory mainly responsible for naming of threads.Digest A message digest containing - for each member - the highest seqno delivered (hd) and the highest seqno received (hr).Digest.Entry Keeps track of one members plus its highest delivered and received seqnosExtendedUUID Subclass ofUUID
accommodating additional data such as a flag and a small hashmap.FixedSizeBitSet Class copied fromBitSet
.FlagsUUID Subclass ofUUID
accommodating additional data such as a flag.ForwardQueue.Flusher FutureListener A listener that is called back when a future is done.LongTuple A tuple with a long (primitive) first valueMaxOneThreadPerSender.Entry MaxOneThreadPerSender.MessageTable MergeId ID to uniquely identify a mergeMessageBatch Represents a message batch; multiple messages from the same sender to the same receiver(s).MessageBatch.Mode MessageCache A cache associating members and messagesMessageIterator MutableDigest A mutable version of Digest.MyReceiver Generic receiver for a JChannelNotifyingFuture A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified when the future completes.Owner Represents an 'owner', which is an address and thread IDPool.Element ProcessingQueue A queue with many producers and consumers.ProcessingQueue.Handler Profiler WrapsAverageMinMax
and provides an impl ofDiagnosticsHandler.ProbeHandler
.Promise Allows a thread to submit an asynchronous request and to wait for the result.Range RequestTable Table for storing requests associated with monotonically increasing sequence numbers (seqnos).RequestTable.Visitor ResponseCollector Similar to AckCollector, but collects responses from cluster members, not just acks.ResponseCollectorTask Task which is seeded with an initial membership.Responses Manages responses for the discovery protocol.RingBuffer Ring buffer of fixed capacity designed for multiple writers but only a single reader.RpcStats Keeps track of stats for sync and async unicasts and multicastsRpcStats.Result RpcStats.Type Rsp Class that represents a response from a communicationRspList Contains responses from all members.Runner Runs a given function in a loop (in a separate thread) until it is stoppedSeqnoList A bitset of missing messages with a fixed size.SizeBoundedQueue Blocking FIFO queue bounded by the max number of bytes of all elements.SizeBoundedQueue.El SizeStreamable Interface implementing Streamable and returning the size of the marshalled object.SocketFactory Factory to create various types of sockets.SslContextFactory SslContextFactory.StackType Streamable Implementations of Streamable can add their state directly to the output stream, enabling them to bypass costly serializationSubmitToThreadPool Default message processing policy.SubmitToThreadPool.BatchHandler SubmitToThreadPool.SingleMessageHandler SuppressCache Cache which keeps a timestamp and counter for every key.SuppressCache.Value SuppressLog.Level Table.Visitor ThreadFactory TimeScheduler Timer-like interface which allows for execution of tasks.TimeScheduler.Task The interface that dynamic tasks (TimeScheduler.scheduleWithDynamicInterval(org.jgroups.util.TimeScheduler.Task)
) must implementTimeScheduler3.Task TimeScheduler3.TaskType TimeService Provides a coarse grained time service.Tuple 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.Util.AddressScope UUID Logical address which is unique over space and time.