All Classes Interface Summary Class Summary Enum Summary Exception Summary Annotation Types Summary
Class |
Description |
AbstractConcurrentArrayQueue<E> |
Left over immutable queue fields.
|
AbstractConcurrentArrayQueueConsumer |
Values for the consumer that are expected to be padded.
|
AbstractConcurrentArrayQueuePadding1 |
Pad out a cacheline to the left of a producer fields to prevent false sharing.
|
AbstractConcurrentArrayQueuePadding2 |
Pad out a cacheline between the producer and consumer fields to prevent false sharing.
|
AbstractConcurrentArrayQueuePadding3 |
Pad out a cacheline between the producer and consumer fields to prevent false sharing.
|
AbstractConcurrentArrayQueueProducer |
Value for the producer that are expected to be padded.
|
AbstractMutableDirectBuffer |
|
AbstractSnowflakeIdGeneratorPaddingLhs |
|
AbstractSnowflakeIdGeneratorPaddingRhs |
|
AbstractSnowflakeIdGeneratorValue |
|
Agent |
An Agent is scheduled to do work on a thread on a duty cycle.
|
AgentInvoker |
Agent container which does not start a thread.
|
AgentRunner |
Agent runner containing an Agent which is run on a Thread .
|
AgentTerminationException |
Thrown to terminate the work/duty cycle of an Agent .
|
ArrayListUtil |
Utility functions for working with ArrayList s.
|
ArrayUtil |
Utility class for operating on arrays as if they were collections.
|
AsciiEncoding |
Helper for dealing with ASCII encoding of numbers.
|
AsciiNumberFormatException |
Thrown when parsing an ASCII string and finding characters that are not digits.
|
AsciiSequenceView |
View over a DirectBuffer which contains an ASCII string for a given range.
|
AtomicBuffer |
Abstraction over a range of buffer types that allows type to be accessed with memory ordering semantics.
|
AtomicCounter |
Atomic counter that is backed by an AtomicBuffer that can be read across threads and processes.
|
AtomicLongPosition |
Position that is backed by an AtomicLong which is useful for tests.
|
BackoffIdleStrategy |
Idling strategy for threads when they have no work to do.
|
BackoffIdleStrategyData |
|
BackoffIdleStrategyPrePad |
|
BiInt2NullableObjectMap<V> |
|
BiInt2ObjectMap<V> |
Map that takes two part int key and associates with an object.
|
BiInt2ObjectMap.EntryConsumer<V> |
Handler for a map entry
|
BiInt2ObjectMap.EntryFunction<V> |
Creates a new value based upon keys.
|
BiInt2ObjectMap.EntryRemap<V,V1> |
Creates a new value based upon keys.
|
BitUtil |
Miscellaneous useful functions for dealing with low level bits and bytes.
|
BroadcastBufferDescriptor |
Layout of the broadcast buffer.
|
BroadcastReceiver |
|
BroadcastTransmitter |
Transmit messages via an underlying broadcast buffer to zero or more BroadcastReceiver s.
|
BufferAlignmentAgent |
A Java agent that verifies that all memory accesses in DirectBuffer implementations are aligned.
|
BufferAlignmentAgent.AgentBuilderListener |
|
BufferAlignmentException |
|
BufferAlignmentInterceptor |
Interceptor to be applied when verifying buffer alignment accesses.
|
BufferAlignmentInterceptor.CharVerifier |
Verifier for char types.
|
BufferAlignmentInterceptor.DoubleVerifier |
Verifier for double types.
|
BufferAlignmentInterceptor.FloatVerifier |
Verifier for float types.
|
BufferAlignmentInterceptor.IntVerifier |
Verifier for int types.
|
BufferAlignmentInterceptor.LongVerifier |
Verifier for long types.
|
BufferAlignmentInterceptor.ShortVerifier |
Verifier for short types.
|
BufferUtil |
Common functions for buffer implementations.
|
BusySpinIdleStrategy |
Busy spin strategy targeted at lowest possible latency.
|
CachedEpochClock |
|
CachedEpochClockPadding |
Pad out a cacheline to the left of a value to prevent false sharing.
|
CachedEpochClockValue |
Value for the sequence that is expected to be padded.
|
CachedNanoClock |
|
CachedNanoClockPadding |
Pad out a cacheline to the left of a value to prevent false sharing.
|
CachedNanoClockValue |
Value for the sequence that is expected to be padded.
|
CharSequenceJavaFileObject |
An implementation of a SimpleJavaFileObject which stores the content in a CharSequence .
|
ClassFileManager<M extends javax.tools.JavaFileManager> |
ForwardingJavaFileManager for storing class files which can be looked up by name.
|
CloseHelper |
Utility functions to help with using AutoCloseable resources.
|
CollectionUtil |
Utility functions for collection objects.
|
CompilerUtil |
Utilities for compiling Java source files at runtime.
|
CompositeAgent |
Group several Agent s into one composite, so they can be scheduled as a unit.
|
CompositeDecoderFlyweight |
A flyweight for decoding an SBE Composite type.
|
CompositeEncoderFlyweight |
A flyweight for encoding an SBE Composite type.
|
ConcurrentCountersManager |
A thread safe extension of CountersManager which allows intra-process read and write access to the same
counters buffer.
|
ContinueBarrier |
Barrier to block the calling thread until a command is given on the command line.
|
ControllableIdleStrategy |
IdleStrategy which can be controlled by a counter so its mode of operation can be switched between
doing nothing (NOOP), busy spinning by calling ThreadHints.onSpinWait() , yielding by calling
Thread.yield() , or sleeping for the minimum period by calling LockSupport.parkNanos(long) when
work count is zero, so it idles.
|
ControlledMessageHandler |
Callback interface for processing of messages that are read from a buffer.
|
ControlledMessageHandler.Action |
|
CopyBroadcastReceiver |
Receiver that copies messages which have been broadcast to enable a simpler API for the client.
|
CountedErrorHandler |
|
CountersManager |
Manages the allocation and freeing of counters that are normally stored in a memory-mapped file.
|
CountersReader |
Reads the counters metadata and values buffers.
|
CountersReader.CounterConsumer |
Callback function for consuming basic counter details and value.
|
CountersReader.MetaData |
Callback function for consuming metadata records of counters.
|
DeadlineTimerWheel |
Timer Wheel for timers scheduled to expire on a deadline, (NOT thread safe).
|
DeadlineTimerWheel.TimerConsumer |
Consumer of timer entries as deadline to timerId.
|
DeadlineTimerWheel.TimerHandler |
Handler for processing expired timers.
|
DecoderFlyweight |
A flyweight for decoding an SBE type.
|
DelegatingErrorHandler |
ErrorHandler that can insert into a chain of responsibility, so it handles an error and then delegates
on to the next in the chain.
|
DirectBuffer |
Abstraction over a range of buffer types that allows fields to be read in native typed fashion.
|
DirectBufferDataInput |
A data input implementation that reads from a DirectBuffer.
|
DirectBufferInputStream |
|
DirectBufferOutputStream |
|
DistinctErrorLog |
Distinct record of error observations.
|
DistinctErrorLog.DistinctObservation |
|
DoNotSub |
A marker annotation to tell the primitive expander not to substitute
The line in question
|
DynamicCompositeAgent |
Group several Agent s into one composite, so they can be scheduled as a unit.
|
DynamicCompositeAgent.Status |
|
DynamicPackageOutputManager |
Extended version of the OutputManager allowing the specification of packages for selected outputs.
|
EncoderFlyweight |
A flyweight for encoding an SBE type.
|
EpochClock |
Retrieves the number of milliseconds since 1 Jan 1970 UTC.
|
EpochMicroClock |
Clock representing the time in microseconds since 1 Jan 1970 UTC.
|
EpochNanoClock |
Clock representing the time in nanoseconds since 1 Jan 1970 UTC.
|
ErrorConsumer |
|
ErrorHandler |
Callback interface for handling an error/exception that has occurred when processing an operation or event.
|
ErrorLogReader |
|
ExpandableArrayBuffer |
|
ExpandableDirectBufferOutputStream |
|
ExpandableDirectByteBuffer |
|
ExpandableRingBuffer |
Ring-buffer for storing messages which can expand to accommodate the messages written into it.
|
ExpandableRingBuffer.MessageConsumer |
|
Flyweight |
An SBE (Simple Binary Encoding) flyweight object.
|
Hashing |
Hashing functions for applying to integers.
|
HighResolutionClock |
Clock that provides the number of time units since the 1 Jan 1970 UTC.
|
HighResolutionTimer |
Control the use of high-resolution timers on Windows by a bit of hackery.
|
IdGenerator |
Generates unique identifiers that fit in a 64-bit word.
|
IdleStrategy |
Idle strategy for use by threads when they do not have work to do.
|
Int2IntCounterMap |
An open-addressing with linear probing hash map specialised for primitive key and counter pairs.
|
Int2IntHashMap |
An open-addressing with linear probing hash map specialised for primitive key and value pairs.
|
Int2NullableObjectHashMap<V> |
|
Int2ObjectCache<V> |
A cache implementation specialised for int keys using open addressing to probe a set of fixed size.
|
Int2ObjectHashMap<V> |
Map implementation specialised for int keys using open addressing and
linear probing for cache efficient access.
|
IntArrayList |
A List implementation that stores int values with the ability to not have them boxed.
|
IntArrayQueue |
Queue of ints which stores the elements without boxing.
|
IntHashSet |
Open-addressing with linear-probing expandable hash set.
|
IntIntConsumer |
Primitive specialisation of a BiConsumer for a pair of ints.
|
IntIntFunction |
Primitive specialisation of a BiFunction for a pair of ints.
|
IntIntPredicate |
Primitive specialisation of a BiPredicate for a pair of ints.
|
IntLruCache<E> |
A fixed capacity cache of int keyed values that evicts the least-recently-used element when it runs out of space.
|
IntObjConsumer<T> |
This is an (int, Object) primitive specialisation of a BiConsumer.
|
IntObjectToObjectFunction<T,R> |
This is an (int, Object) -> Object primitive specialisation of a BiFunction.
|
IntObjPredicate<T> |
This is an (int, Object) primitive specialisation of a BiPredicate.
|
IoUtil |
Collection of IO utilities for dealing with files, especially mapping and un-mapping.
|
JavaClassObject |
A SimpleJavaFileObject that is used to store the bytes for a java class in memory.
|
LangUtil |
Grouping of language level utilities to make programming in Java more convenient.
|
LoggingErrorHandler |
|
Long2LongCounterMap |
An open-addressing with linear probing hash map specialised for primitive key and counter pairs.
|
Long2LongHashMap |
An open-addressing with linear probing hash map specialised for primitive key and value pairs.
|
Long2NullableObjectHashMap<V> |
|
Long2ObjectCache<V> |
A cache implementation specialised for long keys using open addressing to probe a set of fixed size.
|
Long2ObjectHashMap<V> |
Map implementation specialised for long keys using open addressing and
linear probing for cache efficient access.
|
LongArrayList |
A List implementation that stores long values with the ability to not have them boxed.
|
LongArrayQueue |
Queue of longs which stores the elements without boxing.
|
LongHashSet |
Open-addressing with linear-probing expandable hash set.
|
LongLongConsumer |
Primitive specialisation of a BiConsumer for a pair of longs.
|
LongLongFunction |
Primitive specialisation of a BiFunction for a pair of longs.
|
LongLongPredicate |
Primitive specialisation of a BiPredicate for a pair of longs.
|
LongLruCache<E> |
A fixed capacity cache of long keyed values that evicts the least-recently-used element when it runs out of space.
|
LongObjConsumer<T> |
This is an (long, Object) primitive specialisation of a BiConsumer.
|
LongObjectToObjectFunction<T,R> |
This is an (long, Object) -> Object primitive specialisation of a BiFunction.
|
LongObjPredicate<T> |
This is an (long, Object) primitive specialisation of a BiPredicate.
|
ManagedResource |
Implementations of this interface can a resource that need to have external state tracked for deletion.
|
ManyToManyConcurrentArrayQueue<E> |
Many producer to many consumer concurrent queue that is array backed.
|
ManyToOneConcurrentArrayQueue<E> |
Many producer to one consumer concurrent queue that is array backed.
|
ManyToOneConcurrentLinkedQueue<E> |
Concurrent linked Queue that can be used from many producers and a single consumer.
|
ManyToOneConcurrentLinkedQueueHead<E> |
Value for the head that is expected to be padded.
|
ManyToOneConcurrentLinkedQueuePadding1 |
Pad out a cache line to the left of a tail to prevent false sharing.
|
ManyToOneConcurrentLinkedQueuePadding1.Node<E> |
|
ManyToOneConcurrentLinkedQueuePadding2<E> |
Pad out a cache line between the tail and the head to prevent false sharing.
|
ManyToOneConcurrentLinkedQueueTail<E> |
Value for the tail that is expected to be padded.
|
ManyToOneRingBuffer |
A ring-buffer that supports the exchange of messages from many producers to a single consumer.
|
MarkFile |
A MarkFile is used to mark the presence of a running component and to track liveness.
|
MemoryAccess |
Memory access operations which encapsulate the use of Unsafe.
|
MessageDecoderFlyweight |
A flyweight for decoding an SBE message from a buffer.
|
MessageEncoderFlyweight |
A flyweight for encoding SBE messages.
|
MessageFlyweight |
Common behaviour to SBE Message encoder and decoder flyweights.
|
MessageHandler |
Callback interface for processing of messages that are read from a buffer.
|
MutableBoolean |
Mutable boolean valid that is useful for capturing a value when using lambdas or collections.
|
MutableDirectBuffer |
Abstraction over a range of buffer types that allows fields to be written in native typed fashion.
|
MutableInteger |
Holder for an int value that is mutable.
|
MutableLong |
Holder for a long value that is mutable.
|
MutableReference<T> |
Mutable reference that is useful for capturing an object reference when using lambdas.
|
NanoClock |
Functional interface for return the current time as system-wide monotonic tick of 1 nanosecond precision.
|
NoOpIdleStrategy |
Low-latency idle strategy to be employed in loops that do significant work on each iteration such that any
work in the idle strategy would be wasteful.
|
NoOpLock |
A Lock implementation that is a no operation, i.e.
|
NullReference |
Sentinel value used in collections supporting null value references.
|
Object2IntCounterMap<K> |
An open-addressing with linear probing hash map specialised for object and primitive counter pairs.
|
Object2IntHashMap<K> |
Map implementation specialised for int values using open addressing and
linear probing for cache efficient access.
|
Object2LongCounterMap<K> |
An open-addressing with linear probing hash map specialised for object and primitive counter pairs.
|
Object2LongHashMap<K> |
Map implementation specialised for long values using open addressing and
linear probing for cache efficient access.
|
Object2NullableObjectHashMap<K,V> |
|
Object2ObjectHashMap<K,V> |
An open-addressing with linear probing hash map, same algorithm as Int2IntHashMap .
|
ObjectHashSet<T> |
Open-addressing with linear-probing expandable hash set.
|
ObjectIntToIntFunction<T> |
This is an (Object, int) -> int primitive specialisation of a BiFunction.
|
ObjectLongToLongFunction<T> |
This is an (Object, long) -> long primitive specialisation of a BiFunction.
|
ObjIntConsumer<T> |
This is an (Object, i) primitive specialisation of a BiConsumer.
|
ObjIntPredicate<T> |
This is an (Object, int) primitive specialisation of a BiPredicate.
|
ObjLongConsumer<T> |
This is an (Object, i) primitive specialisation of a BiConsumer.
|
ObjLongPredicate<T> |
This is an (Object, long) primitive specialisation of a BiPredicate.
|
OffsetEpochNanoClock |
An accurate, zero-gc, pure-java, EpochNanoClock that calculates an initial epoch nano time based on
System.currentTimeMillis() and then uses that offset to adjust the return value of
System.nanoTime() to the UNIX epoch.
|
OffsetEpochNanoClock.TimeFields |
|
OneToOneConcurrentArrayQueue<E> |
One producer to one consumer concurrent queue that is array backed.
|
OneToOneRingBuffer |
A ring-buffer that supports the exchange of messages from a single producer to a single consumer.
|
OutputManager |
Abstraction that manages the destination of generated output.
|
PackageOutputManager |
OutputManager for managing the creation of Java source files as the target of code generation.
|
Pipe<E> |
A container for items exchanged from producers to consumers.
|
Position |
Reports on how far through a buffer some component has progressed.
|
PrintBufferUtil |
Useful utils to hex dump the Agrona's buffers.
|
PrintBufferUtil.HexUtil |
|
PropertyAction |
Action to be taken for each property loaded into system properties.
|
QueuedPipe<E> |
Composed interface for concurrent Queue and Pipe .
|
ReadablePosition |
Indicates how far through an abstract task a component has progressed as a counter value.
|
RecordDescriptor |
Description of the structure for a record in the broadcast buffer.
|
RecordDescriptor |
Description of the record structure for message framing in the a RingBuffer .
|
References |
|
ResourceConsumer<T> |
Consumer of a resource which can throw IOException s.
|
RingBuffer |
Ring-buffer for the concurrent exchanging of binary encoded messages from producer(s) to consumer(s)
in a FIFO manner.
|
RingBufferDescriptor |
Layout description for the underlying buffer used by a RingBuffer .
|
SemanticVersion |
Store and extract a semantic version in a 4 byte integer.
|
ShutdownSignalBarrier |
One time barrier for blocking one or more threads until a SIGINT or SIGTERM signal is received from the operating
system or by programmatically calling ShutdownSignalBarrier.signal() .
|
SigInt |
Utility to allow the registration of a SIGINT handler that hides the unsupported Signal class.
|
SigIntBarrier |
One time barrier for blocking one or more threads until a SIGINT signal is received from the operating system
or by programmatically calling SigIntBarrier.signal() .
|
SleepingIdleStrategy |
When idle this strategy is to sleep for a specified period in nanoseconds.
|
SleepingMillisIdleStrategy |
When idle this strategy is to sleep for a specified period time in milliseconds.
|
SnowflakeIdGenerator |
Generate unique identifiers based on the Twitter
Snowflake algorithm.
|
SpecialisationGenerator |
Specialise classes written for primitive type int for other primitive types by substitution.
|
SpecialisationGenerator.Substitution |
Substitution to be performed on each code line.
|
StatusIndicator |
|
StatusIndicatorReader |
Reads the value of a counter to indicate current status and what abstraction should be taken.
|
Strings |
Utility functions for using Strings.
|
StringWriterOutputManager |
An OutputManager which can store source files as StringWriter buy source file name.
|
SystemEpochClock |
Implementation that calls System.currentTimeMillis() .
|
SystemEpochMicroClock |
|
SystemEpochNanoClock |
|
SystemNanoClock |
A NanoClock the delegates to System.nanoTime() .
|
SystemUtil |
Utilities for inspecting the system.
|
ThreadHints |
This class captures possible hints that may be used by some
runtimes to improve code performance.
|
TransportPoller |
Implements the common functionality for a transport poller.
|
UnmodifiableCollectionView<V,E> |
An unmodifiable view of a collection that maps each element in an underlying collection into a view.
|
UnsafeAccess |
Obtain access the Unsafe class for direct memory operations.
|
UnsafeBuffer |
Supports regular, byte ordered, and atomic (memory ordered) access to an underlying buffer.
|
UnsafeBufferPosition |
|
UnsafeBufferStatusIndicator |
|
Verify |
Various verification checks to be applied in code.
|
YieldingIdleStrategy |
IdleStrategy that will call Thread.yield() when the work count is zero.
|