Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 

A

AbstractConcurrentArrayQueue<E> - Class in org.agrona.concurrent
Left over immutable queue fields.
AbstractConcurrentArrayQueue(int) - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
accept(int, int, V) - Method in interface org.agrona.collections.BiInt2ObjectMap.EntryConsumer
A map entry
accept(int, int) - Method in interface org.agrona.collections.IntIntConsumer
Accept two values that comes as a tuple of ints.
accept(int, T) - Method in interface org.agrona.collections.IntObjConsumer
 
accept(long, long) - Method in interface org.agrona.collections.LongLongConsumer
Accept two values that comes as a tuple of longs.
accept(int, long, long, String) - Method in interface org.agrona.concurrent.errors.ErrorConsumer
Callback for accepting errors encountered in the log.
accept(long, int, String) - Method in interface org.agrona.concurrent.status.CountersReader.CounterConsumer
Accept the value for a counter.
accept(int, int, DirectBuffer, String) - Method in interface org.agrona.concurrent.status.CountersReader.MetaData
Accept a metadata record.
accept(long, long) - Method in interface org.agrona.DeadlineTimerWheel.TimerConsumer
 
accept(T) - Method in interface org.agrona.generation.ResourceConsumer
Accept a resource to be consumed.
add(T[], T) - Static method in class org.agrona.collections.ArrayUtil
Add an element to an array resulting in a new array.
add(Integer) - Method in class org.agrona.collections.IntArrayList
 
add(int, Integer) - Method in class org.agrona.collections.IntArrayList
 
add(Integer) - Method in class org.agrona.collections.IntHashSet
add(int) - Method in class org.agrona.collections.IntHashSet
Primitive specialised overload of {this#add(Integer)}
add(Long) - Method in class org.agrona.collections.LongArrayList
 
add(int, Long) - Method in class org.agrona.collections.LongArrayList
 
add(Long) - Method in class org.agrona.collections.LongHashSet
add(long) - Method in class org.agrona.collections.LongHashSet
Primitive specialised overload of {this#add(Long)}
add(T) - Method in class org.agrona.collections.ObjectHashSet
 
add(E) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
add(E) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
add(SelectionKey) - Method in class org.agrona.nio.NioSelectedKeySet
addAll(Collection<? extends Integer>) - Method in class org.agrona.collections.IntHashSet
addAll(IntHashSet) - Method in class org.agrona.collections.IntHashSet
Alias for IntHashSet.addAll(Collection) for the specialized case when adding another IntHashSet, avoids boxing and allocations
addAll(Collection<? extends Long>) - Method in class org.agrona.collections.LongHashSet
addAll(LongHashSet) - Method in class org.agrona.collections.LongHashSet
Alias for LongHashSet.addAll(Collection) for the specialized case when adding another LongHashSet, avoids boxing and allocations
addAll(Collection<? extends T>) - Method in class org.agrona.collections.ObjectHashSet
addAll(ObjectHashSet<T>) - Method in class org.agrona.collections.ObjectHashSet
Alias for ObjectHashSet.addAll(Collection) for the specialized case when adding another ObjectHashSet, avoids boxing and allocations
addAll(Collection<? extends E>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
addAll(Collection<? extends E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
addAndGet(int, int) - Method in class org.agrona.collections.Int2IntCounterMap
Add amount to the current value associated with this key.
addAndGet(long, long) - Method in class org.agrona.collections.Long2LongCounterMap
Add amount to the current value associated with this key.
addedCount() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
addedCount() - Method in interface org.agrona.concurrent.Pipe
The number of items added to this container since creation.
addInt(int) - Method in class org.agrona.collections.IntArrayList
Add an element without boxing.
addInt(int, int) - Method in class org.agrona.collections.IntArrayList
Add a element without boxing at a given index.
addIntOrdered(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Add a value to a given index with ordered store semantics.
addIntOrdered(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
addIntOrdered(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
addLong(long) - Method in class org.agrona.collections.LongArrayList
Add an element without boxing.
addLong(int, long) - Method in class org.agrona.collections.LongArrayList
Add a element without boxing at a given index.
addLongOrdered(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Add a value to a given index with ordered store semantics.
addLongOrdered(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
addLongOrdered(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
address(ByteBuffer) - Static method in class org.agrona.BufferUtil
Get the address at which the underlying buffer storage begins.
addressOffset() - Method in class org.agrona.concurrent.MappedResizeableBuffer
Address offset in memory at which the mapping begins.
addressOffset() - Method in class org.agrona.concurrent.UnsafeBuffer
 
addressOffset() - Method in interface org.agrona.DirectBuffer
Reads the underlying offset to to the memory address.
addressOffset() - Method in class org.agrona.ExpandableArrayBuffer
 
addressOffset() - Method in class org.agrona.ExpandableDirectByteBuffer
 
Agent - Interface in org.agrona.concurrent
An Agent is scheduled to do work on a thread on a duty cycle.
agent() - Method in class org.agrona.concurrent.AgentInvoker
The Agent which is contained.
agent() - Method in class org.agrona.concurrent.AgentRunner
The Agent which is contained
AgentInvoker - Class in org.agrona.concurrent
Agent container which does not start a thread.
AgentInvoker(ErrorHandler, AtomicCounter, Agent) - Constructor for class org.agrona.concurrent.AgentInvoker
Create an agent and initialise it.
AgentRunner - Class in org.agrona.concurrent
Agent runner containing an Agent which is run on a Thread.
AgentRunner(IdleStrategy, ErrorHandler, AtomicCounter, Agent) - Constructor for class org.agrona.concurrent.AgentRunner
Create an agent runner and initialise it.
AgentTerminationException - Exception in org.agrona.concurrent
Thrown to terminate the work/duty cycle of an Agent.
AgentTerminationException() - Constructor for exception org.agrona.concurrent.AgentTerminationException
 
AgentTerminationException(String) - Constructor for exception org.agrona.concurrent.AgentTerminationException
 
AgentTerminationException(String, Throwable) - Constructor for exception org.agrona.concurrent.AgentTerminationException
 
AgentTerminationException(Throwable) - Constructor for exception org.agrona.concurrent.AgentTerminationException
 
AgentTerminationException(String, Throwable, boolean, boolean) - Constructor for exception org.agrona.concurrent.AgentTerminationException
 
align(int, int) - Static method in class org.agrona.BitUtil
Align a value to the next multiple up of alignment.
ALIGNMENT - Static variable in class org.agrona.concurrent.ringbuffer.RecordDescriptor
Alignment as a multiple of bytes for each record.
ALIGNMENT - Static variable in class org.agrona.concurrent.UnsafeBuffer
Buffer alignment to ensure atomic word accesses.
allocate(String, int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
 
allocate(String, int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
 
allocate(int, DirectBuffer, int, int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
 
allocate(String) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a new counter with a given label with a default type of CountersManager.DEFAULT_TYPE_ID.
allocate(String, int) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a new counter with a given label and type.
allocate(String, int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a new counter with a given label.
allocate(int, DirectBuffer, int, int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a counter with the minimum of allocation by allowing the label an key to be provided and copied.
allocateDirectAligned(int, int) - Static method in class org.agrona.BufferUtil
Allocate a new direct ByteBuffer that is aligned on a given alignment boundary.
apply(int, int) - Method in interface org.agrona.collections.BiInt2ObjectMap.EntryFunction
A map entry
array(ByteBuffer) - Static method in class org.agrona.BufferUtil
Get the array from a read-only ByteBuffer similar to ByteBuffer.array().
ARRAY_BASE_OFFSET - Static variable in class org.agrona.BufferUtil
 
ARRAY_BYTE_BASE_OFFSET - Static variable in class org.agrona.UnsafeAccess
 
ArrayListUtil - Class in org.agrona.collections
Utility functions for working with ArrayLists.
ArrayListUtil() - Constructor for class org.agrona.collections.ArrayListUtil
 
arrayOffset(ByteBuffer) - Static method in class org.agrona.BufferUtil
Get the array offset from a read-only ByteBuffer similar to ByteBuffer.arrayOffset().
ArrayUtil - Class in org.agrona.collections
Utility class for operating on arrays as if they were collections.
ArrayUtil() - Constructor for class org.agrona.collections.ArrayUtil
 
AsciiEncoding - Class in org.agrona
Helper for dealing with ASCII encoding of numbers.
AsciiEncoding() - Constructor for class org.agrona.AsciiEncoding
 
AsciiSequenceView - Class in org.agrona
View over a DirectBuffer which contains an ASCII string for a given range.
AsciiSequenceView() - Constructor for class org.agrona.AsciiSequenceView
 
AsciiSequenceView(DirectBuffer, int, int) - Constructor for class org.agrona.AsciiSequenceView
Construct a view over a DirectBuffer from an offset for a given length..
AtomicBuffer - Interface in org.agrona.concurrent
Abstraction over a range of buffer types that allows type to be accessed with memory ordering semantics.
AtomicCounter - Class in org.agrona.concurrent.status
Atomic counter that is backed by an AtomicBuffer that can be read across threads and processes.
AtomicCounter(AtomicBuffer, int) - Constructor for class org.agrona.concurrent.status.AtomicCounter
Map a counter over a buffer.
AtomicCounter(AtomicBuffer, int, CountersManager) - Constructor for class org.agrona.concurrent.status.AtomicCounter
Map a counter over a buffer.
AtomicLongPosition - Class in org.agrona.concurrent.status
Position that is backed by an AtomicLong that is useful for tests.
AtomicLongPosition() - Constructor for class org.agrona.concurrent.status.AtomicLongPosition
 
available() - Method in class org.agrona.io.DirectBufferInputStream
 
await() - Method in class org.agrona.concurrent.ShutdownSignalBarrier
Await the reception of the shutdown signal.
await() - Method in class org.agrona.concurrent.SigIntBarrier
Await the reception of the SIGINT signal.
await() - Method in class org.agrona.console.ContinueBarrier
Await for input that matches the provided command.

B

BackoffIdleStrategy - Class in org.agrona.concurrent
Idling strategy for threads when they have no work to do.
BackoffIdleStrategy(long, long, long, long) - Constructor for class org.agrona.concurrent.BackoffIdleStrategy
Create a set of state tracking idle behavior
BiInt2ObjectMap<V> - Class in org.agrona.collections
Map that takes two part int key and associates with an object.
BiInt2ObjectMap() - Constructor for class org.agrona.collections.BiInt2ObjectMap
Construct an empty map
BiInt2ObjectMap(int, float) - Constructor for class org.agrona.collections.BiInt2ObjectMap
Construct a map that sets it initial capacity and load factor.
BiInt2ObjectMap.EntryConsumer<V> - Interface in org.agrona.collections
Handler for a map entry
BiInt2ObjectMap.EntryFunction<V> - Interface in org.agrona.collections
Creates new values based upon keys
BitUtil - Class in org.agrona
Miscellaneous useful functions for dealing with low level bits and bytes.
BitUtil() - Constructor for class org.agrona.BitUtil
 
BLOCK_SIZE - Static variable in class org.agrona.IoUtil
Size in bytes of a file page.
boundsCheck(byte[], long, int) - Static method in class org.agrona.BufferUtil
Bounds check the access range and throw a IndexOutOfBoundsException if exceeded.
boundsCheck(ByteBuffer, long, int) - Static method in class org.agrona.BufferUtil
Bounds check the access range and throw a IndexOutOfBoundsException if exceeded.
boundsCheck(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
boundsCheck(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
boundsCheck(int, int) - Method in interface org.agrona.DirectBuffer
Check that a given length of bytes is within the bounds from a given index.
boundsCheck(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
boundsCheck(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
BroadcastBufferDescriptor - Class in org.agrona.concurrent.broadcast
Layout of the broadcast buffer.
BroadcastBufferDescriptor() - Constructor for class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
 
BroadcastReceiver - Class in org.agrona.concurrent.broadcast
Receive messages broadcast from a BroadcastTransmitter via an underlying buffer.
BroadcastReceiver(AtomicBuffer) - Constructor for class org.agrona.concurrent.broadcast.BroadcastReceiver
Construct a new broadcast receiver based on an underlying AtomicBuffer.
broadcastReceiver() - Method in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Get the underlying BroadcastReceiver which this is wrapping and copying out of.
BroadcastTransmitter - Class in org.agrona.concurrent.broadcast
Transmit messages via an underlying broadcast buffer to zero or more BroadcastReceivers.
BroadcastTransmitter(AtomicBuffer) - Constructor for class org.agrona.concurrent.broadcast.BroadcastTransmitter
Construct a new broadcast transmitter based on an underlying AtomicBuffer.
buffer - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
buffer() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
The underlying buffer containing the broadcast message stream.
buffer() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Get the underlying buffer used by the RingBuffer for storage.
buffer() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Get the underlying buffer used by the RingBuffer for storage.
buffer() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Get the underlying buffer used by the RingBuffer for storage.
buffer() - Method in class org.agrona.io.DirectBufferInputStream
The underlying buffer being wrapped.
buffer() - Method in class org.agrona.io.DirectBufferOutputStream
The underlying buffer being wrapped.
buffer() - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
The underlying buffer being wrapped.
buffer() - Method in class org.agrona.MarkFile
 
buffer() - Method in interface org.agrona.sbe.EncoderFlyweight
Buffer in which the flyweight is encoded.
buffer() - Method in interface org.agrona.sbe.Flyweight
Buffer in which the flyweight is encoded.
BUFFER_ARRAY_BASE - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
BufferUtil - Class in org.agrona
Common functions for buffer implementations.
BufferUtil() - Constructor for class org.agrona.BufferUtil
 
BUSY_SPIN - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
BusySpinIdleStrategy - Class in org.agrona.concurrent
Busy spin strategy targeted at lowest possible latency.
BusySpinIdleStrategy() - Constructor for class org.agrona.concurrent.BusySpinIdleStrategy
 
BYTE_BUFFER_ADDRESS_FIELD_OFFSET - Static variable in class org.agrona.BufferUtil
 
BYTE_BUFFER_HB_FIELD_OFFSET - Static variable in class org.agrona.BufferUtil
 
BYTE_BUFFER_OFFSET_FIELD_OFFSET - Static variable in class org.agrona.BufferUtil
 
byteArray() - Method in class org.agrona.concurrent.UnsafeBuffer
 
byteArray() - Method in interface org.agrona.DirectBuffer
Get the underlying byte[] if one exists.
byteArray() - Method in class org.agrona.ExpandableArrayBuffer
 
byteArray() - Method in class org.agrona.ExpandableDirectByteBuffer
 
byteBuffer() - Method in class org.agrona.concurrent.UnsafeBuffer
 
byteBuffer() - Method in interface org.agrona.DirectBuffer
Get the underlying ByteBuffer if one exists.
byteBuffer() - Method in class org.agrona.ExpandableArrayBuffer
 
byteBuffer() - Method in class org.agrona.ExpandableDirectByteBuffer
 
byteValue() - Method in class org.agrona.collections.MutableInteger
 
byteValue() - Method in class org.agrona.collections.MutableLong
 

C

CACHE_LINE_LENGTH - Static variable in class org.agrona.BitUtil
Length of the data blocks used by the CPU cache sub-system in bytes.
CachedEpochClock - Class in org.agrona.concurrent
An EpochClock that caches a timestamp which can be updated with CachedEpochClock.update(long).
CachedEpochClock() - Constructor for class org.agrona.concurrent.CachedEpochClock
 
CachedNanoClock - Class in org.agrona.concurrent
A NanoClock that caches a timestamp which can be updated with CachedNanoClock.update(long).
CachedNanoClock() - Constructor for class org.agrona.concurrent.CachedNanoClock
 
cacheHits() - Method in class org.agrona.collections.Int2ObjectCache
The number of times a cache hit has occurred on the Int2ObjectCache.get(int) method.
cacheHits() - Method in class org.agrona.collections.Long2ObjectCache
The number of times a cache hit has occurred on the Long2ObjectCache.get(long) method.
cacheMisses() - Method in class org.agrona.collections.Int2ObjectCache
The number of times a cache miss has occurred on the Int2ObjectCache.get(int) method.
cacheMisses() - Method in class org.agrona.collections.Long2ObjectCache
The number of times a cache miss has occurred on the Long2ObjectCache.get(long) method.
cachePuts() - Method in class org.agrona.collections.Int2ObjectCache
The number of items that have been put in the cache.
cachePuts() - Method in class org.agrona.collections.Long2ObjectCache
The number of items that have been put in the cache.
calculateMaxMessageLength(int) - Static method in class org.agrona.concurrent.broadcast.RecordDescriptor
Calculate the maximum supported message length for a buffer of given capacity.
calculateShiftForScale(int) - Static method in class org.agrona.BitUtil
Calculate the shift value to scale a number based on how refs are compressed or not.
cancelTimer(long) - Method in class org.agrona.DeadlineTimerWheel
Cancel a previously scheduled timer.
capacity() - Method in class org.agrona.collections.BiInt2ObjectMap
Get the total capacity for the map to which the load factor with be a fraction of.
capacity() - Method in class org.agrona.collections.Int2IntCounterMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Int2IntHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Int2ObjectCache
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Int2ObjectHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.IntHashSet
Get the total capacity for the set to which the load factor with be a fraction of.
capacity() - Method in class org.agrona.collections.IntLruCache
 
capacity() - Method in class org.agrona.collections.Long2LongCounterMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Long2LongHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Long2ObjectCache
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Long2ObjectHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.LongHashSet
Get the total capacity for the set to which the load factor with be a fraction of.
capacity() - Method in class org.agrona.collections.LongLruCache
 
capacity() - Method in class org.agrona.collections.Object2IntHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Object2LongHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.Object2ObjectHashMap
Get the total capacity for the map to which the load factor will be a fraction of.
capacity() - Method in class org.agrona.collections.ObjectHashSet
Get the total capacity for the set to which the load factor with be a fraction of.
capacity - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
capacity() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
capacity() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Get the capacity of the underlying broadcast buffer.
capacity() - Method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
Get the capacity of the underlying broadcast buffer.
capacity() - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
capacity() - Method in interface org.agrona.concurrent.Pipe
The maximum capacity of this container to hold items.
capacity() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Get the capacity of the ring-buffer in bytes for exchange.
capacity() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Get the capacity of the ring-buffer in bytes for exchange.
capacity() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Get the capacity of the ring-buffer in bytes for exchange.
capacity() - Method in class org.agrona.concurrent.UnsafeBuffer
 
capacity() - Method in interface org.agrona.DirectBuffer
Get the capacity of the underlying buffer.
capacity() - Method in class org.agrona.ExpandableArrayBuffer
 
capacity() - Method in class org.agrona.ExpandableDirectByteBuffer
 
capacity() - Method in class org.agrona.nio.NioSelectedKeySet
Capacity of the current set
charAt(int) - Method in class org.agrona.AsciiSequenceView
CharSequenceJavaFileObject - Class in org.agrona.generation
 
CharSequenceJavaFileObject(String, CharSequence) - Constructor for class org.agrona.generation.CharSequenceJavaFileObject
 
checkCapacity(int) - Static method in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Check the the buffer capacity is the correct size.
checkCapacity(int) - Static method in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Check the the buffer capacity is the correct size (a power of 2 + RingBufferDescriptor.TRAILER_LENGTH).
checkedSubstitute(String) - Method in class org.agrona.generation.PrimitiveExpander.Substitution
 
checkFileExists(File, String) - Static method in class org.agrona.IoUtil
Check that a file exists and throw an exception if not.
checkLimit(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
checkLimit(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
checkLimit(int) - Method in interface org.agrona.DirectBuffer
Check that a given limit is not greater than the capacity of a buffer from a given offset.
checkLimit(int) - Method in class org.agrona.ExpandableArrayBuffer
 
checkLimit(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
checkTypeId(int) - Static method in class org.agrona.concurrent.broadcast.RecordDescriptor
Check that and message id is in the valid range.
checkTypeId(int) - Static method in class org.agrona.concurrent.ringbuffer.RecordDescriptor
Check that and message id is in the valid range.
claimRecord(int) - Method in class org.agrona.concurrent.RecordBuffer
Claim a record in the buffer.
ClassFileManager<M extends javax.tools.JavaFileManager> - Class in org.agrona.generation
 
ClassFileManager(M) - Constructor for class org.agrona.generation.ClassFileManager
 
clear() - Method in class org.agrona.collections.BiInt2ObjectMap
Clear out the map of all entries.
clear() - Method in class org.agrona.collections.Int2IntCounterMap
Clear out all entries.
clear() - Method in class org.agrona.collections.Int2IntHashMap
clear() - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
clear() - Method in class org.agrona.collections.Int2IntHashMap.KeySet
clear() - Method in class org.agrona.collections.Int2ObjectCache
Clear down all items in the cache.
clear() - Method in class org.agrona.collections.Int2ObjectCache.EntrySet
 
clear() - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
clear() - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
 
clear() - Method in class org.agrona.collections.Int2ObjectHashMap
clear() - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
 
clear() - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
clear() - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
 
clear() - Method in class org.agrona.collections.IntArrayList
 
clear() - Method in class org.agrona.collections.IntHashSet
clear() - Method in class org.agrona.collections.Long2LongCounterMap
Clear out all entries.
clear() - Method in class org.agrona.collections.Long2LongHashMap
clear() - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
clear() - Method in class org.agrona.collections.Long2LongHashMap.KeySet
clear() - Method in class org.agrona.collections.Long2ObjectCache
Clear down all items in the cache.
clear() - Method in class org.agrona.collections.Long2ObjectCache.EntrySet
 
clear() - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
clear() - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
 
clear() - Method in class org.agrona.collections.Long2ObjectHashMap
clear() - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
 
clear() - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
clear() - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
 
clear() - Method in class org.agrona.collections.LongArrayList
 
clear() - Method in class org.agrona.collections.LongHashSet
clear() - Method in class org.agrona.collections.Object2IntHashMap
clear() - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
 
clear() - Method in class org.agrona.collections.Object2IntHashMap.KeySet
 
clear() - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
 
clear() - Method in class org.agrona.collections.Object2LongHashMap
clear() - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
 
clear() - Method in class org.agrona.collections.Object2LongHashMap.KeySet
 
clear() - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
 
clear() - Method in class org.agrona.collections.Object2ObjectHashMap
clear() - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
clear() - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
clear() - Method in class org.agrona.collections.ObjectHashSet
clear() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
clear() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
clear() - Method in class org.agrona.generation.StringWriterOutputManager
 
close(AutoCloseable) - Static method in class org.agrona.CloseHelper
Close a AutoCloseable dealing with nulls and exceptions.
close() - Method in class org.agrona.collections.IntLruCache
 
close() - Method in class org.agrona.collections.LongLruCache
 
close() - Method in class org.agrona.concurrent.AgentInvoker
Mark the invoker as closed and call the Agent.onClose() logic for clean up.
close() - Method in class org.agrona.concurrent.AgentRunner
Stop the running Agent and cleanup.
close(int, Consumer<Thread>) - Method in class org.agrona.concurrent.AgentRunner
Stop the running Agent and cleanup.
close() - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
close() - Method in class org.agrona.concurrent.status.AtomicCounter
Free the counter slot for reuse.
close() - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
close() - Method in class org.agrona.concurrent.status.ReadablePosition
 
close() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
close() - Method in class org.agrona.io.DirectBufferInputStream
 
close() - Method in class org.agrona.io.DirectBufferOutputStream
Override to remove IOException.
close() - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
 
close() - Method in class org.agrona.MarkFile
 
close() - Method in class org.agrona.nio.TransportPoller
Close NioSelector down.
CloseHelper - Class in org.agrona
 
CloseHelper() - Constructor for class org.agrona.CloseHelper
 
CollectionUtil - Class in org.agrona.collections
Utility functions for collection objects.
CollectionUtil() - Constructor for class org.agrona.collections.CollectionUtil
 
commit(int) - Method in class org.agrona.concurrent.RecordBuffer
Commit a claimed record into the buffer.
compact() - Method in class org.agrona.collections.BiInt2ObjectMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Int2IntCounterMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Int2IntHashMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Int2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.IntHashSet
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Long2LongCounterMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Long2LongHashMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Long2ObjectHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.LongHashSet
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Object2IntHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Object2LongHashMap
Compact the Map backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.Object2ObjectHashMap
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compact() - Method in class org.agrona.collections.ObjectHashSet
Compact the backing arrays by rehashing with a capacity just larger than current size and giving consideration to the load factor.
compare(int, int) - Static method in class org.agrona.collections.MutableInteger
 
compare(long, long) - Static method in class org.agrona.collections.MutableLong
 
compareAndSet(long, long) - Method in class org.agrona.concurrent.status.AtomicCounter
Compare the current value to expected and if true then set to the update value atomically.
compareAndSetInt(int, int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomic compare and set of a int given an expected value.
compareAndSetInt(long, int, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
compareAndSetInt(int, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
compareAndSetLong(int, long, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomic compare and set of a long given an expected value.
compareAndSetLong(long, long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
compareAndSetLong(int, long, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
compareTo(MutableInteger) - Method in class org.agrona.collections.MutableInteger
 
compareTo(MutableLong) - Method in class org.agrona.collections.MutableLong
 
compareTo(DirectBuffer) - Method in class org.agrona.concurrent.UnsafeBuffer
 
compareTo(DirectBuffer) - Method in class org.agrona.ExpandableArrayBuffer
 
compareTo(DirectBuffer) - Method in class org.agrona.ExpandableDirectByteBuffer
 
compile(DiagnosticCollector<JavaFileObject>, JavaCompiler.CompilationTask) - Static method in class org.agrona.generation.CompilerUtil
 
compileAndLoad(String, DiagnosticCollector<JavaFileObject>, JavaFileManager, JavaCompiler.CompilationTask) - Static method in class org.agrona.generation.CompilerUtil
 
compileInMemory(String, Map<String, CharSequence>) - Static method in class org.agrona.generation.CompilerUtil
Compile a Map of source files in-memory resulting in a Class which is named.
compileOnDisk(String, Map<String, CharSequence>) - Static method in class org.agrona.generation.CompilerUtil
Compile a Map of source files on disk resulting in a Class which is named.
CompilerUtil - Class in org.agrona.generation
Utilities for compiling Java source files at runtime.
CompilerUtil() - Constructor for class org.agrona.generation.CompilerUtil
 
CompositeAgent - Class in org.agrona.concurrent
Group several Agents into one composite so they can be scheduled as a unit.
CompositeAgent(List<? extends Agent>) - Constructor for class org.agrona.concurrent.CompositeAgent
 
CompositeAgent(Agent...) - Constructor for class org.agrona.concurrent.CompositeAgent
 
CompositeDecoderFlyweight - Interface in org.agrona.sbe
A flyweight for decoding an SBE Composite type.
CompositeEncoderFlyweight - Interface in org.agrona.sbe
A flyweight for encoding an SBE Composite type.
compoundKey(int, int) - Static method in class org.agrona.collections.Hashing
Combined two 32 bit keys into a 64-bit compound.
computeIfAbsent(int, int, BiInt2ObjectMap.EntryFunction<? extends V>) - Method in class org.agrona.collections.BiInt2ObjectMap
If the specified key is not already associated with a value (or is mapped to null), attempts to compute its value using the given mapping function and enters it into this map unless null.
computeIfAbsent(int, IntUnaryOperator) - Method in class org.agrona.collections.Int2IntCounterMap
Try get a value for a key and if not present then apply mapping function.
computeIfAbsent(int, IntUnaryOperator) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.computeIfAbsent(Object, Function)
computeIfAbsent(int, IntFunction<? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
Get a value for a given key, or if it does ot exist then default the value via a IntFunction and put it in the cache.
computeIfAbsent(int, IntFunction<? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Get a value for a given key, or if it does not exist then default the value via a IntFunction and put it in the map.
computeIfAbsent(long, LongUnaryOperator) - Method in class org.agrona.collections.Long2LongCounterMap
Try get a value for a key and if not present then apply mapping function.
computeIfAbsent(long, LongUnaryOperator) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.computeIfAbsent(Object, Function)
computeIfAbsent(long, LongFunction<? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
Get a value for a given key, or if it does ot exist then default the value via a LongFunction and put it in the cache.
computeIfAbsent(long, LongFunction<? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Get a value for a given key, or if it does not exist then default the value via a LongFunction and put it in the map.
computeIfAbsent(K, ToIntFunction<? super K>) - Method in class org.agrona.collections.Object2IntHashMap
Get a value for a given key, or if it does not exist then default the value via a IntFunction and put it in the map.
computeIfAbsent(K, ToLongFunction<? super K>) - Method in class org.agrona.collections.Object2LongHashMap
Get a value for a given key, or if it does not exist then default the value via a LongFunction and put it in the map.
ConcurrentCountersManager - Class in org.agrona.concurrent.status
A thread safe extension of CountersManager which allows intra-process read and write access to the same counters buffer.
ConcurrentCountersManager(AtomicBuffer, AtomicBuffer) - Constructor for class org.agrona.concurrent.status.ConcurrentCountersManager
 
ConcurrentCountersManager(AtomicBuffer, AtomicBuffer, Charset) - Constructor for class org.agrona.concurrent.status.ConcurrentCountersManager
 
ConcurrentCountersManager(AtomicBuffer, AtomicBuffer, Charset, EpochClock, long) - Constructor for class org.agrona.concurrent.status.ConcurrentCountersManager
 
CONSUMER_HEARTBEAT_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the consumer heartbeat time value is stored.
consumerHeartbeatTime(long) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Set the time of the last consumer heartbeat.
consumerHeartbeatTime() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
The time of the last consumer heartbeat.
consumerHeartbeatTime(long) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Set the time of the last consumer heartbeat.
consumerHeartbeatTime() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
The time of the last consumer heartbeat.
consumerHeartbeatTime(long) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Set the time of the last consumer heartbeat.
consumerHeartbeatTime() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
The time of the last consumer heartbeat.
consumerPosition() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
The position in bytes from start up for the consumers.
consumerPosition() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
The position in bytes from start up for the consumers.
consumerPosition() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
The position in bytes from start up for the consumers.
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.KeySet
contains(int) - Method in class org.agrona.collections.Int2IntHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
contains(int) - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
contains(int) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
contains(Object) - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
contains(int) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.IntHashSet
contains(int) - Method in class org.agrona.collections.IntHashSet
contains(Object) - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Long2LongHashMap.KeySet
contains(long) - Method in class org.agrona.collections.Long2LongHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
contains(long) - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
contains(long) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
contains(Object) - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
contains(long) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.LongHashSet
contains(long) - Method in class org.agrona.collections.LongHashSet
contains(Object) - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Object2IntHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Object2LongHashMap.KeySet
 
contains(Object) - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
 
contains(Object) - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
contains(Object) - Method in class org.agrona.collections.Object2ObjectHashMap.ValueCollection
contains(Object) - Method in class org.agrona.collections.ObjectHashSet
contains(Object) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
contains(Object) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
contains(Object) - Method in class org.agrona.nio.NioSelectedKeySet
containsAll(IntHashSet) - Method in class org.agrona.collections.IntHashSet
IntHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(LongHashSet) - Method in class org.agrona.collections.LongHashSet
LongHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(Collection<?>) - Method in class org.agrona.collections.ObjectHashSet
containsAll(Collection<?>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
containsAll(Collection<?>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
containsInt(int) - Method in class org.agrona.collections.IntArrayList
Does the list contain this element value.
containsKey(int) - Method in class org.agrona.collections.Int2IntCounterMap
Does the map contain a value for a given key which is not Int2IntCounterMap.initialValue().
containsKey(int) - Method in class org.agrona.collections.Int2IntHashMap
Int primitive specialised containsKey.
containsKey(Object) - Method in class org.agrona.collections.Int2IntHashMap
containsKey(Object) - Method in class org.agrona.collections.Int2ObjectCache
containsKey(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
containsKey(int) - Method in class org.agrona.collections.Int2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(long) - Method in class org.agrona.collections.Long2LongCounterMap
Does the map contain a value for a given key which is not Long2LongCounterMap.initialValue().
containsKey(long) - Method in class org.agrona.collections.Long2LongHashMap
Long primitive specialised containsKey.
containsKey(Object) - Method in class org.agrona.collections.Long2LongHashMap
containsKey(Object) - Method in class org.agrona.collections.Long2ObjectCache
containsKey(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
containsKey(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
containsKey(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
containsKey(Object) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(Object) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
containsKey(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
containsLong(long) - Method in class org.agrona.collections.LongArrayList
Does the list contain this element value.
containsValue(int) - Method in class org.agrona.collections.Int2IntCounterMap
Iterate over the values to see if any match the provided value.
containsValue(int) - Method in class org.agrona.collections.Int2IntHashMap
Does the map contain the value.
containsValue(Object) - Method in class org.agrona.collections.Int2IntHashMap
containsValue(Object) - Method in class org.agrona.collections.Int2ObjectCache
containsValue(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
containsValue(long) - Method in class org.agrona.collections.Long2LongCounterMap
Iterate over the values to see if any match the provided value.
containsValue(long) - Method in class org.agrona.collections.Long2LongHashMap
Does the map contain the value.
containsValue(Object) - Method in class org.agrona.collections.Long2LongHashMap
containsValue(Object) - Method in class org.agrona.collections.Long2ObjectCache
containsValue(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
containsValue(Object) - Method in class org.agrona.collections.Object2IntHashMap
containsValue(int) - Method in class org.agrona.collections.Object2IntHashMap
 
containsValue(Object) - Method in class org.agrona.collections.Object2LongHashMap
containsValue(long) - Method in class org.agrona.collections.Object2LongHashMap
 
containsValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
Does the map contain the value.
ContinueBarrier - Class in org.agrona.console
Barrier to block the calling thread until a command is given on the command line.
ContinueBarrier(String) - Constructor for class org.agrona.console.ContinueBarrier
Create a barrier that will display the provided label and interact via System.out, System.in and Scanner.
ControllableIdleStrategy - Class in org.agrona.concurrent
 
ControllableIdleStrategy(StatusIndicatorReader) - Constructor for class org.agrona.concurrent.ControllableIdleStrategy
 
copy(IntHashSet) - Method in class org.agrona.collections.IntHashSet
 
copy(LongHashSet) - Method in class org.agrona.collections.LongHashSet
 
copy(ObjectHashSet<T>) - Method in class org.agrona.collections.ObjectHashSet
 
CopyBroadcastReceiver - Class in org.agrona.concurrent.broadcast
Receiver that copies messages which have been broadcast to enable a simpler API for the client.
CopyBroadcastReceiver(BroadcastReceiver, MutableDirectBuffer) - Constructor for class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Wrap a BroadcastReceiver to simplify the API for receiving messages.
CopyBroadcastReceiver(BroadcastReceiver, int) - Constructor for class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Wrap a BroadcastReceiver to simplify the API for receiving messages.
CopyBroadcastReceiver(BroadcastReceiver) - Constructor for class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Wrap a BroadcastReceiver to simplify the API for receiving messages.
CORRELATION_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the correlation counter value is stored.
CountedErrorHandler - Class in org.agrona.concurrent
An ErrorHandler which calls AtomicCounter.increment() before delegating the exception.
CountedErrorHandler(ErrorHandler, AtomicCounter) - Constructor for class org.agrona.concurrent.CountedErrorHandler
Construct a counted error handler with a delegate and counter.
COUNTER_LENGTH - Static variable in class org.agrona.concurrent.status.CountersReader
Length of the space allocated to a counter that includes padding to avoid false sharing.
counterOffset(int) - Static method in class org.agrona.concurrent.status.CountersReader
The offset in the counter buffer for a given counterId.
CountersManager - Class in org.agrona.concurrent.status
Manages the allocation and freeing of counters that are normally stored in a memory-mapped file.
CountersManager(AtomicBuffer, AtomicBuffer, Charset, EpochClock, long) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter buffer manager over two buffers.
CountersManager(AtomicBuffer, AtomicBuffer) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter buffer manager over two buffers.
CountersManager(AtomicBuffer, AtomicBuffer, Charset) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter buffer manager over two buffers.
CountersReader - Class in org.agrona.concurrent.status
Reads the counters metadata and values buffers.
CountersReader(AtomicBuffer, AtomicBuffer) - Constructor for class org.agrona.concurrent.status.CountersReader
Construct a reader over buffers containing the values and associated metadata.
CountersReader(AtomicBuffer, AtomicBuffer, Charset) - Constructor for class org.agrona.concurrent.status.CountersReader
Construct a reader over buffers containing the values and associated metadata.
CountersReader.CounterConsumer - Interface in org.agrona.concurrent.status
Callback function for consuming basic counter details and value.
CountersReader.MetaData - Interface in org.agrona.concurrent.status
Callback function for consuming metadata records of counters.
createEmptyFile(File, long) - Static method in class org.agrona.IoUtil
Create an empty file, fill with 0s, and return the FileChannel
createEmptyFile(File, long, boolean) - Static method in class org.agrona.IoUtil
Create an empty file, and optionally fill with 0s, and return the FileChannel
createOutput(String) - Method in interface org.agrona.generation.OutputManager
Create a new output destination based on a name.
createOutput(String) - Method in class org.agrona.generation.PackageOutputManager
Create a new output which will be a Java source file in the given package.
createOutput(String) - Method in class org.agrona.generation.StringWriterOutputManager
 
currentTickTime() - Method in class org.agrona.DeadlineTimerWheel
Time of current tick of the wheel in DeadlineTimerWheel.timeUnit()s.

D

deadline(long) - Method in class org.agrona.DeadlineTimerWheel
Return the deadline for the given timerId.
DeadlineTimerWheel - Class in org.agrona
Deadline scheduled Timer Wheel (NOT thread safe)
DeadlineTimerWheel(TimeUnit, long, int, int) - Constructor for class org.agrona.DeadlineTimerWheel
Construct timer wheel with given parameters.
DeadlineTimerWheel(TimeUnit, long, int, int, int) - Constructor for class org.agrona.DeadlineTimerWheel
Construct timer wheel with given parameters.
DeadlineTimerWheel.TimerConsumer - Interface in org.agrona
Consumer of timer entries as deadline to timerId.
DeadlineTimerWheel.TimerHandler - Interface in org.agrona
Handler for expired timers.
DecoderFlyweight - Interface in org.agrona.sbe
A flyweight for decoding an SBE type.
decrementAndGet(int) - Method in class org.agrona.collections.Int2IntCounterMap
Convenience version of Int2IntCounterMap.addAndGet(int, int) (key, -1).
decrementAndGet(long) - Method in class org.agrona.collections.Long2LongCounterMap
Convenience version of Long2LongCounterMap.addAndGet(long, long) (key, -1).
DEFAULT_INITIAL_CAPACITY - Static variable in class org.agrona.collections.IntHashSet
The initial capacity used when none is specified in the constructor.
DEFAULT_INITIAL_CAPACITY - Static variable in class org.agrona.collections.LongHashSet
The initial capacity used when none is specified in the constructor.
DEFAULT_INITIAL_CAPACITY - Static variable in class org.agrona.collections.ObjectHashSet
The initial capacity used when none is specified in the constructor.
DEFAULT_LOAD_FACTOR - Static variable in class org.agrona.collections.Hashing
Default load factor to be used in open addressing hashed data structures.
DEFAULT_NULL_VALUE - Static variable in class org.agrona.collections.IntArrayList
The default value that will be used in place of null for an element.
DEFAULT_NULL_VALUE - Static variable in class org.agrona.collections.LongArrayList
The default value that will be used in place of null for an element.
DEFAULT_TYPE_ID - Static variable in class org.agrona.concurrent.status.CountersManager
Default type id of a counter when none is supplied.
delete(File, boolean) - Static method in class org.agrona.IoUtil
Recursively delete a file or directory tree.
delete() - Method in interface org.agrona.ManagedResource
Delete any resources held.
deleteDirectory(boolean) - Method in class org.agrona.MarkFile
 
deleteIfExists(File) - Static method in class org.agrona.IoUtil
Delete file only if it already exists.
DID_NOT_CLAIM_RECORD - Static variable in class org.agrona.concurrent.RecordBuffer
 
difference(IntHashSet) - Method in class org.agrona.collections.IntHashSet
Fast Path set difference for comparison with another IntHashSet.
difference(LongHashSet) - Method in class org.agrona.collections.LongHashSet
Fast Path set difference for comparison with another LongHashSet.
difference(ObjectHashSet<T>) - Method in class org.agrona.collections.ObjectHashSet
Fast Path set difference for comparison with another ObjectHashSet.
DirectBuffer - Interface in org.agrona
Abstraction over a range of buffer types that allows fields to be read in native typed fashion.
DirectBufferInputStream - Class in org.agrona.io
An InputStream that wraps a DirectBuffer.
DirectBufferInputStream() - Constructor for class org.agrona.io.DirectBufferInputStream
 
DirectBufferInputStream(DirectBuffer) - Constructor for class org.agrona.io.DirectBufferInputStream
 
DirectBufferInputStream(DirectBuffer, int, int) - Constructor for class org.agrona.io.DirectBufferInputStream
 
DirectBufferOutputStream - Class in org.agrona.io
OutputStream that wraps an underlying MutableDirectBuffer.
DirectBufferOutputStream() - Constructor for class org.agrona.io.DirectBufferOutputStream
 
DirectBufferOutputStream(MutableDirectBuffer) - Constructor for class org.agrona.io.DirectBufferOutputStream
 
DirectBufferOutputStream(MutableDirectBuffer, int, int) - Constructor for class org.agrona.io.DirectBufferOutputStream
 
disable() - Static method in class org.agrona.concurrent.HighResolutionTimer
Attempt to disable the high resolution timer by closing the MidiDevice.
DISABLE_BOUNDS_CHECKS_PROP_NAME - Static variable in class org.agrona.concurrent.UnsafeBuffer
 
DistinctErrorLog - Class in org.agrona.concurrent.errors
Distinct record of error observations.
DistinctErrorLog(AtomicBuffer, EpochClock) - Constructor for class org.agrona.concurrent.errors.DistinctErrorLog
Create a new error log that will be written to a provided AtomicBuffer.
distinctErrorLog() - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
The wrapped log.
DistinctErrorLog.DistinctObservation - Class in org.agrona.concurrent.errors
 
DistinctObservation(Throwable, int) - Constructor for class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
DoNotSub - Annotation Type in org.agrona.generation
A marker annotation to tell the primitive expander not to substitute The line in question
doubleValue() - Method in class org.agrona.collections.MutableInteger
 
doubleValue() - Method in class org.agrona.collections.MutableLong
 
doWork() - Method in interface org.agrona.concurrent.Agent
An agent should implement this method to do its work.
doWork() - Method in class org.agrona.concurrent.CompositeAgent
 
doWork() - Method in class org.agrona.concurrent.DynamicCompositeAgent
 
drain(Consumer<E>) - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
drain(Consumer<E>, int) - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
drain(Consumer<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
drain(Consumer<E>, int) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
drain(Consumer<E>) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
drain(Consumer<E>, int) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
drain(Consumer<E>) - Method in interface org.agrona.concurrent.Pipe
Drain the number of elements present in a collection at the time the operation starts.
drain(Consumer<E>, int) - Method in interface org.agrona.concurrent.Pipe
Drain the minimum of a limit and the number of elements present in a collection at the time the operation starts.
drainTo(Collection<? super E>, int) - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
drainTo(Collection<? super E>, int) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
drainTo(Collection<? super E>, int) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
drainTo(Collection<? super E>, int) - Method in interface org.agrona.concurrent.Pipe
Drain available elements into the provided Collection up to a provided maximum limit of elements.
DynamicCompositeAgent - Class in org.agrona.concurrent
Group several Agents into one composite so they can be scheduled as a unit.
DynamicCompositeAgent(String) - Constructor for class org.agrona.concurrent.DynamicCompositeAgent
Construct a new composite that has no Agents to begin with.
DynamicCompositeAgent(String, List<? extends Agent>) - Constructor for class org.agrona.concurrent.DynamicCompositeAgent
 
DynamicCompositeAgent(String, Agent...) - Constructor for class org.agrona.concurrent.DynamicCompositeAgent
 
DynamicCompositeAgent.Status - Enum in org.agrona.concurrent
 

E

element() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
element() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
EMPTY_BOOLEAN_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_BYTE_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_CHAR_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_DOUBLE_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_FLOAT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_INT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_LONG_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_OBJECT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_SHORT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
EMPTY_STRING_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
 
enable() - Static method in class org.agrona.concurrent.HighResolutionTimer
Attempt to enable the MidiDevice which requires the high resolution timer.
ENCODED_ERROR_OFFSET - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Offset within a record at which the encoded exception field begins.
encodedLength() - Method in interface org.agrona.sbe.Flyweight
The length of the encoded type in bytes.
encodedMsgOffset(int) - Static method in class org.agrona.concurrent.ringbuffer.RecordDescriptor
The offset from the beginning of a record at which the encoded message begins.
EncoderFlyweight - Interface in org.agrona.sbe
A flyweight for encoding an SBE type.
endOffset(int) - Static method in class org.agrona.AsciiEncoding
Get the end offset of an ASCII encoded value.
endOffset(long) - Static method in class org.agrona.AsciiEncoding
Get the end offset of an ASCII encoded value.
ensureCapacity(T[], int) - Static method in class org.agrona.collections.ArrayUtil
Ensure an array has the required capacity.
ensureCapacity(int) - Method in class org.agrona.collections.IntArrayList
Ensure the backing array has a required capacity.
ensureCapacity(int) - Method in class org.agrona.collections.LongArrayList
Ensure the backing array has a required capacity.
ensureDirectoryExists(File, String) - Static method in class org.agrona.IoUtil
Create a directory if it doesn't already exist.
ensureDirectoryExists(File, String, boolean, boolean, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
 
ensureDirectoryIsRecreated(File, String, BiConsumer<String, String>) - Static method in class org.agrona.IoUtil
Create a directory, removing previous directory if it already exists.
EntryIterator() - Constructor for class org.agrona.collections.Int2IntHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Int2ObjectCache.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Long2LongHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Long2ObjectCache.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Object2IntHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Object2LongHashMap.EntryIterator
 
EntryIterator() - Constructor for class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
entrySet() - Method in class org.agrona.collections.Int2IntHashMap
EntrySet() - Constructor for class org.agrona.collections.Int2IntHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Int2ObjectCache
EntrySet() - Constructor for class org.agrona.collections.Int2ObjectCache.EntrySet
 
entrySet() - Method in class org.agrona.collections.Int2ObjectHashMap
EntrySet() - Constructor for class org.agrona.collections.Int2ObjectHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Long2LongHashMap
EntrySet() - Constructor for class org.agrona.collections.Long2LongHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Long2ObjectCache
EntrySet() - Constructor for class org.agrona.collections.Long2ObjectCache.EntrySet
 
entrySet() - Method in class org.agrona.collections.Long2ObjectHashMap
EntrySet() - Constructor for class org.agrona.collections.Long2ObjectHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Object2IntHashMap
EntrySet() - Constructor for class org.agrona.collections.Object2IntHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Object2LongHashMap
EntrySet() - Constructor for class org.agrona.collections.Object2LongHashMap.EntrySet
 
entrySet() - Method in class org.agrona.collections.Object2ObjectHashMap
EntrySet() - Constructor for class org.agrona.collections.Object2ObjectHashMap.EntrySet
 
EpochClock - Interface in org.agrona.concurrent
Retrieves the number of milliseconds since 1 Jan 1970 UTC.
EpochMicroClock - Interface in org.agrona.concurrent
 
epochMicros() - Static method in class org.agrona.concurrent.HighResolutionClock
The number of microseconds since the 1 Jan 1970 UTC.
epochMillis() - Static method in class org.agrona.concurrent.HighResolutionClock
The number of milliseconds since the 1 Jan 1970 UTC.
EpochNanoClock - Interface in org.agrona.concurrent
 
epochNanos() - Static method in class org.agrona.concurrent.HighResolutionClock
The number of nanoseconds since the 1 Jan 1970 UTC.
equals(Object) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
equals(Object) - Method in class org.agrona.collections.Int2IntHashMap
equals(Object) - Method in class org.agrona.collections.Int2ObjectCache
equals(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
equals(IntArrayList) - Method in class org.agrona.collections.IntArrayList
 
equals(Object) - Method in class org.agrona.collections.IntArrayList
equals(Object) - Method in class org.agrona.collections.IntHashSet
equals(Object) - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
equals(Object) - Method in class org.agrona.collections.Long2LongHashMap
equals(Object) - Method in class org.agrona.collections.Long2ObjectCache
equals(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
equals(LongArrayList) - Method in class org.agrona.collections.LongArrayList
 
equals(Object) - Method in class org.agrona.collections.LongArrayList
equals(Object) - Method in class org.agrona.collections.LongHashSet
equals(Object) - Method in class org.agrona.collections.MutableBoolean
 
equals(Object) - Method in class org.agrona.collections.MutableInteger
 
equals(Object) - Method in class org.agrona.collections.MutableLong
 
equals(Object) - Method in class org.agrona.collections.MutableReference
 
equals(Object) - Method in class org.agrona.collections.NullReference
 
equals(Object) - Method in class org.agrona.collections.Object2IntHashMap
equals(Object) - Method in class org.agrona.collections.Object2LongHashMap
equals(Object) - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
equals(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
equals(Object) - Method in class org.agrona.collections.ObjectHashSet
equals(Object) - Method in class org.agrona.concurrent.UnsafeBuffer
 
equals(Object) - Method in class org.agrona.ExpandableArrayBuffer
 
equals(Object) - Method in class org.agrona.ExpandableDirectByteBuffer
 
ErrorConsumer - Interface in org.agrona.concurrent.errors
Callback handler for consuming errors encountered in a DistinctErrorLog.
ErrorHandler - Interface in org.agrona
Callback interface for handling an error/exception that has occurred when processing an operation or event.
ErrorLogReader - Class in org.agrona.concurrent.errors
Reader for the log created by a DistinctErrorLog.
ErrorLogReader() - Constructor for class org.agrona.concurrent.errors.ErrorLogReader
 
errorOverflow() - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
The wrapped PrintStream for error log overflow when the log is full.
evenHash(int, int) - Static method in class org.agrona.collections.Hashing
Generate an even hash for a int value.
evenHash(long, int) - Static method in class org.agrona.collections.Hashing
Generate an even hash for a long value.
ExpandableArrayBuffer - Class in org.agrona
Expandable MutableDirectBuffer that is backed by an array.
ExpandableArrayBuffer() - Constructor for class org.agrona.ExpandableArrayBuffer
ExpandableArrayBuffer(int) - Constructor for class org.agrona.ExpandableArrayBuffer
Create an ExpandableArrayBuffer with a provided initial length.
ExpandableDirectBufferOutputStream - Class in org.agrona.io
OutputStream that wraps an underlying expandable version of a MutableDirectBuffer.
ExpandableDirectBufferOutputStream() - Constructor for class org.agrona.io.ExpandableDirectBufferOutputStream
 
ExpandableDirectBufferOutputStream(MutableDirectBuffer) - Constructor for class org.agrona.io.ExpandableDirectBufferOutputStream
 
ExpandableDirectBufferOutputStream(MutableDirectBuffer, int) - Constructor for class org.agrona.io.ExpandableDirectBufferOutputStream
 
ExpandableDirectByteBuffer - Class in org.agrona
Expandable MutableDirectBuffer that is backed by a direct ByteBuffer.
ExpandableDirectByteBuffer() - Constructor for class org.agrona.ExpandableDirectByteBuffer
ExpandableDirectByteBuffer(int) - Constructor for class org.agrona.ExpandableDirectByteBuffer
Create an ExpandableDirectByteBuffer with a provided initial capacity.

F

fastUnorderedRemove(ArrayList<T>, int) - Static method in class org.agrona.collections.ArrayListUtil
Removes element at index, but instead of copying all elements to the left, moves into the same slot the last element.
fastUnorderedRemove(ArrayList<T>, int, int) - Static method in class org.agrona.collections.ArrayListUtil
Removes element at index, but instead of copying all elements to the left, moves into the same slot the last element.
fastUnorderedRemove(ArrayList<T>, T) - Static method in class org.agrona.collections.ArrayListUtil
Removes element but instead of copying all elements to the left, moves into the same slot the last element.
fastUnorderedRemove(int) - Method in class org.agrona.collections.IntArrayList
Removes element at index, but instead of copying all elements to the left, it replaces the item in the slot with the last item in the list.
fastUnorderedRemove(int) - Method in class org.agrona.collections.LongArrayList
Removes element at index, but instead of copying all elements to the left, it replaces the item in the slot with the last item in the list.
fastUnorderedRemoveInt(int) - Method in class org.agrona.collections.IntArrayList
Remove the first instance of a value if found in the list and replaces it with the last item in the list.
fastUnorderedRemoveLong(long) - Method in class org.agrona.collections.LongArrayList
Remove the first instance of a value if found in the list and replaces it with the last item in the list.
fileChannel() - Method in class org.agrona.concurrent.MappedResizeableBuffer
FileChannel that this buffer is mapping over.
fill(FileChannel, long, long, byte) - Static method in class org.agrona.IoUtil
Fill a region of a file with a given byte value.
findNextPositivePowerOfTwo(int) - Static method in class org.agrona.BitUtil
Fast method of finding the next power of 2 greater than or equal to the supplied value.
FIRST_OBSERVATION_TIMESTAMP_OFFSET - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Offset within a record at which the first observation timestamp field begins.
floatValue() - Method in class org.agrona.collections.MutableInteger
 
floatValue() - Method in class org.agrona.collections.MutableLong
 
flush() - Method in class org.agrona.io.DirectBufferOutputStream
Override to remove IOException.
Flyweight - Interface in org.agrona.sbe
An SBE (Simple Binary Encoding) flyweight object.
forEach(Consumer<V>) - Method in class org.agrona.collections.BiInt2ObjectMap
Iterate over the contents of the map
forEach(BiInt2ObjectMap.EntryConsumer<V>) - Method in class org.agrona.collections.BiInt2ObjectMap
Iterate over the contents of the map
forEach(IntIntConsumer) - Method in class org.agrona.collections.Int2IntCounterMap
Iterate over all value in the map which are not at Int2IntCounterMap.initialValue().
forEach(BiConsumer<? super Integer, ? super Integer>) - Method in class org.agrona.collections.Int2IntHashMap
forEach(LongLongConsumer) - Method in class org.agrona.collections.Long2LongCounterMap
Iterate over all value in the map which are not at Long2LongCounterMap.initialValue().
forEach(BiConsumer<? super Long, ? super Long>) - Method in class org.agrona.collections.Long2LongHashMap
forEach(BiConsumer<? super K, ? super V>) - Method in class org.agrona.collections.Object2ObjectHashMap
forEach(RecordBuffer.RecordHandler) - Method in class org.agrona.concurrent.RecordBuffer
Read each record out of the buffer in turn.
forEach(IntObjConsumer<String>) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over all labels in the label buffer.
forEach(CountersReader.CounterConsumer) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over the counters and provide the value and basic metadata.
forEach(CountersReader.MetaData) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over all the metadata in the buffer.
forEach(DeadlineTimerWheel.TimerConsumer) - Method in class org.agrona.DeadlineTimerWheel
Iterate over wheel so all active timers can be consumed without expiring them.
forEach(ToIntFunction<SelectionKey>) - Method in class org.agrona.nio.NioSelectedKeySet
Iterate over the key set and apply the given function.
forEachOrderedInt(IntConsumer) - Method in class org.agrona.collections.IntArrayList
For each element in order provide the int value to a IntConsumer.
forEachOrderedLong(LongConsumer) - Method in class org.agrona.collections.LongArrayList
For each element in order provide the long value to a LongConsumer.
free(int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
 
free(int) - Method in class org.agrona.concurrent.status.CountersManager
Free the counter identified by counterId.
FREE_FOR_REUSE_DEADLINE_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the deadline (in milliseconds) for when counter may be reused.
fromHex(String) - Static method in class org.agrona.BitUtil
Generate a byte array from a string that is the hex representation of the given byte array.
fromHexByteArray(byte[]) - Static method in class org.agrona.BitUtil
Generate a byte array from the hex representation of the given byte array.
FULL_LABEL_LENGTH - Static variable in class org.agrona.concurrent.status.CountersReader
Length of a counter label length including length prefix.

G

generateRandomisedId() - Static method in class org.agrona.BitUtil
Generate a randomised integer over [Integer.MIN_VALUE, Integer.MAX_VALUE].
get(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
Retrieve a value from the map.
get(int) - Method in class org.agrona.collections.Int2IntCounterMap
Get the value of a counter associated with a key or Int2IntCounterMap.initialValue() if not found.
get(int) - Method in class org.agrona.collections.Int2IntHashMap
 
get(Object) - Method in class org.agrona.collections.Int2IntHashMap
get(Object) - Method in class org.agrona.collections.Int2ObjectCache
get(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.get(Object) that takes a primitive int key.
get(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
get(int) - Method in class org.agrona.collections.Int2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive int key.
get(int) - Method in class org.agrona.collections.IntArrayList
 
get(long) - Method in class org.agrona.collections.Long2LongCounterMap
Get the value of a counter associated with a key or Long2LongCounterMap.initialValue() if not found.
get(long) - Method in class org.agrona.collections.Long2LongHashMap
 
get(Object) - Method in class org.agrona.collections.Long2LongHashMap
get(Object) - Method in class org.agrona.collections.Long2ObjectCache
get(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.get(Object) that takes a primitive long key.
get(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
get(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
get(int) - Method in class org.agrona.collections.LongArrayList
 
get() - Method in class org.agrona.collections.MutableBoolean
Get the current value.
get() - Method in class org.agrona.collections.MutableInteger
 
get() - Method in class org.agrona.collections.MutableLong
 
get() - Method in class org.agrona.collections.MutableReference
Get the current value of the reference.
get(Object) - Method in class org.agrona.collections.Object2IntHashMap
get(Object) - Method in class org.agrona.collections.Object2LongHashMap
get(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
 
get(int) - Method in class org.agrona.concurrent.RecordBuffer
Search for the first record with the specified key.
get() - Method in class org.agrona.concurrent.status.AtomicCounter
Get the latest value for the counter with volatile semantics.
get() - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
get() - Method in class org.agrona.concurrent.status.Position
Get the current position of a component without memory ordering semantics.
get() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
getAndAdd(int, int) - Method in class org.agrona.collections.Int2IntCounterMap
Add amount to the current value associated with this key.
getAndAdd(long, long) - Method in class org.agrona.collections.Long2LongCounterMap
Add amount to the current value associated with this key.
getAndAdd(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Add an increment to the counter that will not lose updates across threads.
getAndAddInt(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomically add a delta to a value at a location returning the previous contents.
getAndAddInt(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getAndAddInt(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getAndAddLong(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomically add a delta to a value at a location returning the previous contents.
getAndAddLong(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getAndAddLong(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getAndAddOrdered(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Add an increment to the counter with ordered store semantics.
getAndDecrement(int) - Method in class org.agrona.collections.Int2IntCounterMap
Convenience version of Int2IntCounterMap.getAndAdd(int, int) (key, -1).
getAndDecrement(long) - Method in class org.agrona.collections.Long2LongCounterMap
Convenience version of Long2LongCounterMap.getAndAdd(long, long) (key, -1).
getAndIncrement(int) - Method in class org.agrona.collections.Int2IntCounterMap
Convenience version of Int2IntCounterMap.getAndAdd(int, int) (key, 1).
getAndIncrement(long) - Method in class org.agrona.collections.Long2LongCounterMap
Convenience version of Long2LongCounterMap.getAndAdd(long, long) (key, 1).
getAndSet(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Get the current value of a counter and atomically set it to a new value.
getAndSetInt(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomically exchange a value at a location returning the previous contents.
getAndSetInt(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getAndSetInt(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getAndSetLong(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomically exchange a value at a location returning the previous contents.
getAndSetLong(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getAndSetLong(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getByte(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getByte(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getByte(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getByte(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getByte(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes(MutableDirectBuffer, int) - Method in class org.agrona.AsciiSequenceView
 
getBytes(long, byte[]) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getBytes(long, byte[], long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getBytes(long, ByteBuffer, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getBytes(int, byte[]) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getBytes(int, byte[], int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getBytes(int, MutableDirectBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getBytes(int, ByteBuffer, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getBytes(int, ByteBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getBytes(int, byte[]) - Method in interface org.agrona.DirectBuffer
Get from the underlying buffer into a supplied byte array.
getBytes(int, byte[], int, int) - Method in interface org.agrona.DirectBuffer
Get bytes from the underlying buffer into a supplied byte array.
getBytes(int, MutableDirectBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Get bytes from this DirectBuffer into the provided MutableDirectBuffer at given indices.
getBytes(int, ByteBuffer, int) - Method in interface org.agrona.DirectBuffer
Get from the underlying buffer into a supplied ByteBuffer current Buffer.position().
getBytes(int, ByteBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Get from the underlying buffer into a supplied ByteBuffer at a offset.
getBytes(int, byte[]) - Method in class org.agrona.ExpandableArrayBuffer
 
getBytes(int, byte[], int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getBytes(int, MutableDirectBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getBytes(int, ByteBuffer, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getBytes(int, ByteBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getBytes(int, byte[]) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes(int, byte[], int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes(int, MutableDirectBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes(int, ByteBuffer, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes(int, ByteBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getBytes() - Method in class org.agrona.generation.JavaClassObject
 
getByteVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getByteVolatile(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getByteVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getChar(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getChar(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getChar(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getChar(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getChar(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getChar(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getChar(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getChar(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getChar(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getChar(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getCharContent(boolean) - Method in class org.agrona.generation.CharSequenceJavaFileObject
 
getCharVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getCharVolatile(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getCharVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getClassLoader(JavaFileManager.Location) - Method in class org.agrona.generation.ClassFileManager
 
getCounterLabel(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the label for a given counter id.
getCounterState(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the state for a given counter id as a volatile read.
getCounterValue(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the value for a given counter id as a volatile read.
getDigit(int, byte) - Static method in class org.agrona.AsciiEncoding
Get the digit value of an ASCII encoded byte.
getDigit(int, char) - Static method in class org.agrona.AsciiEncoding
Get the digit value of an ASCII encoded char.
getDouble(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getDouble(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getDouble(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getDouble(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getDouble(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getDouble(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getDouble(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getDouble(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getDouble(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getDouble(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getDurationInNanos(String, long) - Static method in class org.agrona.SystemUtil
Get a string representation of a time duration with an optional suffix of 's', 'ms', 'us', or 'ns' suffix to indicate seconds, milliseconds, microseconds, or nanoseconds respectively.
getFloat(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getFloat(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getFloat(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getFloat(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getFloat(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getFloat(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getFloat(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getFloat(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getFloat(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getFloat(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getFreeForReuseDeadline(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the deadline (in milliseconds) for when a given counter id may be reused.
getInt(int) - Method in class org.agrona.collections.IntArrayList
Get the element at a given index without boxing.
getInt(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getInt(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getInt(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getInt(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getInt(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getInt(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getInt(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getInt(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getInt(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getInt(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getIntKey() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
getIntKey() - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
 
getIntKey() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
getIntValue() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
getIntValue() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
getIntVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getIntVolatile(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getIntVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getJavaFileForOutput(JavaFileManager.Location, String, JavaFileObject.Kind, FileObject) - Method in class org.agrona.generation.ClassFileManager
 
getKey() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
 
getKey() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
 
getKey() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
getKey() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
getKind() - Method in class org.agrona.generation.JavaClassObject
 
getLong(int) - Method in class org.agrona.collections.LongArrayList
Get the element at a given index without boxing.
getLong(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getLong(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getLong(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getLong(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getLong(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getLong(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getLong(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getLong(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getLong(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getLong(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getLongKey() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
getLongKey() - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
 
getLongKey() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
getLongValue() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
getLongValue() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
getLongVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getLongVolatile(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getLongVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getMapped(int) - Method in class org.agrona.collections.Int2ObjectHashMap
 
getMapped(long) - Method in class org.agrona.collections.Long2ObjectHashMap
 
getOrDefault(Map<K, V>, K, Function<K, V>) - Static method in class org.agrona.collections.CollectionUtil
A getOrDefault that doesn't create garbage if its suppler is non-capturing.
getPid() - Static method in class org.agrona.SystemUtil
Return the current process id from the OS.
getShort(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getShort(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getShort(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getShort(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getShort(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getShort(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getShort(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getShort(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getShort(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getShort(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getShortVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getShortVolatile(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getShortVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getSizeAsInt(String, int) - Static method in class org.agrona.SystemUtil
Get a size value as an int from a system property.
getSizeAsLong(String, long) - Static method in class org.agrona.SystemUtil
Get a size value as a long from a system property.
getSource(String) - Method in class org.agrona.generation.StringWriterOutputManager
 
getSources() - Method in class org.agrona.generation.StringWriterOutputManager
 
getStringAscii(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringAscii(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringAscii(int) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get part of String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringAscii(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringAscii(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringAscii(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringUtf8(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getStringUtf8(long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getStringUtf8(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getStringUtf8(int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringUtf8(int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringUtf8(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringUtf8(int) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in UTF-8 format that is length prefixed.
getStringUtf8(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in UTF-8 format that is length prefixed.
getStringUtf8(int, int) - Method in interface org.agrona.DirectBuffer
Get part of String from bytes encoded in UTF-8 format that is length prefixed.
getStringUtf8(int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringUtf8(int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringUtf8(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringUtf8(int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringUtf8(int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringUtf8(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringWithoutLengthAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringWithoutLengthAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get an encoded ASCII String from the buffer that does not have a length prefix.
getStringWithoutLengthAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringWithoutLengthAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getStringWithoutLengthUtf8(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
getStringWithoutLengthUtf8(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
getStringWithoutLengthUtf8(int, int) - Method in interface org.agrona.DirectBuffer
Get an encoded UTF-8 String from the buffer that does not have a length prefix.
getStringWithoutLengthUtf8(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
getStringWithoutLengthUtf8(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
getValue() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
getValue() - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
 
getValue() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
getValue() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
getValue() - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
 
getValue() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
getValue() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
getValue(K) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version of Map.get(Object) that takes a primitive int key.
getValue() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
getValue(K) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
getValue() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
getVolatile() - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
getVolatile() - Method in class org.agrona.concurrent.status.ReadablePosition
Get the current position of a component with volatile semantics
getVolatile() - Method in class org.agrona.concurrent.status.StatusIndicatorReader
Get the current status indication of a component with volatile semantics.
getVolatile() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
getVolatile() - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
getWeak() - Method in class org.agrona.concurrent.status.AtomicCounter
Get the value of the counter using weak ordering semantics.

H

hasAddAgentCompleted() - Method in class org.agrona.concurrent.DynamicCompositeAgent
Has the last successful DynamicCompositeAgent.tryAdd(Agent) operation been processed in the DynamicCompositeAgent.doWork() cycle?
hasErrors(AtomicBuffer) - Static method in class org.agrona.concurrent.errors.ErrorLogReader
Has the error buffer any recorded errors?
hash(int) - Static method in class org.agrona.collections.Hashing
Generate a hash for an int value.
hash(long) - Static method in class org.agrona.collections.Hashing
Generate a hash for an long value.
hash(int, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for a int value.
hash(K, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for a K value.
hash(long, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for a long value.
hashCode() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
hashCode() - Method in class org.agrona.collections.Int2IntHashMap
 
hashCode() - Method in class org.agrona.collections.Int2ObjectCache
hashCode() - Method in class org.agrona.collections.Int2ObjectHashMap
hashCode() - Method in class org.agrona.collections.IntArrayList
hashCode() - Method in class org.agrona.collections.IntHashSet
hashCode() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
hashCode() - Method in class org.agrona.collections.Long2LongHashMap
 
hashCode() - Method in class org.agrona.collections.Long2ObjectCache
hashCode() - Method in class org.agrona.collections.Long2ObjectHashMap
hashCode() - Method in class org.agrona.collections.LongArrayList
hashCode() - Method in class org.agrona.collections.LongHashSet
hashCode() - Method in class org.agrona.collections.MutableBoolean
 
hashCode() - Method in class org.agrona.collections.MutableInteger
 
hashCode() - Method in class org.agrona.collections.MutableLong
 
hashCode() - Method in class org.agrona.collections.MutableReference
 
hashCode() - Method in class org.agrona.collections.NullReference
 
hashCode() - Method in class org.agrona.collections.Object2IntHashMap
hashCode() - Method in class org.agrona.collections.Object2LongHashMap
hashCode() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
hashCode() - Method in class org.agrona.collections.Object2ObjectHashMap
 
hashCode() - Method in class org.agrona.collections.ObjectHashSet
hashCode() - Method in class org.agrona.concurrent.UnsafeBuffer
 
hashCode() - Method in class org.agrona.ExpandableArrayBuffer
 
hashCode() - Method in class org.agrona.ExpandableDirectByteBuffer
 
Hashing - Class in org.agrona.collections
Hashing functions for applying to integers.
Hashing() - Constructor for class org.agrona.collections.Hashing
 
hasNext() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
hasNext() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
hasNext() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
hasNext() - Method in class org.agrona.collections.UnmodifiableCollectionView.ReusableIterator
 
hasRemoveAgentCompleted() - Method in class org.agrona.concurrent.DynamicCompositeAgent
Has the last DynamicCompositeAgent.tryRemove(Agent) operation been processed in the DynamicCompositeAgent.doWork() cycle?
HEAD_CACHE_POSITION_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the head cache value is stored.
HEAD_OFFSET - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
HEAD_POSITION_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the head value is stored.
HEADER_LENGTH - Static variable in class org.agrona.concurrent.broadcast.RecordDescriptor
Length of the record header in bytes.
HEADER_LENGTH - Static variable in class org.agrona.concurrent.ringbuffer.RecordDescriptor
Header length made up of fields for length, type, and then the encoded message.
HighResolutionClock - Class in org.agrona.concurrent
Clock that provides the number of time units since the 1 Jan 1970 UTC.
HighResolutionClock() - Constructor for class org.agrona.concurrent.HighResolutionClock
 
HighResolutionTimer - Class in org.agrona.concurrent
Control the supporting of high resolution timers for scheduled events by enabling the MidiDevice.
HighResolutionTimer() - Constructor for class org.agrona.concurrent.HighResolutionTimer
 

I

id() - Method in class org.agrona.concurrent.status.AtomicCounter
Identity for the counter within the CountersManager.
id() - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
id() - Method in class org.agrona.concurrent.status.ReadablePosition
Identifier for this position.
id() - Method in class org.agrona.concurrent.status.StatusIndicatorReader
Identifier for this status indicator.
id() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
id() - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
idle(int) - Method in class org.agrona.concurrent.BackoffIdleStrategy
Perform current idle action (e.g.
idle() - Method in class org.agrona.concurrent.BackoffIdleStrategy
 
idle(int) - Method in class org.agrona.concurrent.BusySpinIdleStrategy
Note: this implementation will result in no safepoint poll once inlined.
idle() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
 
idle(int) - Method in class org.agrona.concurrent.ControllableIdleStrategy
Idle based on current status indication value
idle() - Method in class org.agrona.concurrent.ControllableIdleStrategy
Perform current idle action (e.g.
idle(int) - Method in interface org.agrona.concurrent.IdleStrategy
Perform current idle action (e.g.
idle() - Method in interface org.agrona.concurrent.IdleStrategy
Perform current idle action (e.g.
idle(int) - Method in class org.agrona.concurrent.NoOpIdleStrategy
Note: this implementation will result in no safepoint poll once inlined.
idle() - Method in class org.agrona.concurrent.NoOpIdleStrategy
Note: this implementation will result in no safepoint poll once inlined.
idle(int) - Method in class org.agrona.concurrent.SleepingIdleStrategy
 
idle() - Method in class org.agrona.concurrent.SleepingIdleStrategy
 
idle(int) - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
 
idle() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
 
idle(int) - Method in class org.agrona.concurrent.YieldingIdleStrategy
 
idle() - Method in class org.agrona.concurrent.YieldingIdleStrategy
 
IdleStrategy - Interface in org.agrona.concurrent
Idle strategy for use by threads when they do not have work to do.
increment() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic increment that will not lose updates across threads.
incrementAndGet(int) - Method in class org.agrona.collections.Int2IntCounterMap
Convenience version of Int2IntCounterMap.addAndGet(int, int) (key, 1).
incrementAndGet(long) - Method in class org.agrona.collections.Long2LongCounterMap
Convenience version of Long2LongCounterMap.addAndGet(long, long) (key, 1).
incrementOrdered() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic increment that is not safe across threads.
indexOf(int) - Method in class org.agrona.collections.IntArrayList
Index of the first element with this value.
indexOf(long) - Method in class org.agrona.collections.LongArrayList
Index of the first element with this value.
INITIAL_CAPACITY - Static variable in class org.agrona.collections.IntArrayList
Initial capacity to which the array will be sized.
INITIAL_CAPACITY - Static variable in class org.agrona.collections.LongArrayList
Initial capacity to which the array will be sized.
INITIAL_CAPACITY - Static variable in class org.agrona.ExpandableArrayBuffer
Initial capacity of the buffer from which it will expand as necessary.
INITIAL_CAPACITY - Static variable in class org.agrona.ExpandableDirectByteBuffer
Initial capacity of the buffer from which it will expand.
initialise() - Method in class org.agrona.concurrent.RecordBuffer
Initialise the buffer if you're the first thread to begin writing
initialValue() - Method in class org.agrona.collections.Int2IntCounterMap
The value to be used as a null marker in the map.
initialValue() - Method in class org.agrona.collections.Long2LongCounterMap
The value to be used as a null marker in the map.
INSTANCE - Static variable in class org.agrona.collections.NullReference
 
Int2IntCounterMap - Class in org.agrona.collections
A open-addressing with linear probing hash map specialised for primitive key and counter pairs.
Int2IntCounterMap(int) - Constructor for class org.agrona.collections.Int2IntCounterMap
Construct a new counter map with the initial value for the counter provided.
Int2IntCounterMap(int, float, int) - Constructor for class org.agrona.collections.Int2IntCounterMap
 
Int2IntHashMap - Class in org.agrona.collections
A open addressing with linear probing hash map specialised for primitive key and value pairs.
Int2IntHashMap(int) - Constructor for class org.agrona.collections.Int2IntHashMap
 
Int2IntHashMap(int, float, int) - Constructor for class org.agrona.collections.Int2IntHashMap
 
Int2IntHashMap(int, float, int, boolean) - Constructor for class org.agrona.collections.Int2IntHashMap
 
Int2IntHashMap.EntryIterator - Class in org.agrona.collections
 
Int2IntHashMap.EntrySet - Class in org.agrona.collections
 
Int2IntHashMap.KeyIterator - Class in org.agrona.collections
 
Int2IntHashMap.KeySet - Class in org.agrona.collections
 
Int2IntHashMap.ValueCollection - Class in org.agrona.collections
 
Int2IntHashMap.ValueIterator - Class in org.agrona.collections
 
Int2NullableObjectHashMap<V> - Class in org.agrona.collections
Variation of Int2ObjectHashMap that allows null values.
Int2NullableObjectHashMap() - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
 
Int2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
 
Int2NullableObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Int2NullableObjectHashMap(Int2ObjectHashMap<V>) - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
Copy construct a new map from an existing one.
Int2ObjectCache<V> - Class in org.agrona.collections
A cache implementation specialised for int keys using open addressing to probe a set of fixed size.
Int2ObjectCache(int, int, Consumer<V>) - Constructor for class org.agrona.collections.Int2ObjectCache
 
Int2ObjectCache.EntryIterator - Class in org.agrona.collections
 
Int2ObjectCache.EntrySet - Class in org.agrona.collections
 
Int2ObjectCache.KeyIterator - Class in org.agrona.collections
 
Int2ObjectCache.KeySet - Class in org.agrona.collections
 
Int2ObjectCache.ValueCollection - Class in org.agrona.collections
 
Int2ObjectCache.ValueIterator - Class in org.agrona.collections
 
Int2ObjectHashMap<V> - Class in org.agrona.collections
Map implementation specialised for int keys using open addressing and linear probing for cache efficient access.
Int2ObjectHashMap() - Constructor for class org.agrona.collections.Int2ObjectHashMap
 
Int2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Int2ObjectHashMap
 
Int2ObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Int2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Int2ObjectHashMap(Int2ObjectHashMap<V>) - Constructor for class org.agrona.collections.Int2ObjectHashMap
Copy construct a new map from an existing one.
Int2ObjectHashMap.EntryIterator - Class in org.agrona.collections
 
Int2ObjectHashMap.EntrySet - Class in org.agrona.collections
 
Int2ObjectHashMap.KeyIterator - Class in org.agrona.collections
 
Int2ObjectHashMap.KeySet - Class in org.agrona.collections
 
Int2ObjectHashMap.ValueCollection - Class in org.agrona.collections
 
Int2ObjectHashMap.ValueIterator - Class in org.agrona.collections
 
IntArrayList - Class in org.agrona.collections
A List implementation that stores int values with the ability to not have them boxed.
IntArrayList() - Constructor for class org.agrona.collections.IntArrayList
 
IntArrayList(int, int) - Constructor for class org.agrona.collections.IntArrayList
Construct a new list.
IntArrayList(int[], int, int) - Constructor for class org.agrona.collections.IntArrayList
Create a new list that wraps an existing arrays without copying it.
intForEach(IntIntConsumer) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised forEach implementation.
IntHashSet - Class in org.agrona.collections
Open-addressing with linear-probing expandable hash set.
IntHashSet() - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with IntHashSet.DEFAULT_INITIAL_CAPACITY, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
IntHashSet(int) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed capacity, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
IntHashSet(int, float) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed initial capacity, load factor, and iterator caching support.
IntHashSet(int, float, boolean) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed initial capacity, load factor, and indicated iterator caching support.
IntHashSet.IntIterator - Class in org.agrona.collections
 
IntIntConsumer - Interface in org.agrona.collections
This is an (int, int) primitive specialisation of a BiConsumer
IntIterator() - Constructor for class org.agrona.collections.IntHashSet.IntIterator
 
IntLruCache<E> - Class in org.agrona.collections
A fixed capacity cache of int keyed values that evicts the least-recently-used element when it runs out of space.
IntLruCache(int, IntFunction<E>, Consumer<E>) - Constructor for class org.agrona.collections.IntLruCache
Constructor.
IntObjConsumer<T> - Interface in org.agrona.collections
This is an (int, Object) primitive specialisation of a BiConsumer.
intStream() - Method in class org.agrona.collections.IntArrayList
Create a IntStream over the elements of underlying array.
intValue() - Method in class org.agrona.collections.MutableInteger
 
intValue() - Method in class org.agrona.collections.MutableLong
 
invoke() - Method in class org.agrona.concurrent.AgentInvoker
Invoke the Agent.doWork() method and return the work count.
IoUtil - Class in org.agrona
Collection of IO utilities.
IoUtil() - Constructor for class org.agrona.IoUtil
 
isActive(MappedByteBuffer, EpochClock, long, int, int, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
 
isAligned(long, int) - Static method in class org.agrona.BitUtil
Is an address aligned on a boundary.
isCleared(Reference) - Static method in class org.agrona.References
Indicate whether a Reference has been cleared.
isClosed() - Method in class org.agrona.concurrent.AgentInvoker
Has the Agent been closed?
isClosed() - Method in class org.agrona.concurrent.AgentRunner
Has the Agent been closed?
isClosed() - Method in class org.agrona.concurrent.status.AtomicCounter
Has this counter been closed?
isClosed() - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
isClosed() - Method in class org.agrona.concurrent.status.Position
Has this Position been closed?
isClosed() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
isClosed() - Method in class org.agrona.MarkFile
 
isDebuggerAttached() - Static method in class org.agrona.SystemUtil
Is a debugger attached to the JVM?
isEmpty() - Method in class org.agrona.collections.BiInt2ObjectMap
Is map empty or not.
isEmpty() - Method in class org.agrona.collections.Int2IntCounterMap
Is the map empty.
isEmpty() - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
isEmpty() - Method in class org.agrona.collections.Int2IntHashMap
isEmpty() - Method in class org.agrona.collections.Int2IntHashMap.KeySet
isEmpty() - Method in class org.agrona.collections.Int2ObjectCache
isEmpty() - Method in class org.agrona.collections.Int2ObjectHashMap
isEmpty() - Method in class org.agrona.collections.IntHashSet
isEmpty() - Method in class org.agrona.collections.Long2LongCounterMap
Is the map empty.
isEmpty() - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
isEmpty() - Method in class org.agrona.collections.Long2LongHashMap
isEmpty() - Method in class org.agrona.collections.Long2LongHashMap.KeySet
isEmpty() - Method in class org.agrona.collections.Long2ObjectCache
isEmpty() - Method in class org.agrona.collections.Long2ObjectHashMap
isEmpty() - Method in class org.agrona.collections.LongHashSet
isEmpty() - Method in class org.agrona.collections.Object2IntHashMap
isEmpty() - Method in class org.agrona.collections.Object2LongHashMap
isEmpty() - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
isEmpty() - Method in class org.agrona.collections.Object2ObjectHashMap
isEmpty() - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
isEmpty() - Method in class org.agrona.collections.ObjectHashSet
isEmpty() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
isEmpty() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
isEmpty(String) - Static method in class org.agrona.Strings
Is a string null or empty?
isEnabled() - Static method in class org.agrona.concurrent.HighResolutionTimer
Has the high resolution timer been enabled?
isEven(int) - Static method in class org.agrona.BitUtil
Is a number even.
isExpandable() - Method in class org.agrona.concurrent.UnsafeBuffer
 
isExpandable() - Method in class org.agrona.ExpandableArrayBuffer
 
isExpandable() - Method in class org.agrona.ExpandableDirectByteBuffer
 
isExpandable() - Method in interface org.agrona.MutableDirectBuffer
Is this buffer expandable to accommodate putting data into it beyond the current capacity?
isInitialised() - Method in class org.agrona.concurrent.RecordBuffer
Check if the buffer has been initialised.
isPowerOfTwo(int) - Static method in class org.agrona.BitUtil
Is a value a positive power of 2.
isReferringTo(Reference<T>, T) - Static method in class org.agrona.References
Indicate whether a Reference refers to a given object.
isRunning() - Method in class org.agrona.concurrent.AgentInvoker
Has the Agent been running?
isStarted() - Method in class org.agrona.concurrent.AgentInvoker
Has the Agent been started?
ITERATION_THRESHOLD - Static variable in class org.agrona.nio.TransportPoller
 
iterator() - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Int2IntHashMap.KeySet
iterator() - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.Int2ObjectCache.EntrySet
 
iterator() - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
iterator() - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
 
iterator() - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
iterator() - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.IntHashSet
iterator() - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Long2LongHashMap.KeySet
iterator() - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.Long2ObjectCache.EntrySet
 
iterator() - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
iterator() - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
 
iterator() - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
iterator() - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.LongHashSet
iterator() - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Object2IntHashMap.KeySet
iterator() - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Object2LongHashMap.KeySet
iterator() - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
iterator() - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
iterator() - Method in class org.agrona.collections.Object2ObjectHashMap.ValueCollection
iterator() - Method in class org.agrona.collections.ObjectHashSet
iterator() - Method in class org.agrona.collections.UnmodifiableCollectionView
iterator() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
iterator() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
iterator() - Method in class org.agrona.nio.NioSelectedKeySet

J

JavaClassObject - Class in org.agrona.generation
 
JavaClassObject(String, JavaFileObject.Kind) - Constructor for class org.agrona.generation.JavaClassObject
 

K

KEY_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the key is stored.
KeyIterator() - Constructor for class org.agrona.collections.Int2IntHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Int2ObjectCache.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Int2ObjectHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Long2LongHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Long2ObjectCache.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Long2ObjectHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Object2IntHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Object2LongHashMap.KeyIterator
 
KeyIterator() - Constructor for class org.agrona.collections.Object2ObjectHashMap.KeyIterator
 
keys() - Method in class org.agrona.nio.NioSelectedKeySet
Return selected keys.
keySet() - Method in class org.agrona.collections.Int2IntHashMap
KeySet() - Constructor for class org.agrona.collections.Int2IntHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Int2ObjectCache
KeySet() - Constructor for class org.agrona.collections.Int2ObjectCache.KeySet
 
keySet() - Method in class org.agrona.collections.Int2ObjectHashMap
KeySet() - Constructor for class org.agrona.collections.Int2ObjectHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Long2LongHashMap
KeySet() - Constructor for class org.agrona.collections.Long2LongHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Long2ObjectCache
KeySet() - Constructor for class org.agrona.collections.Long2ObjectCache.KeySet
 
keySet() - Method in class org.agrona.collections.Long2ObjectHashMap
KeySet() - Constructor for class org.agrona.collections.Long2ObjectHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Object2IntHashMap
KeySet() - Constructor for class org.agrona.collections.Object2IntHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Object2LongHashMap
KeySet() - Constructor for class org.agrona.collections.Object2LongHashMap.KeySet
 
keySet() - Method in class org.agrona.collections.Object2ObjectHashMap
KeySet() - Constructor for class org.agrona.collections.Object2ObjectHashMap.KeySet
 

L

LABEL_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the label is stored.
labelCharset - Variable in class org.agrona.concurrent.status.CountersReader
 
labelCharset() - Method in class org.agrona.concurrent.status.CountersReader
The Charset used for the encoded label.
LangUtil - Class in org.agrona
Grouping of language level utilities to make programming in Java more convenient.
LangUtil() - Constructor for class org.agrona.LangUtil
 
lappedCount() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Get the number of times the transmitter has lapped this receiver around the buffer.
LAST_OBSERVATION_TIMESTAMP_OFFSET - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Offset within a record at which the last observation timestamp field begins.
lastIndexOf(int) - Method in class org.agrona.collections.IntArrayList
Index of the last element with this value.
lastIndexOf(long) - Method in class org.agrona.collections.LongArrayList
Index of the last element with this value.
LATEST_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Offset within the trailer for where the latest sequence value is stored.
length() - Method in class org.agrona.AsciiSequenceView
length() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
The length of the next message in the transmission stream.
length() - Method in class org.agrona.io.DirectBufferInputStream
The length of the underlying buffer to use
length() - Method in class org.agrona.io.DirectBufferOutputStream
The length of the underlying buffer to use
LENGTH_OFFSET - Static variable in class org.agrona.concurrent.broadcast.RecordDescriptor
Offset within the record at which the record length field begins.
LENGTH_OFFSET - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Offset within a record at which the length field begins.
lengthOffset(int) - Static method in class org.agrona.concurrent.broadcast.RecordDescriptor
The buffer offset at which the message length field begins.
lengthOffset(int) - Static method in class org.agrona.concurrent.ringbuffer.RecordDescriptor
The offset from the beginning of a record at which the message length field begins.
loadFactor() - Method in class org.agrona.collections.BiInt2ObjectMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class org.agrona.collections.Int2IntCounterMap
Get the load factor applied for resize operations.
loadFactor() - Method in class org.agrona.collections.Int2IntHashMap
Get the load factor applied for resize operations.
loadFactor() - Method in class org.agrona.collections.Int2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class org.agrona.collections.IntHashSet
Get the load factor beyond which the set will increase size.
loadFactor() - Method in class org.agrona.collections.Long2LongCounterMap
Get the load factor applied for resize operations.
loadFactor() - Method in class org.agrona.collections.Long2LongHashMap
Get the load factor applied for resize operations.
loadFactor() - Method in class org.agrona.collections.Long2ObjectHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class org.agrona.collections.LongHashSet
Get the load factor beyond which the set will increase size.
loadFactor() - Method in class org.agrona.collections.Object2IntHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class org.agrona.collections.Object2LongHashMap
Get the load factor beyond which the map will increase size.
loadFactor() - Method in class org.agrona.collections.Object2ObjectHashMap
Get the load factor applied for resize operations.
loadFactor() - Method in class org.agrona.collections.ObjectHashSet
Get the load factor beyond which the set will increase size.
loadPropertiesFile(String) - Static method in class org.agrona.SystemUtil
Load system properties from a given filename or url.
loadPropertiesFiles(String[]) - Static method in class org.agrona.SystemUtil
Load system properties from a given set of filenames or URLs.
lock() - Method in class org.agrona.concurrent.NoOpLock
Proceeds as if the lock has been acquired.
lockInterruptibly() - Method in class org.agrona.concurrent.NoOpLock
Proceeds as if the lock has been acquired.
LoggingErrorHandler - Class in org.agrona.concurrent.errors
A logging ErrorHandler that records to a DistinctErrorLog and if the log is full then overflows to a PrintStream.
LoggingErrorHandler(DistinctErrorLog) - Constructor for class org.agrona.concurrent.errors.LoggingErrorHandler
Construct error handler wrapping a DistinctErrorLog with a default of System.err for the LoggingErrorHandler.errorOverflow().
LoggingErrorHandler(DistinctErrorLog, PrintStream) - Constructor for class org.agrona.concurrent.errors.LoggingErrorHandler
Construct error handler wrapping a DistinctErrorLog and PrintStream for error overflow.
Long2LongCounterMap - Class in org.agrona.collections
A open-addressing with linear probing hash map specialised for primitive key and counter pairs.
Long2LongCounterMap(long) - Constructor for class org.agrona.collections.Long2LongCounterMap
Construct a new counter map with the initial value for the counter provided.
Long2LongCounterMap(int, float, long) - Constructor for class org.agrona.collections.Long2LongCounterMap
 
Long2LongHashMap - Class in org.agrona.collections
A open addressing with linear probing hash map specialised for primitive key and value pairs.
Long2LongHashMap(long) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap(int, float, long) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap(int, float, long, boolean) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap.EntryIterator - Class in org.agrona.collections
 
Long2LongHashMap.EntrySet - Class in org.agrona.collections
 
Long2LongHashMap.KeyIterator - Class in org.agrona.collections
 
Long2LongHashMap.KeySet - Class in org.agrona.collections
 
Long2LongHashMap.ValueCollection - Class in org.agrona.collections
 
Long2LongHashMap.ValueIterator - Class in org.agrona.collections
 
Long2NullableObjectHashMap<V> - Class in org.agrona.collections
Variation of Long2ObjectHashMap that allows null values.
Long2NullableObjectHashMap() - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
 
Long2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
 
Long2NullableObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Long2NullableObjectHashMap(Long2ObjectHashMap<V>) - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
Copy construct a new map from an existing one.
Long2ObjectCache<V> - Class in org.agrona.collections
A cache implementation specialised for long keys using open addressing to probe a set of fixed size.
Long2ObjectCache(int, int, Consumer<V>) - Constructor for class org.agrona.collections.Long2ObjectCache
 
Long2ObjectCache.EntryIterator - Class in org.agrona.collections
 
Long2ObjectCache.EntrySet - Class in org.agrona.collections
 
Long2ObjectCache.KeyIterator - Class in org.agrona.collections
 
Long2ObjectCache.KeySet - Class in org.agrona.collections
 
Long2ObjectCache.ValueCollection - Class in org.agrona.collections
 
Long2ObjectCache.ValueIterator - Class in org.agrona.collections
 
Long2ObjectHashMap<V> - Class in org.agrona.collections
Map implementation specialised for long keys using open addressing and linear probing for cache efficient access.
Long2ObjectHashMap() - Constructor for class org.agrona.collections.Long2ObjectHashMap
 
Long2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Long2ObjectHashMap
 
Long2ObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Long2ObjectHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Long2ObjectHashMap(Long2ObjectHashMap<V>) - Constructor for class org.agrona.collections.Long2ObjectHashMap
Copy construct a new map from an existing one.
Long2ObjectHashMap.EntryIterator - Class in org.agrona.collections
 
Long2ObjectHashMap.EntrySet - Class in org.agrona.collections
 
Long2ObjectHashMap.KeyIterator - Class in org.agrona.collections
 
Long2ObjectHashMap.KeySet - Class in org.agrona.collections
 
Long2ObjectHashMap.ValueCollection - Class in org.agrona.collections
 
Long2ObjectHashMap.ValueIterator - Class in org.agrona.collections
 
LongArrayList - Class in org.agrona.collections
A List implementation that stores long values with the ability to not have them boxed.
LongArrayList() - Constructor for class org.agrona.collections.LongArrayList
 
LongArrayList(int, long) - Constructor for class org.agrona.collections.LongArrayList
Construct a new list.
LongArrayList(long[], int, long) - Constructor for class org.agrona.collections.LongArrayList
Create a new list that wraps an existing arrays without copying it.
longForEach(LongLongConsumer) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised forEach implementation.
LongHashSet - Class in org.agrona.collections
Open-addressing with linear-probing expandable hash set.
LongHashSet() - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with LongHashSet.DEFAULT_INITIAL_CAPACITY, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
LongHashSet(int) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed capacity, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
LongHashSet(int, float) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed initial capacity, load factor, and iterator caching support.
LongHashSet(int, float, boolean) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed initial capacity, load factor, and indicated iterator caching support.
LongHashSet.LongIterator - Class in org.agrona.collections
 
LongIterator() - Constructor for class org.agrona.collections.LongHashSet.LongIterator
 
LongLongConsumer - Interface in org.agrona.collections
This is an (long, long) primitive specialisation of a BiConsumer
LongLruCache<E> - Class in org.agrona.collections
A fixed capacity cache of long keyed values that evicts the least-recently-used element when it runs out of space.
LongLruCache(int, LongFunction<E>, Consumer<E>) - Constructor for class org.agrona.collections.LongLruCache
Constructor.
longStream() - Method in class org.agrona.collections.LongArrayList
Create a LongStream over the elements of underlying array.
longValue() - Method in class org.agrona.collections.MutableInteger
 
longValue() - Method in class org.agrona.collections.MutableLong
 
lookup(int) - Method in class org.agrona.collections.IntLruCache
Looks up an element in the cache, creating a new element if it doesn't exist and evicting the least recently used element if there's no space left in the cache.
lookup(long) - Method in class org.agrona.collections.LongLruCache
Looks up an element in the cache, creating a new element if it doesn't exist and evicting the least recently used element if there's no space left in the cache.

M

main(String[]) - Static method in class org.agrona.generation.PrimitiveExpander
 
ManagedResource - Interface in org.agrona
Implementations of this interface can a resource that need to have external state tracked for deletion.
ManyToManyConcurrentArrayQueue<E> - Class in org.agrona.concurrent
Many producer to many consumer concurrent queue that is array backed.
ManyToManyConcurrentArrayQueue(int) - Constructor for class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
Create a new queue with a bounded capacity.
ManyToOneConcurrentArrayQueue<E> - Class in org.agrona.concurrent
Many producer to one consumer concurrent queue that is array backed.
ManyToOneConcurrentArrayQueue(int) - Constructor for class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
ManyToOneConcurrentLinkedQueue<E> - Class in org.agrona.concurrent
Concurrent linked Queue that can be used from many producers and a single consumer.
ManyToOneConcurrentLinkedQueue() - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
ManyToOneRingBuffer - Class in org.agrona.concurrent.ringbuffer
A ring-buffer that supports the exchange of messages from many producers to a single consumer.
ManyToOneRingBuffer(AtomicBuffer) - Constructor for class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Construct a new RingBuffer based on an underlying AtomicBuffer.
map(FileChannel, FileChannel.MapMode, long, long) - Static method in class org.agrona.IoUtil
Map a range of a file and return the address at which the range begins.
mapExistingFile(File, String) - Static method in class org.agrona.IoUtil
Check that file exists, open file, and return MappedByteBuffer for entire file
mapExistingFile(File, String, long, long) - Static method in class org.agrona.IoUtil
Check that file exists, open file, and return MappedByteBuffer for only region specified
mapExistingFile(File, Consumer<String>, long, long) - Static method in class org.agrona.MarkFile
 
mapExistingMarkFile(File, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
 
mapNewFile(File, long) - Static method in class org.agrona.IoUtil
Create a new file, fill with 0s, and return a MappedByteBuffer for the file.
mapNewFile(File, long, boolean) - Static method in class org.agrona.IoUtil
Create a new file, and optionally fill with 0s, and return a MappedByteBuffer for the file.
mapNewOrExistingMarkFile(File, boolean, int, int, long, long, EpochClock, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
 
mapNullValue(Object) - Method in class org.agrona.collections.Int2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Long2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Object2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
 
mappedByteBuffer() - Method in class org.agrona.MarkFile
 
MappedResizeableBuffer - Class in org.agrona.concurrent
Supports regular, byte ordered, and atomic (memory ordered) access to an underlying buffer.
MappedResizeableBuffer(FileChannel, long, long) - Constructor for class org.agrona.concurrent.MappedResizeableBuffer
Attach a view to an off-heap memory region by address.
MarkFile - Class in org.agrona
A MarkFile is used to mark the presence of a running component and to track liveness.
MarkFile(File, String, boolean, boolean, int, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Constructor for class org.agrona.MarkFile
Create a directory and mark file if none present.
MarkFile(File, boolean, int, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Constructor for class org.agrona.MarkFile
Create a MarkFile if none present.
MarkFile(File, String, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Constructor for class org.agrona.MarkFile
Map a pre-existing MarkFile if one present and is active.
MarkFile(MappedByteBuffer, int, int) - Constructor for class org.agrona.MarkFile
Manage a MarkFile given a mapped file and offsets of version and timestamp.
MarkFile(UnsafeBuffer, int, int) - Constructor for class org.agrona.MarkFile
Manage a MarkFile given a buffer and offsets of version and timestamp.
markFile() - Method in class org.agrona.MarkFile
 
markSupported() - Method in class org.agrona.io.DirectBufferInputStream
 
MAX_ARRAY_LENGTH - Static variable in class org.agrona.ExpandableArrayBuffer
Maximum length to which the underlying buffer can grow.
MAX_BUFFER_LENGTH - Static variable in class org.agrona.ExpandableDirectByteBuffer
Maximum length to which the underlying buffer can grow.
MAX_CAPACITY - Static variable in class org.agrona.collections.IntArrayList
Maximum capacity to which the array can grow.
MAX_CAPACITY - Static variable in class org.agrona.collections.LongArrayList
Maximum capacity to which the array can grow.
MAX_KEY_LENGTH - Static variable in class org.agrona.concurrent.status.CountersReader
Maximum length a key can be.
MAX_LABEL_LENGTH - Static variable in class org.agrona.concurrent.status.CountersReader
Maximum length of a label not including its length prefix.
maxCounterId - Variable in class org.agrona.concurrent.status.CountersReader
 
maxCounterId() - Method in class org.agrona.concurrent.status.CountersReader
Get the maximum counter id which can be supported given the length of the values buffer.
maxMsgLength() - Method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
Get the maximum message length that can be transmitted for a buffer.
maxMsgLength() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
The maximum message length in bytes supported by the underlying ring buffer.
maxMsgLength() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
The maximum message length in bytes supported by the underlying ring buffer.
maxMsgLength() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
The maximum message length in bytes supported by the underlying ring buffer.
maxValue() - Method in class org.agrona.collections.Int2IntCounterMap
Get the maximum value stored in the map.
maxValue() - Method in class org.agrona.collections.Int2IntHashMap
Get the maximum value stored in the map.
maxValue() - Method in class org.agrona.collections.Long2LongCounterMap
Get the maximum value stored in the map.
maxValue() - Method in class org.agrona.collections.Long2LongHashMap
Get the maximum value stored in the map.
MessageDecoderFlyweight - Interface in org.agrona.sbe
A flyweight for decoding an SBE message from a buffer.
MessageEncoderFlyweight - Interface in org.agrona.sbe
A flyweight for encoding SBE messages.
MessageFlyweight - Interface in org.agrona.sbe
Common behaviour to SBE Message encoder and decoder flyweights.
MessageHandler - Interface in org.agrona.concurrent
Callback interface for processing of messages that are read from a buffer.
METADATA_LENGTH - Static variable in class org.agrona.concurrent.status.CountersReader
Length of a meta data record in bytes.
metaDataBuffer - Variable in class org.agrona.concurrent.status.CountersReader
 
metaDataBuffer() - Method in class org.agrona.concurrent.status.CountersReader
Get the buffer containing the metadata for the counters.
metaDataOffset(int) - Static method in class org.agrona.concurrent.status.CountersReader
The offset in the metadata buffer for a given id.
microTime() - Method in interface org.agrona.concurrent.EpochMicroClock
Time in microseconds since 1 Jan 1970 UTC.
microTime() - Method in class org.agrona.concurrent.SystemEpochMicroClock
 
MIN_INTEGER_VALUE - Static variable in class org.agrona.AsciiEncoding
 
MIN_LONG_VALUE - Static variable in class org.agrona.AsciiEncoding
 
MINUS_SIGN - Static variable in class org.agrona.AsciiEncoding
 
minValue() - Method in class org.agrona.collections.Int2IntCounterMap
Get the minimum value stored in the map.
minValue() - Method in class org.agrona.collections.Int2IntHashMap
Get the minimum value stored in the map.
minValue() - Method in class org.agrona.collections.Long2LongCounterMap
Get the minimum value stored in the map.
minValue() - Method in class org.agrona.collections.Long2LongHashMap
Get the minimum value stored in the map.
missingValue() - Method in class org.agrona.collections.Int2IntHashMap
The value to be used as a null marker in the map.
missingValue() - Method in class org.agrona.collections.Long2LongHashMap
The value to be used as a null marker in the map.
missingValue() - Method in class org.agrona.collections.Object2IntHashMap
The value to be used as a null marker in the map.
missingValue() - Method in class org.agrona.collections.Object2LongHashMap
The value to be used as a null marker in the map.
msgOffset(int) - Static method in class org.agrona.concurrent.broadcast.RecordDescriptor
The buffer offset at which the encoded message begins.
MutableBoolean - Class in org.agrona.collections
Mutable boolean valid that is useful for capturing a value when using lambdas or collections.
MutableBoolean() - Constructor for class org.agrona.collections.MutableBoolean
Default constructor.
MutableBoolean(boolean) - Constructor for class org.agrona.collections.MutableBoolean
Construct with a default value.
MutableDirectBuffer - Interface in org.agrona
Abstraction over a range of buffer types that allows fields to be written in native typed fashion.
MutableInteger - Class in org.agrona.collections
Holder for an int value that is mutable.
MutableInteger() - Constructor for class org.agrona.collections.MutableInteger
 
MutableInteger(int) - Constructor for class org.agrona.collections.MutableInteger
 
MutableLong - Class in org.agrona.collections
Holder for an long value that is mutable.
MutableLong() - Constructor for class org.agrona.collections.MutableLong
 
MutableLong(long) - Constructor for class org.agrona.collections.MutableLong
 
MutableReference<T> - Class in org.agrona.collections
Mutable reference that is useful for capturing an object reference when using lambdas.
MutableReference() - Constructor for class org.agrona.collections.MutableReference
Default constructor.
MutableReference(T) - Constructor for class org.agrona.collections.MutableReference
Set the reference at construction.

N

NanoClock - Interface in org.agrona.concurrent
Functional interface for return the current time as system wide monotonic tick of 1 nanosecond precision.
nanoTime() - Method in class org.agrona.concurrent.CachedNanoClock
 
nanoTime() - Method in interface org.agrona.concurrent.EpochNanoClock
Time in nanoseconds since 1 Jan 1970 UTC.
nanoTime() - Method in interface org.agrona.concurrent.NanoClock
The number of ticks in nanoseconds the clock has advanced since starting.
nanoTime() - Method in class org.agrona.concurrent.SystemEpochNanoClock
 
nanoTime() - Method in class org.agrona.concurrent.SystemNanoClock
 
NATIVE_BYTE_ORDER - Static variable in class org.agrona.BufferUtil
 
newArray(T[], int) - Static method in class org.agrona.collections.ArrayUtil
Allocate a new array of the same type as another array.
newCondition() - Method in class org.agrona.concurrent.NoOpLock
Not supported.
newCounter(String) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a counter record and wrap it with a new AtomicCounter for use with a default type of CountersManager.DEFAULT_TYPE_ID.
newCounter(String, int) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a counter record and wrap it with a new AtomicCounter for use.
newCounter(String, int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a counter record and wrap it with a new AtomicCounter for use.
newCounter(int, DirectBuffer, int, int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a counter record and wrap it with a new AtomicCounter for use.
next(int, int) - Static method in class org.agrona.BitUtil
Cycles indices of an array one at a time in a forward fashion
next() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Int2IntHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Int2IntHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
 
next() - Method in class org.agrona.collections.Int2ObjectCache.KeyIterator
 
next() - Method in class org.agrona.collections.Int2ObjectCache.ValueIterator
 
next() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Int2ObjectHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Int2ObjectHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
next() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Long2LongHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Long2LongHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
 
next() - Method in class org.agrona.collections.Long2ObjectCache.KeyIterator
 
next() - Method in class org.agrona.collections.Long2ObjectCache.ValueIterator
 
next() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Long2ObjectHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Long2ObjectHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
next() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Object2IntHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Object2IntHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Object2LongHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Object2LongHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
next() - Method in class org.agrona.collections.Object2ObjectHashMap.KeyIterator
 
next() - Method in class org.agrona.collections.Object2ObjectHashMap.ValueIterator
 
next() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
next() - Method in class org.agrona.collections.UnmodifiableCollectionView.ReusableIterator
 
nextCorrelationId() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Get the next value that can be used for a correlation id on an message when a response needs to be correlated.
nextCorrelationId() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Get the next value that can be used for a correlation id on an message when a response needs to be correlated.
nextCorrelationId() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Get the next value that can be used for a correlation id on an message when a response needs to be correlated.
nextInt() - Method in class org.agrona.collections.Int2ObjectCache.KeyIterator
 
nextInt() - Method in class org.agrona.collections.Int2ObjectHashMap.KeyIterator
 
nextInt() - Method in class org.agrona.collections.Object2IntHashMap.ValueIterator
 
nextLong() - Method in class org.agrona.collections.Long2ObjectCache.KeyIterator
 
nextLong() - Method in class org.agrona.collections.Long2ObjectHashMap.KeyIterator
 
nextLong() - Method in class org.agrona.collections.Object2LongHashMap.ValueIterator
 
nextValue() - Method in class org.agrona.collections.Int2IntHashMap.KeyIterator
 
nextValue() - Method in class org.agrona.collections.Int2IntHashMap.ValueIterator
 
nextValue() - Method in class org.agrona.collections.IntHashSet.IntIterator
Strongly typed alternative of Iterator.next() to avoid boxing.
nextValue() - Method in class org.agrona.collections.Long2LongHashMap.KeyIterator
 
nextValue() - Method in class org.agrona.collections.Long2LongHashMap.ValueIterator
 
nextValue() - Method in class org.agrona.collections.LongHashSet.LongIterator
Strongly typed alternative of Iterator.next() to avoid boxing.
nextValue() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
NioSelectedKeySet - Class in org.agrona.nio
Try to fix handling of HashSet for Selector.
NioSelectedKeySet() - Constructor for class org.agrona.nio.NioSelectedKeySet
Construct a key set with default capacity
NioSelectedKeySet(int) - Constructor for class org.agrona.nio.NioSelectedKeySet
Construct a key set with the given capacity.
NOOP - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
NoOpIdleStrategy - Class in org.agrona.concurrent
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.
NoOpIdleStrategy() - Constructor for class org.agrona.concurrent.NoOpIdleStrategy
 
NoOpLock - Class in org.agrona.concurrent
A Lock implementation that is a no operation, i.e.
NoOpLock() - Constructor for class org.agrona.concurrent.NoOpLock
 
NOT_CONTROLLED - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
NOT_FREE_TO_REUSE - Static variable in class org.agrona.concurrent.status.CountersReader
Deadline to indicate counter is not free to be reused.
notNull(Object, String) - Static method in class org.agrona.Verify
Verify that a reference is not null.
NULL_BYTES - Static variable in class org.agrona.BufferUtil
 
NULL_COUNTER_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Can be used to representing a null counter id when passed as a argument.
NULL_TIMER - Static variable in class org.agrona.DeadlineTimerWheel
 
NullReference - Class in org.agrona.collections
 
NullReference() - Constructor for class org.agrona.collections.NullReference
 
nullValue() - Method in class org.agrona.collections.IntArrayList
The value representing a null element.
nullValue() - Method in class org.agrona.collections.LongArrayList
The value representing a null element.

O

Object2IntHashMap<K> - Class in org.agrona.collections
Map implementation specialised for int values using open addressing and linear probing for cache efficient access.
Object2IntHashMap(int) - Constructor for class org.agrona.collections.Object2IntHashMap
Construct a map with default capacity and load factor.
Object2IntHashMap(int, float, int) - Constructor for class org.agrona.collections.Object2IntHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Object2IntHashMap(int, float, int, boolean) - Constructor for class org.agrona.collections.Object2IntHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Object2IntHashMap(Object2IntHashMap<K>) - Constructor for class org.agrona.collections.Object2IntHashMap
Copy construct a new map from an existing one.
Object2IntHashMap.EntryIterator - Class in org.agrona.collections
 
Object2IntHashMap.EntrySet - Class in org.agrona.collections
 
Object2IntHashMap.KeyIterator - Class in org.agrona.collections
 
Object2IntHashMap.KeySet - Class in org.agrona.collections
 
Object2IntHashMap.ValueCollection - Class in org.agrona.collections
 
Object2IntHashMap.ValueIterator - Class in org.agrona.collections
 
Object2LongHashMap<K> - Class in org.agrona.collections
Map implementation specialised for long values using open addressing and linear probing for cache efficient access.
Object2LongHashMap(long) - Constructor for class org.agrona.collections.Object2LongHashMap
Construct a map with default capacity and load factor.
Object2LongHashMap(int, float, long) - Constructor for class org.agrona.collections.Object2LongHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Object2LongHashMap(int, float, long, boolean) - Constructor for class org.agrona.collections.Object2LongHashMap
Construct a new map allowing a configuration for initial capacity and load factor.
Object2LongHashMap(Object2LongHashMap<K>) - Constructor for class org.agrona.collections.Object2LongHashMap
Copy construct a new map from an existing one.
Object2LongHashMap.EntryIterator - Class in org.agrona.collections
 
Object2LongHashMap.EntrySet - Class in org.agrona.collections
 
Object2LongHashMap.KeyIterator - Class in org.agrona.collections
 
Object2LongHashMap.KeySet - Class in org.agrona.collections
 
Object2LongHashMap.ValueCollection - Class in org.agrona.collections
 
Object2LongHashMap.ValueIterator - Class in org.agrona.collections
 
Object2NullableObjectHashMap<K,V> - Class in org.agrona.collections
Variation of Object2ObjectHashMap that allows null values.
Object2NullableObjectHashMap() - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
 
Object2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
 
Object2NullableObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
 
Object2ObjectHashMap<K,V> - Class in org.agrona.collections
A open addressing with linear probing hash map, same algorithm as Int2IntHashMap.
Object2ObjectHashMap() - Constructor for class org.agrona.collections.Object2ObjectHashMap
 
Object2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Object2ObjectHashMap
 
Object2ObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Object2ObjectHashMap
 
Object2ObjectHashMap.EntryIterator - Class in org.agrona.collections
 
Object2ObjectHashMap.EntrySet - Class in org.agrona.collections
 
Object2ObjectHashMap.KeyIterator - Class in org.agrona.collections
 
Object2ObjectHashMap.KeySet - Class in org.agrona.collections
 
Object2ObjectHashMap.ValueCollection - Class in org.agrona.collections
 
Object2ObjectHashMap.ValueIterator - Class in org.agrona.collections
 
ObjectHashSet<T> - Class in org.agrona.collections
Open-addressing with linear-probing expandable hash set.
ObjectHashSet() - Constructor for class org.agrona.collections.ObjectHashSet
Construct a hash set with ObjectHashSet.DEFAULT_INITIAL_CAPACITY, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
ObjectHashSet(int) - Constructor for class org.agrona.collections.ObjectHashSet
Construct a hash set with a proposed initial capacity, Hashing.DEFAULT_LOAD_FACTOR, and iterator caching support.
ObjectHashSet(int, float) - Constructor for class org.agrona.collections.ObjectHashSet
Construct a hash set with a proposed initial capacity, load factor, and iterator caching support.
ObjectHashSet(int, float, boolean) - Constructor for class org.agrona.collections.ObjectHashSet
Construct a hash set with a proposed initial capacity, load factor, and indicated iterator caching support.
ObjectHashSet.ObjectIterator - Class in org.agrona.collections
 
ObjectIterator() - Constructor for class org.agrona.collections.ObjectHashSet.ObjectIterator
 
OBSERVATION_COUNT_OFFSET - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Offset within a record at which the observation count field begins.
offer(E) - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
offer(E) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
offer(E) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
offer(E) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
offset() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
The offset for the beginning of the next message in the transmission stream.
offset - Variable in class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
offset() - Method in class org.agrona.io.DirectBufferInputStream
The offset within the underlying buffer at which to start.
offset() - Method in class org.agrona.io.DirectBufferOutputStream
The offset within the underlying buffer at which to start.
offset() - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
The offset within the underlying buffer at which to start.
offset() - Method in interface org.agrona.sbe.Flyweight
Offset within the Flyweight.buffer() the flyweight is encoded.
offset() - Method in interface org.agrona.sbe.MessageFlyweight
The current offset in the buffer from which the message is being encoded or decoded.
onClose() - Method in interface org.agrona.concurrent.Agent
To be overridden by Agents that need to do resource cleanup on close.
onClose() - Method in class org.agrona.concurrent.CompositeAgent
To be overridden by Agents that need to do resource cleanup on close.
onClose() - Method in class org.agrona.concurrent.DynamicCompositeAgent
To be overridden by Agents that need to do resource cleanup on close.
onError(Throwable) - Method in class org.agrona.concurrent.CountedErrorHandler
 
onError(Throwable) - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
 
onError(Throwable) - Method in interface org.agrona.ErrorHandler
Callback to notify of an error that has occurred when processing an operation or event.
OneToOneConcurrentArrayQueue<E> - Class in org.agrona.concurrent
One producer to one consumer concurrent queue that is array backed.
OneToOneConcurrentArrayQueue(int) - Constructor for class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
OneToOneRingBuffer - Class in org.agrona.concurrent.ringbuffer
A ring-buffer that supports the exchange of messages from a single producer to a single consumer.
OneToOneRingBuffer(AtomicBuffer) - Constructor for class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Construct a new RingBuffer based on an underlying AtomicBuffer.
onMessage(int, MutableDirectBuffer, int, int) - Method in interface org.agrona.concurrent.MessageHandler
Called for the processing of each message read from a buffer in turn.
onRecord(int, int) - Method in interface org.agrona.concurrent.RecordBuffer.RecordHandler
Called once for each committed record in the buffer.
onSpinWait() - Static method in class org.agrona.hints.ThreadHints
Indicates that the caller is momentarily unable to progress, until the occurrence of one or more actions on the part of other activities.
onStart() - Method in interface org.agrona.concurrent.Agent
To be overridden by Agents that need to do resource init on start.
onStart() - Method in class org.agrona.concurrent.CompositeAgent
To be overridden by Agents that need to do resource init on start.
onStart() - Method in class org.agrona.concurrent.DynamicCompositeAgent
To be overridden by Agents that need to do resource init on start.
onTimerExpiry(TimeUnit, long, long) - Method in interface org.agrona.DeadlineTimerWheel.TimerHandler
Called when the deadline is past.
openOutputStream() - Method in class org.agrona.generation.JavaClassObject
 
org.agrona - package org.agrona
 
org.agrona.collections - package org.agrona.collections
 
org.agrona.concurrent - package org.agrona.concurrent
 
org.agrona.concurrent.broadcast - package org.agrona.concurrent.broadcast
 
org.agrona.concurrent.errors - package org.agrona.concurrent.errors
 
org.agrona.concurrent.ringbuffer - package org.agrona.concurrent.ringbuffer
 
org.agrona.concurrent.status - package org.agrona.concurrent.status
 
org.agrona.console - package org.agrona.console
 
org.agrona.generation - package org.agrona.generation
 
org.agrona.hints - package org.agrona.hints
This package captures hints that may be used by some runtimes to improve code performance.
org.agrona.io - package org.agrona.io
 
org.agrona.nio - package org.agrona.nio
 
org.agrona.sbe - package org.agrona.sbe
 
osName() - Static method in class org.agrona.SystemUtil
Get the name of the operating system as a lower case String.
OutputManager - Interface in org.agrona.generation
Abstraction that manages the destination of generated output.

P

p1 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p1 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p10 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p10 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p11 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p11 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p12 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p12 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p13 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p13 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p14 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p14 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p15 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p15 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p2 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p2 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p3 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p3 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p31 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p32 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p33 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p34 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p35 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p36 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p37 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p38 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p39 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p4 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p4 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p40 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p41 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p42 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p43 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p44 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p45 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p5 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p5 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p6 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p6 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p7 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p7 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p8 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p8 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p9 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p9 - Variable in class org.agrona.concurrent.CachedNanoClock
 
PackageOutputManager - Class in org.agrona.generation
OutputManager for managing the creation of Java source files as the target of code generation.
PackageOutputManager(String, String) - Constructor for class org.agrona.generation.PackageOutputManager
Create a new OutputManager for generating Java source files into a given package.
PADDING_MSG_TYPE_ID - Static variable in class org.agrona.concurrent.broadcast.RecordDescriptor
Message type is padding to prevent fragmentation in the buffer.
PADDING_MSG_TYPE_ID - Static variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Record type is padding to prevent fragmentation in the buffer.
PADDING_MSG_TYPE_ID - Static variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Record type is padding to prevent fragmentation in the buffer.
parentDirectory() - Method in class org.agrona.MarkFile
 
PARK - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
parseDuration(String, String) - Static method in class org.agrona.SystemUtil
Parse a string representation of a time duration with an optional suffix of 's', 'ms', 'us', or 'ns' to indicate seconds, milliseconds, microseconds, or nanoseconds respectively.
parseIntAscii(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
Parse an ASCII encoded int from a CharSequence.
parseIntAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
parseIntAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get the ASCII encoded integer value at a given index.
parseIntAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
parseIntAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
parseIntOrDefault(String, int) - Static method in class org.agrona.Strings
Parse an int from a String.
parseLongAscii(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
Parse an ASCII encoded long from a CharSequence.
parseLongAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
parseLongAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get the ASCII encoded long integer value at a given index.
parseLongAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
parseLongAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
parseNaturalIntAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
parseNaturalIntAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get the ASCII encoded int sized natural value at a given index.
parseNaturalIntAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
parseNaturalIntAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
parseNaturalLongAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
parseNaturalLongAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get the ASCII encoded long sized natural value at a given index.
parseNaturalLongAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
parseNaturalLongAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
parseSize(String, String) - Static method in class org.agrona.SystemUtil
Parse a string representation of a value with optional suffix of 'g', 'm', and 'k' suffix to indicate gigabytes, megabytes, or kilobytes respectively.
peek() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
peek() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
persist(Map<String, CharSequence>) - Static method in class org.agrona.generation.CompilerUtil
 
PID_NOT_FOUND - Static variable in class org.agrona.SystemUtil
PID value if a process id could not be determined.
Pipe<E> - Interface in org.agrona.concurrent
A container for items exchanged from producers to consumers.
poll() - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
poll() - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
 
poll() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
poll() - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
 
poll(long, DeadlineTimerWheel.TimerHandler, int) - Method in class org.agrona.DeadlineTimerWheel
Poll for timers expired by the deadline passing.
popInt() - Method in class org.agrona.collections.IntArrayList
Pop a value off the end of the array as a stack operation.
popLong() - Method in class org.agrona.collections.LongArrayList
Pop a value off the end of the array as a stack operation.
Position - Class in org.agrona.concurrent.status
Reports on how far through a buffer some component has progressed.
Position() - Constructor for class org.agrona.concurrent.status.Position
 
position() - Method in class org.agrona.io.DirectBufferOutputStream
The position in the buffer from the offset up to which has been written.
position() - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
The position in the buffer from the offset up to which has been written.
present(Map<?, ?>, Object, String) - Static method in class org.agrona.Verify
Verify that a map contains an entry for a given key.
previous(int, int) - Static method in class org.agrona.BitUtil
Cycles indices of an array one at a time in a backwards fashion
PrimitiveExpander - Class in org.agrona.generation
 
PrimitiveExpander() - Constructor for class org.agrona.generation.PrimitiveExpander
 
PrimitiveExpander.Substitution - Class in org.agrona.generation
 
producerPosition() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
The position in bytes from start up of the producers.
producerPosition() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
The position in bytes from start up of the producers.
producerPosition() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
The position in bytes from start up of the producers.
proposeMax(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Set the value to a new proposedValue if greater than the current value with memory ordering semantics.
proposeMax(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
proposeMax(long) - Method in class org.agrona.concurrent.status.Position
Set the position to a new proposedValue if greater than the current value without memory ordering semantics.
proposeMax(long) - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
proposeMaxOrdered(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Set the value to a new proposedValue if greater than the current value with memory ordering semantics.
proposeMaxOrdered(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
proposeMaxOrdered(long) - Method in class org.agrona.concurrent.status.Position
Set the position to the new proposedValue if greater than the current value with memory ordering semantics.
proposeMaxOrdered(long) - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
PUBLIC_SELECTED_KEYS_FIELD - Static variable in class org.agrona.nio.TransportPoller
 
pushInt(int) - Method in class org.agrona.collections.IntArrayList
Push an element onto the end of the array like a stack.
pushLong(long) - Method in class org.agrona.collections.LongArrayList
Push an element onto the end of the array like a stack.
put(int, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Put a value into the map.
put(int, int) - Method in class org.agrona.collections.Int2IntCounterMap
Put the value for a key into the map.
put(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Put a key value pair into the map.
put(Integer, Integer) - Method in class org.agrona.collections.Int2IntHashMap
put(Integer, V) - Method in class org.agrona.collections.Int2ObjectCache
put(int, V) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
put(Integer, V) - Method in class org.agrona.collections.Int2ObjectHashMap
put(int, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
put(long, long) - Method in class org.agrona.collections.Long2LongCounterMap
Put the value for a key longo the map.
put(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Put a key value pair longo the map.
put(Long, Long) - Method in class org.agrona.collections.Long2LongHashMap
put(Long, V) - Method in class org.agrona.collections.Long2ObjectCache
put(long, V) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(Long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
put(long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(K, Integer) - Method in class org.agrona.collections.Object2IntHashMap
put(K, int) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
put(K, Long) - Method in class org.agrona.collections.Object2LongHashMap
put(K, long) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(Object, Object) - Method in class org.agrona.collections.Object2ObjectHashMap
Put a key value pair into the map.
putAll(Map<? extends Integer, ? extends Integer>) - Method in class org.agrona.collections.Int2IntHashMap
putAll(Map<? extends Integer, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
putAll(Map<? extends Integer, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
putAll(Map<? extends Long, ? extends Long>) - Method in class org.agrona.collections.Long2LongHashMap
putAll(Map<? extends Long, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
putAll(Map<? extends Long, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
putAll(Map<? extends K, ? extends Integer>) - Method in class org.agrona.collections.Object2IntHashMap
putAll(Map<? extends K, ? extends Long>) - Method in class org.agrona.collections.Object2LongHashMap
putAll(Map<? extends K, ? extends V>) - Method in class org.agrona.collections.Object2ObjectHashMap
putByte(long, byte) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putByte(int, byte) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putByte(int, byte) - Method in class org.agrona.ExpandableArrayBuffer
 
putByte(int, byte) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putByte(int, byte) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putBytes(long, byte[]) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putBytes(long, byte[], long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putBytes(long, ByteBuffer, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putBytes(long, ByteBuffer, long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putBytes(long, DirectBuffer, int, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putBytes(int, byte[]) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putBytes(int, byte[], int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putBytes(int, ByteBuffer, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putBytes(int, ByteBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putBytes(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putBytes(int, byte[]) - Method in class org.agrona.ExpandableArrayBuffer
 
putBytes(int, byte[], int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putBytes(int, ByteBuffer, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putBytes(int, ByteBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putBytes(int, DirectBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putBytes(int, byte[]) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putBytes(int, byte[], int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putBytes(int, ByteBuffer, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putBytes(int, ByteBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putBytes(int, DirectBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putBytes(int, byte[]) - Method in interface org.agrona.MutableDirectBuffer
Put an array of src into the underlying buffer.
putBytes(int, byte[], int, int) - Method in interface org.agrona.MutableDirectBuffer
Put an array into the underlying buffer.
putBytes(int, ByteBuffer, int) - Method in interface org.agrona.MutableDirectBuffer
Put bytes into the underlying buffer for the view.
putBytes(int, ByteBuffer, int, int) - Method in interface org.agrona.MutableDirectBuffer
Put bytes into the underlying buffer for the view.
putBytes(int, DirectBuffer, int, int) - Method in interface org.agrona.MutableDirectBuffer
Put bytes from a source DirectBuffer into this MutableDirectBuffer at given indices.
putByteVolatile(int, byte) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putByteVolatile(long, byte) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putByteVolatile(int, byte) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putChar(long, char, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putChar(long, char) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putChar(int, char, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putChar(int, char) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putChar(int, char, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putChar(int, char) - Method in class org.agrona.ExpandableArrayBuffer
 
putChar(int, char, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putChar(int, char) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putChar(int, char, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putChar(int, char) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putCharVolatile(int, char) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putCharVolatile(long, char) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putCharVolatile(int, char) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putDouble(long, double, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putDouble(long, double) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putDouble(int, double, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putDouble(int, double) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putDouble(int, double, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putDouble(int, double) - Method in class org.agrona.ExpandableArrayBuffer
 
putDouble(int, double, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putDouble(int, double) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putDouble(int, double, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putDouble(int, double) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putFloat(long, float, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putFloat(long, float) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putFloat(int, float, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putFloat(int, float) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putFloat(int, float, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putFloat(int, float) - Method in class org.agrona.ExpandableArrayBuffer
 
putFloat(int, float, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putFloat(int, float) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putFloat(int, float, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putFloat(int, float) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putInt(long, int, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putInt(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putInt(int, int, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putInt(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putInt(int, int, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putInt(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putInt(int, int, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putInt(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putInt(int, int, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putInt(int, int) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putIntAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putIntAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putIntAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putIntAscii(int, int) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded int into the buffer
putIntOrdered(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with ordered semantics.
putIntOrdered(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putIntOrdered(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putIntVolatile(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putIntVolatile(long, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putIntVolatile(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putLong(long, long, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putLong(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putLong(int, long, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putLong(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putLong(int, long, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putLong(int, long) - Method in class org.agrona.ExpandableArrayBuffer
 
putLong(int, long, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putLong(int, long) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putLong(int, long, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putLong(int, long) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putLongAscii(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putLongAscii(int, long) - Method in class org.agrona.ExpandableArrayBuffer
 
putLongAscii(int, long) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putLongAscii(int, long) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded long integer into the buffer
putLongOrdered(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with ordered store semantics.
putLongOrdered(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putLongOrdered(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putLongVolatile(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putLongVolatile(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putLongVolatile(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putNaturalIntAscii(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putNaturalIntAscii(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putNaturalIntAscii(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putNaturalIntAscii(int, int) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded int sized natural number into the buffer
putNaturalLongAscii(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putNaturalLongAscii(int, long) - Method in class org.agrona.ExpandableArrayBuffer
 
putNaturalLongAscii(int, long) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putNaturalLongAscii(int, long) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded long sized natural number into the buffer
putShort(long, short, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putShort(long, short) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putShort(int, short, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putShort(int, short) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putShort(int, short, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putShort(int, short) - Method in class org.agrona.ExpandableArrayBuffer
 
putShort(int, short, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putShort(int, short) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putShort(int, short, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putShort(int, short) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putShortVolatile(int, short) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putShortVolatile(long, short) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putShortVolatile(int, short) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringAscii(int, String) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringAscii(int, String, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringAscii(int, String) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringAscii(int, String, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringAscii(int, String) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringAscii(int, String, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringAscii(int, String) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as ASCII bytes to the buffer with a length prefix.
putStringAscii(int, String, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as ASCII bytes to the buffer with a length prefix.
putStringUtf8(long, String) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putStringUtf8(long, String, ByteOrder) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putStringUtf8(long, String, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putStringUtf8(long, String, ByteOrder, int) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putStringUtf8(int, String) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringUtf8(int, String, ByteOrder) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringUtf8(int, String, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringUtf8(int, String, ByteOrder, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringUtf8(int, String) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringUtf8(int, String, ByteOrder) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringUtf8(int, String, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringUtf8(int, String, ByteOrder, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringUtf8(int, String) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringUtf8(int, String, ByteOrder) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringUtf8(int, String, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringUtf8(int, String, ByteOrder, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringUtf8(int, String) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as UTF-8 bytes to the buffer with a length prefix.
putStringUtf8(int, String, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as UTF-8 bytes to the buffer with a length prefix.
putStringUtf8(int, String, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as UTF-8 bytes the buffer with a length prefix with a maximum encoded size check.
putStringUtf8(int, String, ByteOrder, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as UTF-8 bytes the buffer with a length prefix with a maximum encoded size check.
putStringWithoutLengthAscii(int, String) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringWithoutLengthAscii(int, String, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringWithoutLengthAscii(int, String) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringWithoutLengthAscii(int, String, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringWithoutLengthAscii(int, String) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringWithoutLengthAscii(int, String, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringWithoutLengthAscii(int, String) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as ASCII bytes in the buffer without a length prefix.
putStringWithoutLengthAscii(int, String, int, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as ASCII bytes in the buffer without a length prefix taking a range of the value.
putStringWithoutLengthUtf8(long, String) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
putStringWithoutLengthUtf8(int, String) - Method in class org.agrona.concurrent.UnsafeBuffer
 
putStringWithoutLengthUtf8(int, String) - Method in class org.agrona.ExpandableArrayBuffer
 
putStringWithoutLengthUtf8(int, String) - Method in class org.agrona.ExpandableDirectByteBuffer
 
putStringWithoutLengthUtf8(int, String) - Method in interface org.agrona.MutableDirectBuffer
Encode a String as UTF-8 bytes in the buffer without a length prefix.

Q

QueuedPipe<E> - Interface in org.agrona.concurrent
Composed interface for concurrent Queue and Pipe.
quietClose(AutoCloseable) - Static method in class org.agrona.CloseHelper
Quietly close a AutoCloseable dealing with nulls and exceptions.

R

read(AtomicBuffer, ErrorConsumer) - Static method in class org.agrona.concurrent.errors.ErrorLogReader
Read all the errors in a log since the creation of the log.
read(AtomicBuffer, ErrorConsumer, long) - Static method in class org.agrona.concurrent.errors.ErrorLogReader
Read all the errors in a log since a given timestamp.
read(MessageHandler) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Read as many messages as are available to the end of the ring buffer.
read(MessageHandler, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Read as many messages as are available to end of the ring buffer to up a supplied maximum.
read(MessageHandler) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Read as many messages as are available to the end of the ring buffer.
read(MessageHandler, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Read as many messages as are available to end of the ring buffer to up a supplied maximum.
read(MessageHandler) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Read as many messages as are available to the end of the ring buffer.
read(MessageHandler, int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Read as many messages as are available to end of the ring buffer to up a supplied maximum.
read() - Method in class org.agrona.io.DirectBufferInputStream
 
read(byte[], int, int) - Method in class org.agrona.io.DirectBufferInputStream
 
ReadablePosition - Class in org.agrona.concurrent.status
Indicates how far through an abstract task a component has progressed as a counter value.
ReadablePosition() - Constructor for class org.agrona.concurrent.status.ReadablePosition
 
receive(MessageHandler) - Method in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Receive one message from the broadcast buffer.
receiveNext() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Non-blocking receive of next message from the transmission stream.
record(Throwable) - Method in class org.agrona.concurrent.errors.DistinctErrorLog
Record an observation of an error.
RECORD_ALIGNMENT - Static variable in class org.agrona.concurrent.broadcast.RecordDescriptor
Alignment as a multiple of bytes for each record.
RECORD_ALIGNMENT - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
Alignment to be applied for record beginning.
RECORD_ALLOCATED - Static variable in class org.agrona.concurrent.status.CountersReader
Record currently allocated for use.
RECORD_RECLAIMED - Static variable in class org.agrona.concurrent.status.CountersReader
Record was active and now has been reclaimed.
RECORD_UNUSED - Static variable in class org.agrona.concurrent.status.CountersReader
Record has not been used.
RecordBuffer - Class in org.agrona.concurrent
A record buffer is an off-heap buffer with a series of records and a header that can be written to or read from multiple threads.
RecordBuffer(AtomicBuffer, int, int) - Constructor for class org.agrona.concurrent.RecordBuffer
 
RecordBuffer.RecordHandler - Interface in org.agrona.concurrent
Callback interface for reading elements out of the buffer.
RecordBuffer.RecordWriter - Interface in org.agrona.concurrent
Interface for safely writing to the buffer.
RecordDescriptor - Class in org.agrona.concurrent.broadcast
Description of the structure for a record in the broadcast buffer.
RecordDescriptor() - Constructor for class org.agrona.concurrent.broadcast.RecordDescriptor
 
RecordDescriptor - Class in org.agrona.concurrent.ringbuffer
Description of the record structure for message framing in the a RingBuffer.
RecordDescriptor() - Constructor for class org.agrona.concurrent.ringbuffer.RecordDescriptor
 
ref - Variable in class org.agrona.collections.MutableReference
For convenient access.
References - Class in org.agrona
References provides two key helper methods for commonly used idioms on ref types: References.isCleared(Reference), and References.isReferringTo(Reference, Object).
References() - Constructor for class org.agrona.References
 
register(Runnable) - Static method in class org.agrona.concurrent.SigInt
Register a task to be run when a SIGINT is received.
remaining() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
remaining() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
remaining() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
remainingCapacity() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
remainingCapacity() - Method in interface org.agrona.concurrent.Pipe
Get the remaining capacity for elements in the container given the current size.
remove(T[], T) - Static method in class org.agrona.collections.ArrayUtil
Remove an element from an array resulting in a new array if the element was found otherwise the old array.
remove(T[], int) - Static method in class org.agrona.collections.ArrayUtil
 
remove(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
Remove a value from the map and return the value.
remove(int) - Method in class org.agrona.collections.Int2IntCounterMap
Remove a counter value for a given key.
remove(Object) - Method in class org.agrona.collections.Int2IntHashMap
remove(int) - Method in class org.agrona.collections.Int2IntHashMap
 
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache
remove(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.remove(Object) that takes a primitive int key.
remove(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
remove(int) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
remove(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
remove(int) - Method in class org.agrona.collections.Int2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive int key.
remove(int) - Method in class org.agrona.collections.IntArrayList
Remove at a given index.
remove() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
remove(Object) - Method in class org.agrona.collections.IntHashSet
remove(int) - Method in class org.agrona.collections.IntHashSet
An int specialised version of {this#remove(Object)}.
remove(long) - Method in class org.agrona.collections.Long2LongCounterMap
Remove a counter value for a given key.
remove(Object) - Method in class org.agrona.collections.Long2LongHashMap
remove(long) - Method in class org.agrona.collections.Long2LongHashMap
 
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache
remove(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
remove(long) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
remove(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
remove(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(int) - Method in class org.agrona.collections.LongArrayList
Remove at a given index.
remove() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
remove(Object) - Method in class org.agrona.collections.LongHashSet
remove(long) - Method in class org.agrona.collections.LongHashSet
An long specialised version of {this#remove(Object)}.
remove(Object) - Method in class org.agrona.collections.Object2IntHashMap.KeySet
 
remove(Object) - Method in class org.agrona.collections.Object2IntHashMap
remove(Object) - Method in class org.agrona.collections.Object2LongHashMap.KeySet
 
remove(Object) - Method in class org.agrona.collections.Object2LongHashMap
remove(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
remove() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
remove(Object) - Method in class org.agrona.collections.ObjectHashSet
 
remove() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
remove(Object) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
remove() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
remove(Object) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
remove() - Method in class org.agrona.concurrent.ShutdownSignalBarrier
Remove the barrier from the shutdown signals.
remove(Object) - Method in class org.agrona.nio.NioSelectedKeySet
removeAll(Collection<?>) - Method in class org.agrona.collections.IntHashSet
removeAll(IntHashSet) - Method in class org.agrona.collections.IntHashSet
Alias for IntHashSet.removeAll(Collection) for the specialized case when removing another IntHashSet, avoids boxing and allocations
removeAll(Collection<?>) - Method in class org.agrona.collections.LongHashSet
removeAll(LongHashSet) - Method in class org.agrona.collections.LongHashSet
Alias for LongHashSet.removeAll(Collection) for the specialized case when removing another LongHashSet, avoids boxing and allocations
removeAll(Collection<?>) - Method in class org.agrona.collections.ObjectHashSet
removeAll(ObjectHashSet<T>) - Method in class org.agrona.collections.ObjectHashSet
Alias for ObjectHashSet.removeAll(Collection) for the specialized case when removing another ObjectHashSet, avoids boxing and allocations
removeAll(Collection<?>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
removeAll(Collection<?>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
removedCount() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
removedCount() - Method in interface org.agrona.concurrent.Pipe
The number of items removed from this container since creation.
removeIf(List<T>, Predicate<T>) - Static method in class org.agrona.collections.CollectionUtil
Remove element from a list if it matches a predicate.
removeInt(int) - Method in class org.agrona.collections.IntArrayList
Remove the first instance of a value if found in the list.
removeKey(K) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version of Map.remove(Object) that takes a primitive int key.
removeKey(K) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.remove(Object) that takes a primitive long key.
removeLong(long) - Method in class org.agrona.collections.LongArrayList
Remove the first instance of a value if found in the list.
replace(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(int, int, int) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(int, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(int, V, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(long, long, long) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(long, V, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(K, int) - Method in class org.agrona.collections.Object2IntHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(K, int, int) - Method in class org.agrona.collections.Object2IntHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(K, long) - Method in class org.agrona.collections.Object2LongHashMap
Primitive specialised version of Map.replace(Object, Object)
replace(K, long, long) - Method in class org.agrona.collections.Object2LongHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
reset() - Method in class org.agrona.AsciiSequenceView
Reset the view to null.
reset() - Method in class org.agrona.concurrent.BackoffIdleStrategy
 
reset() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
 
reset() - Method in class org.agrona.concurrent.ControllableIdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset() - Method in interface org.agrona.concurrent.IdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset() - Method in class org.agrona.concurrent.NoOpIdleStrategy
 
reset() - Method in class org.agrona.concurrent.SleepingIdleStrategy
 
reset() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
 
reset() - Method in class org.agrona.concurrent.YieldingIdleStrategy
 
reset() - Method in class org.agrona.nio.NioSelectedKeySet
Reset for next iteration.
resetCounters() - Method in class org.agrona.collections.Int2ObjectCache
Reset the cache statistics counters to zero.
resetCounters() - Method in class org.agrona.collections.Long2ObjectCache
Reset the cache statistics counters to zero.
resetStartTime(long) - Method in class org.agrona.DeadlineTimerWheel
Reset the start time of the wheel.
resize(long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
resizeNotifier(IntConsumer) - Method in class org.agrona.collections.ObjectHashSet
Add a Consumer that will be called when the collection is re-sized.
resizeThreshold() - Method in class org.agrona.collections.BiInt2ObjectMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Int2IntCounterMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Int2IntHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Int2ObjectHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.IntHashSet
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Long2LongCounterMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Long2LongHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Long2ObjectHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.LongHashSet
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Object2IntHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Object2LongHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.Object2ObjectHashMap
Get the actual threshold which when reached the map will resize.
resizeThreshold() - Method in class org.agrona.collections.ObjectHashSet
Get the actual threshold which when reached the map will resize.
ResourceConsumer<T> - Interface in org.agrona.generation
Consumer of an resource which can throw IOExceptions.
retainAll(Collection<?>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
retainAll(Collection<?>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
rethrowUnchecked(Throwable) - Static method in class org.agrona.LangUtil
Rethrow an Throwable preserving the stack trace but making it unchecked.
RETRY_CLOSE_TIMEOUT_MS - Static variable in class org.agrona.concurrent.AgentRunner
Default retry timeout for closing.
ReusableIterator() - Constructor for class org.agrona.collections.UnmodifiableCollectionView.ReusableIterator
 
RingBuffer - Interface in org.agrona.concurrent.ringbuffer
Ring-buffer for the concurrent exchanging of binary encoded messages from producer(s) to consumer(s) in a FIFO manner.
RingBufferDescriptor - Class in org.agrona.concurrent.ringbuffer
Layout description for the underlying buffer used by a RingBuffer.
RingBufferDescriptor() - Constructor for class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
 
roleName() - Method in interface org.agrona.concurrent.Agent
Get the name of this agent's role.
roleName() - Method in class org.agrona.concurrent.CompositeAgent
 
roleName() - Method in class org.agrona.concurrent.DynamicCompositeAgent
 
run() - Method in class org.agrona.concurrent.AgentRunner
Run an Agent.

S

sbeBlockLength() - Method in interface org.agrona.sbe.MessageFlyweight
The length of the root block in bytes.
sbeSchemaId() - Method in interface org.agrona.sbe.Flyweight
The SBE Schema identifier containing the message declaration.
sbeSchemaVersion() - Method in interface org.agrona.sbe.Flyweight
The version number of the SBE Schema containing the message.
sbeSemanticType() - Method in interface org.agrona.sbe.MessageFlyweight
The semantic type of the message which is typically the semantic equivalent in the FIX repository.
sbeTemplateId() - Method in interface org.agrona.sbe.MessageFlyweight
The SBE template identifier for the message.
scheduleTimer(long) - Method in class org.agrona.DeadlineTimerWheel
Schedule a timer for a given absolute time as a deadline in DeadlineTimerWheel.timeUnit()s.
SCRATCH_BUFFER_LENGTH - Static variable in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Default length for the scratch buffer for copying messages into.
SELECTED_KEYS_FIELD - Static variable in class org.agrona.nio.TransportPoller
 
selectedKeySet - Variable in class org.agrona.nio.TransportPoller
 
selectNowWithoutProcessing() - Method in class org.agrona.nio.TransportPoller
Explicit call to selectNow but without processing of selected keys.
selector - Variable in class org.agrona.nio.TransportPoller
 
sequenceToBufferOffset(long, long) - Static method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
set(int, Integer) - Method in class org.agrona.collections.IntArrayList
 
set(int, Long) - Method in class org.agrona.collections.LongArrayList
 
set(boolean) - Method in class org.agrona.collections.MutableBoolean
Set the current value.
set(int) - Method in class org.agrona.collections.MutableInteger
 
set(long) - Method in class org.agrona.collections.MutableLong
 
set(T) - Method in class org.agrona.collections.MutableReference
Set the current value of the reference.
set(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Set the counter with volatile semantics.
set(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
set(long) - Method in class org.agrona.concurrent.status.Position
Sets the current position of the component without memory ordering semantics.
set(long) - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
setCounterValue(int, long) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter value based on counterId.
setInt(int, int) - Method in class org.agrona.collections.IntArrayList
Set an element at a given index without boxing.
setLong(int, long) - Method in class org.agrona.collections.LongArrayList
Set an element at a given index without boxing.
setMemory(long, int, byte) - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
setMemory(int, int, byte) - Method in class org.agrona.concurrent.UnsafeBuffer
 
setMemory(int, int, byte) - Method in class org.agrona.ExpandableArrayBuffer
 
setMemory(int, int, byte) - Method in class org.agrona.ExpandableDirectByteBuffer
 
setMemory(int, int, byte) - Method in interface org.agrona.MutableDirectBuffer
Set a region of memory to a given byte value.
setOrdered(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Set the counter with ordered semantics.
setOrdered(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
setOrdered(long) - Method in class org.agrona.concurrent.status.Position
Sets the current position of the component with ordered memory semantics.
setOrdered(long) - Method in class org.agrona.concurrent.status.StatusIndicator
Sets the current status indication of the component with ordered atomic memory semantics.
setOrdered(long) - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
setOrdered(long) - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
setPackageName(String) - Method in class org.agrona.generation.StringWriterOutputManager
 
setValue(Integer) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
setValue(V) - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
 
setValue(V) - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
setValue(Long) - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
setValue(V) - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
 
setValue(V) - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
setValue(Integer) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
setValue(int) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
setValue(Long) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
setValue(long) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
setValue(V) - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
setVolatile(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
 
setVolatile(long) - Method in class org.agrona.concurrent.status.Position
Sets the current position of the component with volatile memory semantics.
setVolatile(long) - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
 
setWeak(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Set the counter with normal semantics.
SHARED_HEAD_CACHE_OFFSET - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
SHIFT_FOR_SCALE - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
shortValue() - Method in class org.agrona.collections.MutableInteger
 
shortValue() - Method in class org.agrona.collections.MutableLong
 
SHOULD_BOUNDS_CHECK - Static variable in class org.agrona.concurrent.UnsafeBuffer
 
ShutdownSignalBarrier - Class in org.agrona.concurrent
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().
ShutdownSignalBarrier() - Constructor for class org.agrona.concurrent.ShutdownSignalBarrier
Construct and register the barrier ready for use.
SigInt - Class in org.agrona.concurrent
Utility to allow the registration of a SIGINT handler that hides the unsupported Signal class.
SigInt() - Constructor for class org.agrona.concurrent.SigInt
 
SigIntBarrier - Class in org.agrona.concurrent
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().
SigIntBarrier() - Constructor for class org.agrona.concurrent.SigIntBarrier
Construct and register the barrier ready for use.
signal() - Method in class org.agrona.concurrent.ShutdownSignalBarrier
Programmatically signal awaiting threads.
signal() - Method in class org.agrona.concurrent.SigIntBarrier
Programmatically signal awaiting threads.
SIGNAL_NAMES - Static variable in class org.agrona.concurrent.ShutdownSignalBarrier
Signals the barrier will be registered for.
signalReady(int) - Method in class org.agrona.MarkFile
 
size() - Method in class org.agrona.collections.BiInt2ObjectMap
Return the number of unique entries in the map.
size() - Method in class org.agrona.collections.Int2IntCounterMap
The current size of the map which at not at Int2IntCounterMap.initialValue().
size() - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
size() - Method in class org.agrona.collections.Int2IntHashMap.KeySet
size() - Method in class org.agrona.collections.Int2IntHashMap
size() - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
size() - Method in class org.agrona.collections.Int2ObjectCache.EntrySet
 
size() - Method in class org.agrona.collections.Int2ObjectCache.KeySet
 
size() - Method in class org.agrona.collections.Int2ObjectCache
size() - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
 
size() - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
 
size() - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
size() - Method in class org.agrona.collections.Int2ObjectHashMap
size() - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
 
size() - Method in class org.agrona.collections.IntArrayList
 
size() - Method in class org.agrona.collections.IntHashSet
size() - Method in class org.agrona.collections.Long2LongCounterMap
The current size of the map which at not at Long2LongCounterMap.initialValue().
size() - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
size() - Method in class org.agrona.collections.Long2LongHashMap.KeySet
size() - Method in class org.agrona.collections.Long2LongHashMap
size() - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
size() - Method in class org.agrona.collections.Long2ObjectCache.EntrySet
 
size() - Method in class org.agrona.collections.Long2ObjectCache.KeySet
 
size() - Method in class org.agrona.collections.Long2ObjectCache
size() - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
 
size() - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
 
size() - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
size() - Method in class org.agrona.collections.Long2ObjectHashMap
size() - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
 
size() - Method in class org.agrona.collections.LongArrayList
 
size() - Method in class org.agrona.collections.LongHashSet
size() - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
 
size() - Method in class org.agrona.collections.Object2IntHashMap.KeySet
 
size() - Method in class org.agrona.collections.Object2IntHashMap
size() - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
 
size() - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
 
size() - Method in class org.agrona.collections.Object2LongHashMap.KeySet
 
size() - Method in class org.agrona.collections.Object2LongHashMap
size() - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
 
size() - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
size() - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
size() - Method in class org.agrona.collections.Object2ObjectHashMap
size() - Method in class org.agrona.collections.Object2ObjectHashMap.ValueCollection
size() - Method in class org.agrona.collections.ObjectHashSet
size() - Method in class org.agrona.collections.UnmodifiableCollectionView
size() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
size() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
Size can be considered an approximation on a moving list.
size() - Method in interface org.agrona.concurrent.Pipe
The number of items currently in the container.
size() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Size of the buffer backlog in bytes between producers and consumers.
size() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Size of the buffer backlog in bytes between producers and consumers.
size() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Size of the buffer backlog in bytes between producers and consumers.
size() - Method in class org.agrona.nio.NioSelectedKeySet
SIZE_OF_BOOLEAN - Static variable in class org.agrona.BitUtil
Size of a boolean in bytes
SIZE_OF_BYTE - Static variable in class org.agrona.BitUtil
Size of a byte in bytes
SIZE_OF_CHAR - Static variable in class org.agrona.BitUtil
Size of a char in bytes
SIZE_OF_DOUBLE - Static variable in class org.agrona.BitUtil
Size of a double in bytes
SIZE_OF_FLOAT - Static variable in class org.agrona.BitUtil
Size of a float in bytes
SIZE_OF_INT - Static variable in class org.agrona.BitUtil
Size of an int in bytes
SIZE_OF_LONG - Static variable in class org.agrona.BitUtil
Size of a long in bytes
SIZE_OF_SHORT - Static variable in class org.agrona.BitUtil
Size of a short in bytes
skip(long) - Method in class org.agrona.io.DirectBufferInputStream
 
SleepingIdleStrategy - Class in org.agrona.concurrent
When idle this strategy is to sleep for a specified period in nanoseconds.
SleepingIdleStrategy(long) - Constructor for class org.agrona.concurrent.SleepingIdleStrategy
Constructed a new strategy that will sleep for a given period when idle.
SleepingMillisIdleStrategy - Class in org.agrona.concurrent
When idle this strategy is to sleep for a specified period time in milliseconds.
SleepingMillisIdleStrategy(long) - Constructor for class org.agrona.concurrent.SleepingMillisIdleStrategy
Constructed a new strategy that will sleep for a given period when idle.
start() - Method in class org.agrona.concurrent.AgentInvoker
Mark the invoker as started and call the Agent.onStart() method.
startOnThread(AgentRunner) - Static method in class org.agrona.concurrent.AgentRunner
Start the given agent runner on a new thread.
startOnThread(AgentRunner, ThreadFactory) - Static method in class org.agrona.concurrent.AgentRunner
Start the given agent runner on a new thread.
status() - Method in class org.agrona.concurrent.DynamicCompositeAgent
Get the DynamicCompositeAgent.Status for the Agent.
StatusIndicator - Class in org.agrona.concurrent.status
 
StatusIndicator() - Constructor for class org.agrona.concurrent.status.StatusIndicator
 
StatusIndicatorReader - Class in org.agrona.concurrent.status
 
StatusIndicatorReader() - Constructor for class org.agrona.concurrent.status.StatusIndicatorReader
 
Strings - Class in org.agrona
Utility functions for using Strings.
Strings() - Constructor for class org.agrona.Strings
 
StringWriterOutputManager - Class in org.agrona.generation
 
StringWriterOutputManager() - Constructor for class org.agrona.generation.StringWriterOutputManager
 
subSequence(int, int) - Method in class org.agrona.AsciiSequenceView
substitute(String) - Method in class org.agrona.generation.PrimitiveExpander.Substitution
 
sum(List<V>, ToIntFunction<V>) - Static method in class org.agrona.collections.CollectionUtil
Garbage free sum function.
SystemEpochClock - Class in org.agrona.concurrent
Implementation that calls System.currentTimeMillis().
SystemEpochClock() - Constructor for class org.agrona.concurrent.SystemEpochClock
 
SystemEpochMicroClock - Class in org.agrona.concurrent
Implementation that calls HighResolutionClock.epochMicros().
SystemEpochMicroClock() - Constructor for class org.agrona.concurrent.SystemEpochMicroClock
 
SystemEpochNanoClock - Class in org.agrona.concurrent
Implementation that calls HighResolutionClock.epochNanos().
SystemEpochNanoClock() - Constructor for class org.agrona.concurrent.SystemEpochNanoClock
 
SystemNanoClock - Class in org.agrona.concurrent
A NanoClock the delegates to System.nanoTime().
SystemNanoClock() - Constructor for class org.agrona.concurrent.SystemNanoClock
 
SystemUtil - Class in org.agrona
Utilities for inspecting the system.
SystemUtil() - Constructor for class org.agrona.SystemUtil
 

T

TAIL_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Offset within the trailer for where the tail value is stored.
TAIL_INTENT_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Offset within the trailer for where the tail intended value is stored.
TAIL_OFFSET - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
TAIL_POSITION_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the tail value is stored.
thread() - Method in class org.agrona.concurrent.AgentRunner
Get the thread which is running that Agent.
ThreadHints - Class in org.agrona.hints
This class captures possible hints that may be used by some runtimes to improve code performance.
throwable - Variable in class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
tickResolution() - Method in class org.agrona.DeadlineTimerWheel
Resolution of a tick of the wheel in DeadlineTimerWheel.timeUnit()s.
time() - Method in class org.agrona.concurrent.CachedEpochClock
 
time() - Method in interface org.agrona.concurrent.EpochClock
Time in milliseconds since 1 Jan 1970 UTC.
time() - Method in class org.agrona.concurrent.SystemEpochClock
 
timeOfLastStateChange(long) - Method in interface org.agrona.ManagedResource
Set the time of the last state change.
timeOfLastStateChange() - Method in interface org.agrona.ManagedResource
Get the time of the last state change.
timerCount() - Method in class org.agrona.DeadlineTimerWheel
Number of active timers.
timestampOrdered(long) - Method in class org.agrona.MarkFile
 
timestampVolatile() - Method in class org.agrona.MarkFile
 
timestampWeak() - Method in class org.agrona.MarkFile
 
timeUnit() - Method in class org.agrona.DeadlineTimerWheel
Time unit for the time values.
tmpDirName() - Static method in class org.agrona.IoUtil
Return the system property for java.io.tmpdir ensuring a File.separator is at the end.
toArray(T[]) - Method in class org.agrona.collections.IntHashSet
toArray() - Method in class org.agrona.collections.IntHashSet
toArray(T[]) - Method in class org.agrona.collections.LongHashSet
toArray() - Method in class org.agrona.collections.LongHashSet
toArray() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
toArray(T[]) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
 
toArray() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
toArray(T[]) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
toHex(byte[], int, int) - Static method in class org.agrona.BitUtil
Generate a string that is the hex representation of a given byte array.
toHex(byte[]) - Static method in class org.agrona.BitUtil
Generate a string that is the hex representation of a given byte array.
toHexByteArray(byte[]) - Static method in class org.agrona.BitUtil
Generate a byte array that is a hex representation of a given byte array.
toHexByteArray(byte[], int, int) - Static method in class org.agrona.BitUtil
Generate a byte array that is a hex representation of a given byte array.
toIntArray() - Method in class org.agrona.collections.IntArrayList
Create a new array that is a copy of the elements.
toIntArray(int[]) - Method in class org.agrona.collections.IntArrayList
Create a new array that is a copy of the elements.
toLongArray() - Method in class org.agrona.collections.LongArrayList
Create a new array that is a copy of the elements.
toLongArray(long[]) - Method in class org.agrona.collections.LongArrayList
Create a new array that is a copy of the elements.
TOMBSTONE - Static variable in class org.agrona.concurrent.AgentRunner
Indicates that the runner is being closed.
toString() - Method in class org.agrona.AsciiSequenceView
 
toString() - Method in class org.agrona.collections.BiInt2ObjectMap
 
toString() - Method in class org.agrona.collections.Int2IntCounterMap
toString() - Method in class org.agrona.collections.Int2IntHashMap
toString() - Method in class org.agrona.collections.Int2ObjectCache
toString() - Method in class org.agrona.collections.Int2ObjectHashMap
toString() - Method in class org.agrona.collections.IntArrayList
toString() - Method in class org.agrona.collections.IntHashSet
toString() - Method in class org.agrona.collections.Long2LongCounterMap
toString() - Method in class org.agrona.collections.Long2LongHashMap
toString() - Method in class org.agrona.collections.Long2ObjectCache
toString() - Method in class org.agrona.collections.Long2ObjectHashMap
toString() - Method in class org.agrona.collections.LongArrayList
toString() - Method in class org.agrona.collections.LongHashSet
toString() - Method in class org.agrona.collections.MutableBoolean
 
toString() - Method in class org.agrona.collections.MutableInteger
 
toString() - Method in class org.agrona.collections.MutableLong
 
toString() - Method in class org.agrona.collections.MutableReference
 
toString() - Method in class org.agrona.collections.Object2IntHashMap
toString() - Method in class org.agrona.collections.Object2LongHashMap
toString() - Method in class org.agrona.collections.Object2ObjectHashMap
toString() - Method in class org.agrona.collections.ObjectHashSet
toString() - Method in class org.agrona.concurrent.BackoffIdleStrategy
 
toString() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
 
toString() - Method in class org.agrona.concurrent.ControllableIdleStrategy
 
toString() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
toString() - Method in class org.agrona.concurrent.NoOpIdleStrategy
 
toString() - Method in class org.agrona.concurrent.SleepingIdleStrategy
 
toString() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
 
toString() - Method in class org.agrona.concurrent.UnsafeBuffer
 
toString() - Method in class org.agrona.concurrent.YieldingIdleStrategy
 
toString() - Method in class org.agrona.ExpandableArrayBuffer
 
toString() - Method in class org.agrona.ExpandableDirectByteBuffer
 
TRAILER_LENGTH - Static variable in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Total size of the trailer
TRAILER_LENGTH - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Total length of the trailer in bytes.
transmit(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
Transmit a message to BroadcastReceivers via the broadcast buffer.
TransportPoller - Class in org.agrona.nio
Implements the common functionality for a transport poller.
TransportPoller() - Constructor for class org.agrona.nio.TransportPoller
 
trimToSize() - Method in class org.agrona.collections.IntArrayList
Trim the underlying array to be the current size, or IntArrayList.INITIAL_CAPACITY if size is less.
trimToSize() - Method in class org.agrona.collections.LongArrayList
Trim the underlying array to be the current size, or LongArrayList.INITIAL_CAPACITY if size is less.
tryAdd(Agent) - Method in class org.agrona.concurrent.DynamicCompositeAgent
Try and add a new Agent to the composite.
tryLock() - Method in class org.agrona.concurrent.NoOpLock
Always succeeds.
tryLock(long, TimeUnit) - Method in class org.agrona.concurrent.NoOpLock
Always succeeds.
tryRemove(Agent) - Method in class org.agrona.concurrent.DynamicCompositeAgent
Try and remove an Agent from the composite.
TYPE_ID_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the type id field is stored.
TYPE_OFFSET - Static variable in class org.agrona.concurrent.broadcast.RecordDescriptor
Offset within the record at which the message type field begins.
typeId() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Type of the message received.
typeOffset(int) - Static method in class org.agrona.concurrent.broadcast.RecordDescriptor
The buffer offset at which the message type field begins.
typeOffset(int) - Static method in class org.agrona.concurrent.ringbuffer.RecordDescriptor
The offset from the beginning of a record at which the message type field begins.

U

unblock() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Unblock a multi-producer ring buffer when a producer has died during the act of offering.
unblock() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Unblock a multi-producer ring buffer when a producer has died during the act of offering.
unblock() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Unblock a multi-producer ring buffer when a producer has died during the act of offering.
UNKNOWN_INDEX - Static variable in class org.agrona.collections.ArrayUtil
 
unlock() - Method in class org.agrona.concurrent.NoOpLock
The lock has never been taken so no effect.
unmap(MappedByteBuffer) - Static method in class org.agrona.IoUtil
Unmap a MappedByteBuffer without waiting for the next GC cycle.
unmap(FileChannel, long, long) - Static method in class org.agrona.IoUtil
Unmap a region of a file.
unmap(ByteBuffer) - Static method in class org.agrona.IoUtil
Unmap a ByteBuffer without waiting for the next GC cycle if its memory mapped.
unmapNullValue(Object) - Method in class org.agrona.collections.Int2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Long2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Object2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
 
UnmodifiableCollectionView<V,E> - Class in org.agrona.collections
An unmodifiable view of a collection that maps each element in an underlying collection into a view.
UnmodifiableCollectionView(Function<E, V>, Collection<E>) - Constructor for class org.agrona.collections.UnmodifiableCollectionView
 
UnmodifiableCollectionView.ReusableIterator - Class in org.agrona.collections
 
UNSAFE - Static variable in class org.agrona.UnsafeAccess
 
UnsafeAccess - Class in org.agrona
Obtain access the the Unsafe class for direct memory operations.
UnsafeAccess() - Constructor for class org.agrona.UnsafeAccess
 
UnsafeBuffer - Class in org.agrona.concurrent
Supports regular, byte ordered, and atomic (memory ordered) access to an underlying buffer.
UnsafeBuffer() - Constructor for class org.agrona.concurrent.UnsafeBuffer
Empty constructor for a reusable wrapper buffer.
UnsafeBuffer(byte[]) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to a byte[] for providing direct access.
UnsafeBuffer(byte[], int, int) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to a byte[] for providing direct access.
UnsafeBuffer(ByteBuffer) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
UnsafeBuffer(ByteBuffer, int, int) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
UnsafeBuffer(DirectBuffer) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to an existing DirectBuffer
UnsafeBuffer(DirectBuffer, int, int) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to an existing DirectBuffer
UnsafeBuffer(long, int) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to an off-heap memory region by address.
UnsafeBufferPosition - Class in org.agrona.concurrent.status
Reports a position by recording it in an UnsafeBuffer.
UnsafeBufferPosition(UnsafeBuffer, int) - Constructor for class org.agrona.concurrent.status.UnsafeBufferPosition
Map a position over a buffer.
UnsafeBufferPosition(UnsafeBuffer, int, CountersManager) - Constructor for class org.agrona.concurrent.status.UnsafeBufferPosition
Map a position over a buffer and this indicator owns the counter for reclamation.
UnsafeBufferStatusIndicator - Class in org.agrona.concurrent.status
 
UnsafeBufferStatusIndicator(AtomicBuffer, int) - Constructor for class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
Map a status indicator over a buffer.
update(long) - Method in class org.agrona.concurrent.CachedEpochClock
Update the value of the timestamp in with ordered semantics.
update(long) - Method in class org.agrona.concurrent.CachedNanoClock
Update the value of the timestamp with memory ordered semantics.
updateWeak(long) - Method in class org.agrona.concurrent.CachedEpochClock
Update the value of the timestamp in with weak ordering semantics.
updateWeak(long) - Method in class org.agrona.concurrent.CachedNanoClock
Update the value of the timestamp in with weak ordering semantics.

V

validate() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Validate that the current received record is still valid and has not been overwritten.
validateLoadFactor(float) - Static method in class org.agrona.collections.CollectionUtil
Validate that a load factor is in the range of 0.1 to 0.9.
validatePositivePowerOfTwo(int) - Static method in class org.agrona.collections.CollectionUtil
Validate that a number is a power of two.
value - Variable in class org.agrona.collections.MutableBoolean
For convenient access.
value - Variable in class org.agrona.collections.MutableInteger
 
value - Variable in class org.agrona.collections.MutableLong
 
ValueCollection() - Constructor for class org.agrona.collections.Int2IntHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Int2ObjectCache.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Int2ObjectHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Long2LongHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Long2ObjectCache.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Long2ObjectHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Object2IntHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Object2LongHashMap.ValueCollection
 
ValueCollection() - Constructor for class org.agrona.collections.Object2ObjectHashMap.ValueCollection
 
ValueIterator() - Constructor for class org.agrona.collections.Int2IntHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Int2ObjectCache.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Int2ObjectHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Long2LongHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Long2ObjectCache.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Long2ObjectHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Object2IntHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Object2LongHashMap.ValueIterator
 
ValueIterator() - Constructor for class org.agrona.collections.Object2ObjectHashMap.ValueIterator
 
valueOf(String) - Static method in enum org.agrona.concurrent.DynamicCompositeAgent.Status
Returns the enum constant of this type with the specified name.
values() - Method in class org.agrona.collections.Int2IntHashMap
values() - Method in class org.agrona.collections.Int2ObjectCache
values() - Method in class org.agrona.collections.Int2ObjectHashMap
values() - Method in class org.agrona.collections.Long2LongHashMap
values() - Method in class org.agrona.collections.Long2ObjectCache
values() - Method in class org.agrona.collections.Long2ObjectHashMap
values() - Method in class org.agrona.collections.Object2IntHashMap
values() - Method in class org.agrona.collections.Object2LongHashMap
values() - Method in class org.agrona.collections.Object2ObjectHashMap
values() - Static method in enum org.agrona.concurrent.DynamicCompositeAgent.Status
Returns an array containing the constants of this enum type, in the order they are declared.
valuesBuffer - Variable in class org.agrona.concurrent.status.CountersReader
 
valuesBuffer() - Method in class org.agrona.concurrent.status.CountersReader
Get the buffer containing the values for the counters.
Verify - Class in org.agrona
Various verification checks to be applied in code.
Verify() - Constructor for class org.agrona.Verify
 
verifyAlignment() - Method in interface org.agrona.concurrent.AtomicBuffer
Verify that the underlying buffer is correctly aligned to prevent word tearing and other ordering issues.
verifyAlignment() - Method in class org.agrona.concurrent.MappedResizeableBuffer
 
verifyAlignment() - Method in class org.agrona.concurrent.UnsafeBuffer
 
verifyNull(Object, String) - Static method in class org.agrona.Verify
Verify that a reference is null.
versionVolatile() - Method in class org.agrona.MarkFile
 
versionWeak() - Method in class org.agrona.MarkFile
 

W

waitForFileMapping(Consumer<String>, File, long, EpochClock) - Static method in class org.agrona.MarkFile
 
withOutput(String, ResourceConsumer<Writer>) - Method in interface org.agrona.generation.OutputManager
 
withRecord(int, RecordBuffer.RecordWriter) - Method in class org.agrona.concurrent.RecordBuffer
High level and safe way of writing a record to the buffer.
wrap(DirectBuffer, int, int) - Method in class org.agrona.AsciiSequenceView
Wrap a range of an existing buffer containing an ASCII sequence.
wrap(int[], int) - Method in class org.agrona.collections.IntArrayList
Wrap an existing array without copying it.
wrap(long[], int) - Method in class org.agrona.collections.LongArrayList
Wrap an existing array without copying it.
wrap(long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
Remap the buffer using the existing file based on a new offset and length
wrap(FileChannel, long, long) - Method in class org.agrona.concurrent.MappedResizeableBuffer
Remap the buffer based on a new file, offset and a length
wrap(byte[]) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(byte[], int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(ByteBuffer) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(ByteBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(DirectBuffer) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(DirectBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(long, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrap(byte[]) - Method in interface org.agrona.DirectBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[], int, int) - Method in interface org.agrona.DirectBuffer
Attach a view to a byte[] for providing direct access.
wrap(ByteBuffer) - Method in interface org.agrona.DirectBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
wrap(ByteBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Attach a view to a ByteBuffer for providing direct access.
wrap(DirectBuffer) - Method in interface org.agrona.DirectBuffer
Attach a view to an existing DirectBuffer
wrap(DirectBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Attach a view to a DirectBuffer for providing direct access.
wrap(long, int) - Method in interface org.agrona.DirectBuffer
Attach a view to an off-heap memory region by address.
wrap(byte[]) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(byte[], int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(ByteBuffer) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(ByteBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(DirectBuffer) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(DirectBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(long, int) - Method in class org.agrona.ExpandableArrayBuffer
 
wrap(byte[]) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(byte[], int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(ByteBuffer) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(ByteBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(DirectBuffer) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(DirectBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(long, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
wrap(DirectBuffer) - Method in class org.agrona.io.DirectBufferInputStream
 
wrap(DirectBuffer, int, int) - Method in class org.agrona.io.DirectBufferInputStream
 
wrap(MutableDirectBuffer) - Method in class org.agrona.io.DirectBufferOutputStream
 
wrap(MutableDirectBuffer, int, int) - Method in class org.agrona.io.DirectBufferOutputStream
 
wrap(MutableDirectBuffer) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Wrap a given buffer beginning with an offset of 0.
wrap(MutableDirectBuffer, int) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Wrap a given buffer beginning at an offset.
wrap(DirectBuffer, int) - Method in interface org.agrona.sbe.CompositeDecoderFlyweight
Wrap a buffer for decoding at a given offset.
wrap(MutableDirectBuffer, int) - Method in interface org.agrona.sbe.EncoderFlyweight
Wrap a buffer for encoding at a given offset.
wrap(DirectBuffer, int, int, int) - Method in interface org.agrona.sbe.MessageDecoderFlyweight
Wrap a buffer containing an encoded message for decoding.
wrapAdjustment() - Method in class org.agrona.concurrent.UnsafeBuffer
 
wrapAdjustment() - Method in interface org.agrona.DirectBuffer
Get the adjustment in indices between an index in this buffer and the wrapped object.
wrapAdjustment() - Method in class org.agrona.ExpandableArrayBuffer
 
wrapAdjustment() - Method in class org.agrona.ExpandableDirectByteBuffer
 
write(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Non-blocking write of an message to an underlying ring-buffer.
write(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Non-blocking write of an message to an underlying ring-buffer.
write(int, DirectBuffer, int, int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Non-blocking write of an message to an underlying ring-buffer.
write(int) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte to buffer.
write(byte[], int, int) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte[] to the buffer.
write(byte[]) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte[] to the buffer.
write(int) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Write a byte to buffer.
write(byte[], int, int) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Write a byte[] to the buffer.
writeRecord(int) - Method in interface org.agrona.concurrent.RecordBuffer.RecordWriter
Write an updated record within this callback.

Y

YIELD - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
YieldingIdleStrategy - Class in org.agrona.concurrent
IdleStrategy that will call Thread.yield() when the work count is zero.
YieldingIdleStrategy() - Constructor for class org.agrona.concurrent.YieldingIdleStrategy
 

Z

ZERO - Static variable in class org.agrona.AsciiEncoding
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
Skip navigation links

Copyright © 2014-2019 Real Logic Ltd. All Rights Reserved.