See: Description
Interface | Description |
---|---|
AgeOutCache.Handler<K> | |
BiConsumer<T,U> |
Required by RingBuffer.
|
Condition | |
Filter<T> | |
FutureListener<T> |
A listener that is called back when a future is done.
|
MessageBatch.Visitor<T> |
Used for iteration over the messages
|
NotifyingFuture<T> |
A sub-interface of a Future, that allows for listeners to be attached so that observers can be notified when the
future completes.
|
Pool.Creator<T> | |
ProcessingQueue.Handler<T> | |
RequestTable.Visitor<T> | |
ResourceManager.IpAddressRep | |
ResponseCollectorTask.Consumer<C> | |
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
serialization
|
Table.Visitor<T> | |
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 implement |
Class | Description |
---|---|
AckCollector |
Collects acks from a number of nodes, waits for all acks.
|
AdditionalDataUUID | Deprecated
Use
ExtendedUUID instead. |
AgeOutCache<K> |
Cache which removes its elements after a certain time
|
ArrayIterator<T> |
Iterator over an array of elements of type T.
|
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 average
|
Base64 |
Encodes and decodes to and from Base64 notation.
|
Base64.InputStream |
A
Base64.InputStream will read data from another
java.io.InputStream, given in the constructor,
and encode/decode to/from Base64 notation on the fly. |
Base64.OutputStream |
A
Base64.OutputStream will write data to another
java.io.OutputStream, given in the constructor,
and encode/decode to/from Base64 notation on the fly. |
Bits |
Class (similar to (and partly copied from) java.nio.Bits) containing helper methods to encode variables
(e.g.
|
BlockingInputStream |
Bounded input stream.
|
BoundedHashMap<K,V> |
Bounded linked hashmap; used by SEQUENCER (and probably soon) FORWARD_TO_COORD
|
BoundedList<T> |
A bounded subclass of LinkedList, oldest elements are removed once max capacity is exceeded.
|
Buffer |
Buffer with an offset and length.
|
ByteArrayDataInputStream |
Implements
DataInput over a byte[] buffer. |
ByteArrayDataOutputStream |
Implements
DataOutput over a byte[] buffer. |
ByteBufferInputStream |
Class using
ByteBuffer and implementing DataInput . |
ByteBufferOutputStream |
Class using
ByteBuffer and implementing DataOutput . |
ConcurrentLinkedBlockingQueue<T> |
Attempt at writing a fast transfer queue, which is bounded.
|
ConcurrentLinkedBlockingQueue2<T> |
Attempt at writing a fast transfer queue, which is bounded.
|
CondVar |
A condition variable with methods for (timed) waiting and signalling
|
CreditMap |
Maintains credits for senders, when credits fall below 0, a sender blocks until new credits have been received.
|
CustomRejectionPolicy |
// TODO: Document this
|
DefaultSocketFactory |
Default implementation, ignores service names
|
DefaultThreadFactory |
Thread factory mainly responsible for naming of threads.
|
DefaultTimeScheduler |
Implementation of
TimeScheduler by extending
ScheduledThreadPoolExecutor to keep tasks sorted. |
DefaultTimeScheduler.RobustRunnable |
Class which catches exceptions in run() - https://jira.jboss.org/jira/browse/JGRP-1062
|
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 seqnos
|
DirectExecutor | |
ExpiryCache<K> |
Cache which maintains timestamps for keys, and methods to remove/replace expired keys.
|
ExtendedUUID |
Subclass of
UUID accommodating additional data such as a flag and a small hashmap. |
FixedSizeBitSet |
Class copied from
BitSet . |
ForwardQueue |
Forwards messages in FIFO order to a destination.
|
GetNetworkInterfaces |
Lists all network interfaces on a system
|
HashedTimingWheel |
Implementation of
TimeScheduler . |
HashedTimingWheel.MyTask |
Simple task wrapper, always executed by at most 1 thread.
|
Headers |
Helper class providing functions to manipulate the
Message.headers array. |
ImmutableReference<T> |
Simple class that holds an immutable reference to another object (or to
null ). |
InputStreamAdapter |
Extends
InputStream from a ByteArrayDataInputStream . |
LazyThreadFactory |
Lazily names threads: whenever the address or cluster name is changed, all threads are renamed
|
MergeId |
ID to uniquely identify a merge
|
MessageBatch |
Represents a message batch; multiple messages from the same sender to the same receiver(s).
|
MockTimeScheduler |
Mock implementation of
TimeScheduler , used by unit tests |
MutableDigest |
A mutable version of Digest.
|
MyReceiver<T> |
Generic receiver for a JChannel
|
NullFuture<T> | |
ObjectInputStreamWithClassloader |
Override
ObjectInputStream.resolveClass(java.io.ObjectStreamClass) using the passed-in
classloader |
OneTimeAddressGenerator |
Implementation of
AddressGenerator which is configured with an initial value, and
after that random values are generated. |
OutputStreamAdapter |
Extends
OutputStream from a ByteArrayDataOutputStream . |
Owner |
Represents an 'owner', which is an address and thread ID
|
PaddedAtomicBoolean | |
PaddedAtomicInteger | |
PaddedAtomicLong |
Copied from http://mechanical-sympathy.blogspot.ch/2011/08/false-sharing-java-7.html.
|
PayloadUUID | Deprecated
Use
ExtendedUUID instead. |
Pool<T> |
Manages a fixed pool of resources (e.g.
|
ProcessingQueue<T> |
A queue with many producers and consumers.
|
ProgressCheckRejectionPolicy |
Detects
|
Promise<T> |
Allows a thread to submit an asynchronous request and to wait for the result.
|
PropertiesToAsciidoc |
Iterates over all concrete Protocol classes and creates tables with Protocol's properties.
|
Queue |
Elements are added at the tail and removed from the head.
|
Range | |
RequestTable<T> |
Table for storing requests associated with monotonically increasing sequence numbers (seqnos).
Used for example in
RequestCorrelator . |
ResourceManager |
Manages resources such as multicast addresses and multicast ports, and TCP
ports.
|
ResponseCollector<T> |
Similar to AckCollector, but collects responses from cluster members, not just acks.
|
ResponseCollectorTask<T> |
Task which is seeded with an initial membership.
|
Responses |
Manages responses for the discovery protocol.
|
Responses.PingDataIterator | |
RetransmitTable | Deprecated |
RingBuffer<T> |
Ring buffer of fixed capacity designed for multiple writers but only a single reader.
|
RingBufferSeqno<T> |
Ring buffer, implemented with a circular array.
|
RingBufferSeqnoLockless<T> |
Ring buffer, implemented with a circular array.
|
RpcStats |
Keeps track of stats for sync and async unicasts and multicasts
|
RpcStats.Result | |
Rsp<T> |
Class that represents a response from a communication
|
RspList<T> |
Contains responses from all members.
|
Runner |
Runs a given function in a loop (in a separate thread) until it is stopped
|
Seqno |
Keeps track of a single message to retransmit
|
SeqnoComparator | |
SeqnoList |
A bitset of missing messages with a fixed size.
|
SeqnoRange |
Keeps track of a range of messages to be retransmitted.
|
ShutdownRejectedExecutionHandler |
ShutdownRejectedExecutionHandler is a decorator RejectedExecutionHandler used
in all JGroups ThreadPoolExecutor(s).
|
SingletonAddress |
Address with a cluster name.
|
StateTransferResult |
Encapsulates the result of a state transfer.
|
SuppressCache<T> |
Cache which keeps a timestamp and counter for every key.
|
SuppressCache.Value | |
SuppressLog<T> |
Log (using
SuppressCache ) which suppresses (certain) messages from the same member for a given time |
Table<T> |
A store for elements (typically messages) to be retransmitted or delivered.
|
TimeScheduler2 | Deprecated
Use
TimeScheduler3 instead |
TimeScheduler2.MyTask |
Simple task wrapper, always executed by at most 1 thread.
|
TimeScheduler3 |
Implementation of
TimeScheduler . |
TimeScheduler3.Task | |
TimeService |
Provides a coarse grained time service.
|
TopologyUUID | Deprecated
Use
ExtendedUUID instead. |
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.
|
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.
|
Util |
Collection of various utility routines that can not be assigned to other classes.
|
UUID |
Logical address which is unique over space and time.
|
XMLSchemaGenerator |
Iterates over all concrete Protocol classes and creates XML schema used for validation of configuration files.
|
Enum | Description |
---|---|
MessageBatch.Mode | |
RpcStats.Type | |
StackType | |
SuppressLog.Level | |
TimeScheduler3.TaskType | |
Util.AddressScope |
Exception | Description |
---|---|
NoProgressException |
Exception raised when a threadpool rejects jobs but shows no progress.
|
QueueClosedException |
Copyright © 1998-2020 Red Hat. All Rights Reserved.