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.atomic org.jgroups.blocks.cs 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.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 ByteArray Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use !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.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 AverageMinMax Measures min and max in addition to averageMessageBatch 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.atomic 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.cs Class Description ByteArray Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use !SocketFactory Factory to create various types of sockets.ThreadFactory TimeService Provides a coarse grained time service. -
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 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.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.AckTable Manages ACKs from receivers inNAKACK4
AgeOutCache Cache which removes its elements after a certain timeAgeOutCache.Handler AsciiString Simple string implemented as a byte[] array.AsyncExecutor Used to execute asynchronous tasks, e.g.Average Maintains an approximation of an average of values.AverageMinMax Measures min and max in addition to averageBoundedHashMap Bounded linked hashmap; used by SEQUENCERBoundedList A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.Buffer Base class for message buffers.Buffer.Options ByteArray Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use !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.Digest A message digest containing - for each member - the highest seqno delivered (hd) and the highest seqno received (hr).ExpiryCache Cache which maintains timestamps for keys, and methods to remove/replace expired keys.FastArray SimpleFixedSizeBitSet Class copied fromBitSet
.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 IDProcessingQueue 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.RingBuffer Ring buffer of fixed capacity designed for multiple writers but only a single reader.RTT Measures round-trip times (RTT) between nodesRunner 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.SslContextFactory SslContextFactory.StackType 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 ThreadPool Thread pool based onThreadPoolExecutor
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.TLS 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.AverageMinMax Measures min and max in addition to averageBlockingInputStream Bounded input stream.BoundedList A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.ByteArray Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use !Digest A message digest containing - for each member - the highest seqno delivered (hd) and the highest seqno received (hr).FixedSizeBitSet Class copied fromBitSet
.MergeId 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 Delayer Collects actions by key and executes them - if a predicate is true - every N ms.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.stack Class Description ByteArrayDataOutputStream ImplementsDataOutput
over a byte[] buffer.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.TLS -
Classes in org.jgroups.util used by org.jgroups.util Class Description AckCollector Collects acks from a number of nodes, waits for all acks.AckTable Manages ACKs from receivers inNAKACK4
AgeOutCache.Handler AsciiString Simple string implemented as a byte[] array.AsyncExecutor Used to execute asynchronous tasks, e.g.AsyncExecutor.Task Average Maintains an approximation of an average of values.AverageMinMax Measures min and max in addition to averageBaseDataOutputStream ImplementsDataOutput
in a generic manner, so that subclasses can implement specific behavior.Buffer Base class for message buffers.Buffer.Options Buffer.Visitor ByteArray Byte array with an offset and length.
Note that the underlying byte array must not be changed as long as this instance is in use !ByteArrayDataInputStream ImplementsDataInput
over a byte[] buffer.ByteArrayDataOutputStream ImplementsDataOutput
over a byte[] buffer.CompletableFutures Utility class withCompletableFuture
andCompletionStage
useful methods.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.Delayer Collects actions by key and executes them - if a predicate is true - every N ms.Delayer.Entry 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 seqnosDynamicBuffer Copy ofTable
.ExtendedUUID Subclass ofUUID
accommodating additional data such as a flag and a small hashmap.FastArray SimpleFastArray.FastIterator FileWatcher FixedSizeBitSet Class copied fromBitSet
.FlagsUUID Subclass ofUUID
accommodating additional data such as a flag.IntHashMap A hashmap where keys have to be ints.LongTuple A tuple with a long (primitive) first valueMaxOneThreadPerSender MessageProcessingPolicy
which processes regular messages and message batches by assigning a max of 1 thread per message from the same sender.MaxOneThreadPerSender.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 messagesMetrics.Entry MutableDigest A mutable version of Digest.MyReceiver Generic receiver for a JChannelObjectWrapperPrimitive Wraps a primitive object (e.g.ObjectWrapperSerializable Wraps an object and its serialized form.Owner Represents an 'owner', which is an address and thread IDProcessingQueue A queue with many producers and consumers.ProcessingQueue.Handler Profiler Maintains averages for time values measured betweenProfiler.start()
andProfiler.stop()
.Promise Allows a thread to submit an asynchronous request and to wait for the result.Range Ref Keeps a reference to another objectRequestTable 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.RTTStat RpcStats.Type Rsp Class that represents a response from a communicationRspList Contains responses from all members.RTT Measures round-trip times (RTT) between nodesRunner 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.SslContextFactory.Context 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 Log (usingSuppressCache
) which suppresses (certain) messages from the same member for a given timeSuppressLog.Level Table A store for elements (typically messages) to be retransmitted or delivered.Table.Visitor ThreadFactory ThreadPool Thread pool based onThreadPoolExecutor
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.TLS TLSClientAuth 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.