Index

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 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form

A

abort(int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Abort claim and allow consumer to proceed after the claimed length.
abort(int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Abort claim and allow consumer to proceed after the claimed length.
abort(int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Abort claim and allow consumer to proceed after the claimed length.
ABORT - Enum constant in enum class org.agrona.concurrent.ControlledMessageHandler.Action
Abort the current read operation and do not advance the position for this message.
AbstractConcurrentArrayQueue<E> - Class in org.agrona.concurrent
Left over immutable queue fields.
AbstractConcurrentArrayQueue(int) - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueue
Constructs a queue with the requested capacity.
AbstractConcurrentArrayQueueConsumer - Class in org.agrona.concurrent
Values for the consumer that are expected to be padded.
AbstractConcurrentArrayQueueConsumer() - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueueConsumer
 
AbstractConcurrentArrayQueuePadding1 - Class in org.agrona.concurrent
Pad out a cacheline to the left of a producer fields to prevent false sharing.
AbstractConcurrentArrayQueuePadding1() - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
AbstractConcurrentArrayQueuePadding2 - Class in org.agrona.concurrent
Pad out a cacheline between the producer and consumer fields to prevent false sharing.
AbstractConcurrentArrayQueuePadding2() - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
AbstractConcurrentArrayQueuePadding3 - Class in org.agrona.concurrent
Pad out a cacheline between the producer and consumer fields to prevent false sharing.
AbstractConcurrentArrayQueuePadding3() - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
AbstractConcurrentArrayQueueProducer - Class in org.agrona.concurrent
Value for the producer that are expected to be padded.
AbstractConcurrentArrayQueueProducer() - Constructor for class org.agrona.concurrent.AbstractConcurrentArrayQueueProducer
 
AbstractIterator() - Constructor for class org.agrona.collections.Int2IntHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Int2ObjectCache.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Long2LongHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Long2ObjectCache.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
AbstractIterator() - Constructor for class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
AbstractMutableDirectBuffer - Class in org.agrona
Common super class for implementing MutableDirectBuffer interface.
AbstractMutableDirectBuffer() - Constructor for class org.agrona.AbstractMutableDirectBuffer
 
AbstractSnowflakeIdGeneratorPaddingLhs - Class in org.agrona.concurrent
 
AbstractSnowflakeIdGeneratorPaddingLhs() - Constructor for class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
AbstractSnowflakeIdGeneratorPaddingRhs - Class in org.agrona.concurrent
 
AbstractSnowflakeIdGeneratorPaddingRhs() - Constructor for class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
AbstractSnowflakeIdGeneratorValue - Class in org.agrona.concurrent
 
AbstractSnowflakeIdGeneratorValue() - Constructor for class org.agrona.concurrent.AbstractSnowflakeIdGeneratorValue
 
accept(int, int) - Method in interface org.agrona.collections.IntIntConsumer
Accept two values that comes as a tuple of ints.
accept(int, int, DirectBuffer, String) - Method in interface org.agrona.concurrent.status.CountersReader.MetaData
Accept a metadata record.
accept(int, int, V) - Method in interface org.agrona.collections.BiInt2ObjectMap.EntryConsumer
A map entry
accept(int, long, long, String) - Method in interface org.agrona.concurrent.errors.ErrorConsumer
Callback for accepting errors encountered in the log.
accept(int, T) - Method in interface org.agrona.collections.IntObjConsumer
 
accept(long, int, String) - Method in interface org.agrona.concurrent.status.CountersReader.CounterConsumer
Accept the value for a counter.
accept(long, long) - Method in interface org.agrona.collections.LongLongConsumer
Accept two values that comes as a tuple of longs.
accept(long, long) - Method in interface org.agrona.DeadlineTimerWheel.TimerConsumer
Called for each timer in the Timer Wheel.
accept(long, T) - Method in interface org.agrona.collections.LongObjConsumer
 
accept(T) - Method in interface org.agrona.generation.ResourceConsumer
Accept a resource to be consumed.
accept(T, int) - Method in interface org.agrona.collections.ObjIntConsumer
 
accept(T, long) - Method in interface org.agrona.collections.ObjLongConsumer
 
acquireFence() - Static method in class org.agrona.concurrent.MemoryAccess
Ensures that loads before the fence will not be reordered with loads and stores after the fence.
Action() - Constructor for enum class org.agrona.concurrent.ControlledMessageHandler.Action
 
ACTIVE - Enum constant in enum class org.agrona.concurrent.DynamicCompositeAgent.Status
Agent is not active after a successful DynamicCompositeAgent.onStart()
add(int) - Method in class org.agrona.collections.IntHashSet
Primitive specialised overload of {this#add(Integer)}.
add(int, Integer) - Method in class org.agrona.collections.IntArrayList
add(int, Long) - Method in class org.agrona.collections.LongArrayList
add(long) - Method in class org.agrona.collections.LongHashSet
Primitive specialised overload of {this#add(Long)}.
add(E) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
add(E) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
add(Integer) - Method in class org.agrona.collections.IntArrayList
add(Integer) - Method in class org.agrona.collections.IntArrayQueue
add(Integer) - Method in class org.agrona.collections.IntHashSet
add(Long) - Method in class org.agrona.collections.LongArrayList
add(Long) - Method in class org.agrona.collections.LongArrayQueue
add(Long) - Method in class org.agrona.collections.LongHashSet
add(Agent) - Method in class org.agrona.concurrent.DynamicCompositeAgent
 
add(T) - Method in class org.agrona.collections.ObjectHashSet
 
add(T[], T) - Static method in class org.agrona.collections.ArrayUtil
Add an element to an array resulting in a new array.
addAgent - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
addAll(int, IntArrayList) - Method in class org.agrona.collections.IntArrayList
Inserts all the elements from the specified list to this list at the specified position.
addAll(int, LongArrayList) - Method in class org.agrona.collections.LongArrayList
Inserts all the elements from the specified list to this list at the specified position.
addAll(Collection<? extends E>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
addAll(Collection<? extends E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
addAll(Collection<? extends Integer>) - Method in class org.agrona.collections.IntHashSet
addAll(Collection<? extends Long>) - Method in class org.agrona.collections.LongHashSet
addAll(Collection<? extends T>) - Method in class org.agrona.collections.ObjectHashSet
addAll(IntArrayList) - Method in class org.agrona.collections.IntArrayList
Appends all the elements in the specified list to the end of this list, in the order that they are stored in the specified list.
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(LongArrayList) - Method in class org.agrona.collections.LongArrayList
Appends all the elements in the specified list to the end of this list, in the order that they are stored in the specified list.
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(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
addAndGet(int) - Method in class org.agrona.collections.MutableInteger
Add the delta and get the value.
addAndGet(int, int) - Method in class org.agrona.collections.Int2IntCounterMap
Add amount to the current value associated with this key.
addAndGet(long) - Method in class org.agrona.collections.MutableLong
Add the delta and get the value.
addAndGet(long, long) - Method in class org.agrona.collections.Long2LongCounterMap
Add amount to the current value associated with this key.
addAndGet(K, int) - Method in class org.agrona.collections.Object2IntCounterMap
Add amount to the current value associated with this key.
addAndGet(K, long) - Method in class org.agrona.collections.Object2LongCounterMap
Add amount to the current value associated with this key.
addedCount() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
The number of items added to this container since creation.
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) - Method in class org.agrona.collections.IntArrayQueue
Offer an element to the tail of the queue without boxing.
addInt(int, int) - Method in class org.agrona.collections.IntArrayList
Add an 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(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Add a value to a given index with ordered store semantics.
addLong(int, long) - Method in class org.agrona.collections.LongArrayList
Add an element without boxing at a given index.
addLong(long) - Method in class org.agrona.collections.LongArrayList
Add an element without boxing.
addLong(long) - Method in class org.agrona.collections.LongArrayQueue
Offer an element to the tail of the queue without boxing.
addLongOrdered(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Add a value to a given index with ordered store semantics.
addLongOrdered(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Add a value to a given index with ordered store semantics.
address(ByteBuffer) - Static method in class org.agrona.BufferUtil
Get the address at which the underlying buffer storage begins.
addressOffset - Variable in class org.agrona.AbstractMutableDirectBuffer
 
addressOffset - Variable in exception class org.agrona.agent.BufferAlignmentException
 
addressOffset - Variable in class org.agrona.concurrent.status.AtomicCounter
 
addressOffset - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
addressOffset - Variable in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
addressOffset() - Method in class org.agrona.AbstractMutableDirectBuffer
Reads the underlying offset to the memory address.
addressOffset() - Method in exception class org.agrona.agent.BufferAlignmentException
Returns an address offset into the start of the underlying buffer.
addressOffset() - Method in interface org.agrona.DirectBuffer
Reads the underlying offset to the memory address.
advance(long) - Method in class org.agrona.concurrent.CachedEpochClock
Advance the value of the timestamp in with release ordered semantics.
advance(long) - Method in class org.agrona.concurrent.CachedNanoClock
Advance the value of the timestamp in with release ordered semantics.
agent - Variable in class org.agrona.concurrent.AgentInvoker
 
agent - Variable in class org.agrona.concurrent.AgentRunner
 
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.
agent(boolean, Instrumentation) - Static method in class org.agrona.agent.BufferAlignmentAgent
 
Agent - Interface in org.agrona.concurrent
An Agent is scheduled to do work on a thread on a duty cycle.
AgentBuilderListener() - Constructor for class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
agentIndex - Variable in class org.agrona.concurrent.CompositeAgent
 
agentIndex - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
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.
agentmain(String, Instrumentation) - Static method in class org.agrona.agent.BufferAlignmentAgent
Invoked when the agent is attached to an already running application.
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.
agents - Variable in class org.agrona.concurrent.CompositeAgent
 
agents - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
AgentTerminationException - Exception Class in org.agrona.concurrent
Thrown to terminate the work/duty cycle of an Agent.
AgentTerminationException() - Constructor for exception class org.agrona.concurrent.AgentTerminationException
Default constructor.
AgentTerminationException(String) - Constructor for exception class org.agrona.concurrent.AgentTerminationException
Create an exception with the given message.
AgentTerminationException(String, Throwable) - Constructor for exception class org.agrona.concurrent.AgentTerminationException
Create an exception with the given message and a cause.
AgentTerminationException(String, Throwable, boolean, boolean) - Constructor for exception class org.agrona.concurrent.AgentTerminationException
Create an exception with the given message and a cause.
AgentTerminationException(Throwable) - Constructor for exception class org.agrona.concurrent.AgentTerminationException
Create an exception with the given cause.
alias() - Method in class org.agrona.concurrent.BackoffIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.ControllableIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in interface org.agrona.concurrent.IdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.NoOpIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.SleepingIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
Simple name by which the strategy can be identified.
alias() - Method in class org.agrona.concurrent.YieldingIdleStrategy
Simple name by which the strategy can be identified.
ALIAS - Static variable in class org.agrona.concurrent.BackoffIdleStrategy
Name to be returned from BackoffIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.BusySpinIdleStrategy
Name to be returned from BusySpinIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
Name to be returned from ControllableIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.NoOpIdleStrategy
Name to be returned from NoOpIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.SleepingIdleStrategy
Name to be returned from SleepingIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.SleepingMillisIdleStrategy
Name to be returned from SleepingMillisIdleStrategy.alias().
ALIAS - Static variable in class org.agrona.concurrent.YieldingIdleStrategy
Name to be returned from YieldingIdleStrategy.alias().
align(int, int) - Static method in class org.agrona.BitUtil
Align a value to the next multiple up of alignment.
align(long, long) - Static method in class org.agrona.BitUtil
Align a value to the next multiple up of alignment.
ALIGNMENT - Static variable in interface org.agrona.concurrent.AtomicBuffer
Buffer alignment in bytes to ensure atomic word accesses.
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
 
alignmentTransformer - Static variable in class org.agrona.agent.BufferAlignmentAgent
 
allocate(int, DirectBuffer, int, int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Allocate a counter with the minimum of allocation by allowing the label a key to be provided and copied.
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 a key to be provided and copied.
allocate(String) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a new counter with a given label with a default type of CountersReader.DEFAULT_TYPE_ID.
allocate(String, int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Allocate a new counter with a given label and type.
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.ConcurrentCountersManager
Allocate a new counter with a given label.
allocate(String, int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.CountersManager
Allocate a new counter with a given label.
allocateDirectAligned(int, int) - Static method in class org.agrona.BufferUtil
Allocate a new direct ByteBuffer that is aligned on a given alignment boundary.
allocateDuplicateEntry() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
 
allocateDuplicateEntry() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
 
allocationBitsToShift - Variable in class org.agrona.DeadlineTimerWheel
 
append(DirectBuffer, int, int) - Method in class org.agrona.ExpandableRingBuffer
Append a message into the ring buffer, expanding the buffer if required.
appendHexDumpRowPrefix(StringBuilder, int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
 
appendLabel(int, String) - Method in class org.agrona.concurrent.status.CountersManager
 
appendPrettyHexDump(StringBuilder, DirectBuffer) - Static method in class org.agrona.PrintBufferUtil
Appends the prettified multi-line hexadecimal dump of the specified DirectBuffer to the specified StringBuilder that is easy to read by humans.
appendPrettyHexDump(StringBuilder, DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil
Appends the prettified multi-line hexadecimal dump of the specified DirectBuffer to the specified StringBuilder that is easy to read by humans, starting at the given offset using the given length.
appendPrettyHexDump(StringBuilder, DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
 
appendTo(StringBuilder) - Method in interface org.agrona.sbe.MessageDecoderFlyweight
Populate the supplied StringBuilder with the string representation of the message.
appendToLabel(int, String) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter label based on counter id.
appendToLabel(int, String) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter label based on counter id.
appendToLabel(String) - Method in class org.agrona.concurrent.status.AtomicCounter
Append to the label for a counter constructed with a CountersManager.
apply(int, int) - Method in interface org.agrona.collections.BiInt2ObjectMap.EntryFunction
A map entry.
apply(int, int) - Method in interface org.agrona.collections.IntIntFunction
Accept two values that comes as a tuple of ints.
apply(int, int, V) - Method in interface org.agrona.collections.BiInt2ObjectMap.EntryRemap
A map entry.
apply(int, T) - Method in interface org.agrona.collections.IntObjectToObjectFunction
Applies this function to the given arguments.
apply(long, long) - Method in interface org.agrona.collections.LongLongFunction
Accept two values that comes as a tuple of longs.
apply(long, T) - Method in interface org.agrona.collections.LongObjectToObjectFunction
Applies this function to the given arguments.
apply(T, int) - Method in interface org.agrona.collections.ObjectIntToIntFunction
Applies this function to the given arguments.
apply(T, long) - Method in interface org.agrona.collections.ObjectLongToLongFunction
Applies this function to the given arguments.
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
Byte array base offset.
ARRAY_BYTE_BASE_OFFSET - Static variable in class org.agrona.UnsafeAccess
Byte array base offset.
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
 
ASCII_DIGITS - Static variable in class org.agrona.AsciiEncoding
Lookup table used for encoding ints/longs as ASCII characters.
AsciiEncoding - Class in org.agrona
Helper for dealing with ASCII encoding of numbers.
AsciiEncoding() - Constructor for class org.agrona.AsciiEncoding
 
AsciiNumberFormatException - Exception Class in org.agrona
Thrown when parsing an ASCII string and finding characters that are not digits.
AsciiNumberFormatException(String) - Constructor for exception class org.agrona.AsciiNumberFormatException
Create exception with a given message.
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
Default constructor.
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 which is useful for tests.
AtomicLongPosition() - Constructor for class org.agrona.concurrent.status.AtomicLongPosition
Default constructor.
AtomicLongPosition(int) - Constructor for class org.agrona.concurrent.status.AtomicLongPosition
Create a position with a given id and zero as an initial value.
AtomicLongPosition(int, long) - Constructor for class org.agrona.concurrent.status.AtomicLongPosition
Create a position with a given id and an initial value.
available() - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Number of counters available to be allocated which is a function of CountersManager.capacity() minus the number already allocated.
available() - Method in class org.agrona.concurrent.status.CountersManager
Number of counters available to be allocated which is a function of CountersManager.capacity() minus the number already allocated.
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() - Constructor for class org.agrona.concurrent.BackoffIdleStrategy
BackoffIdleStrategy(long, long, long, long) - Constructor for class org.agrona.concurrent.BackoffIdleStrategy
Create a set of state tracking idle behavior
BackoffIdleStrategyData - Class in org.agrona.concurrent
 
BackoffIdleStrategyData(long, long, long, long) - Constructor for class org.agrona.concurrent.BackoffIdleStrategyData
 
BackoffIdleStrategyPrePad - Class in org.agrona.concurrent
 
BackoffIdleStrategyPrePad() - Constructor for class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
baos - Variable in class org.agrona.generation.JavaClassObject
 
BiInt2NullableObjectMap<V> - Class in org.agrona.collections
Variation of BiInt2ObjectMap that allows null values.
BiInt2NullableObjectMap() - Constructor for class org.agrona.collections.BiInt2NullableObjectMap
Constructs map with default settings.
BiInt2NullableObjectMap(int, float) - Constructor for class org.agrona.collections.BiInt2NullableObjectMap
Constructs map with given initial capacity and load factory and enables caching of iterators.
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 a new value based upon keys.
BiInt2ObjectMap.EntryRemap<V,V1> - Interface in org.agrona.collections
Creates a new value 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(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Check that a given length of bytes is within the bounds from a given index.
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(ByteBuffer, long, int) - Static method in class org.agrona.BufferUtil
Bounds check the access range and throw a IndexOutOfBoundsException if exceeded.
boundsCheck0(int) - Method in class org.agrona.io.DirectBufferDataInput
 
boundsCheck0(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
boundsCheckWrap(int, int, int) - Static method in class org.agrona.concurrent.UnsafeBuffer
 
boundsCheckWrap(int, int, int) - Static method in class org.agrona.io.DirectBufferDataInput
 
boxedType - Variable in class org.agrona.generation.SpecialisationGenerator.Substitution
 
BREAK - Enum constant in enum class org.agrona.concurrent.ControlledMessageHandler.Action
Break from the current read operation and commit the position as of the end of the current message being handled.
BroadcastBufferDescriptor - Class in org.agrona.concurrent.broadcast
Layout of the broadcast buffer.
BroadcastBufferDescriptor() - Constructor for class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
 
broadcastReceiver() - Method in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Get the underlying BroadcastReceiver which this is wrapping and copying out of.
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.
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.AsciiSequenceView
 
buffer - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
Backing array.
buffer - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
buffer - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
buffer - Variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
buffer - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
buffer - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
buffer - Variable in class org.agrona.ExpandableRingBuffer
 
buffer - Variable in class org.agrona.io.DirectBufferDataInput
 
buffer - Variable in class org.agrona.io.DirectBufferInputStream
 
buffer - Variable in class org.agrona.io.DirectBufferOutputStream
 
buffer - Variable in class org.agrona.io.ExpandableDirectBufferOutputStream
 
buffer - Variable in class org.agrona.MarkFile
 
buffer() - Method in class org.agrona.AsciiSequenceView
Gets the underlying buffer which this is a view over.
buffer() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
The underlying buffer containing the broadcast message stream.
buffer() - Method in class org.agrona.concurrent.errors.DistinctErrorLog
Buffer the error log is written to.
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
Returns the underlying UnsafeBuffer.
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
Array base.
BufferAlignmentAgent - Class in org.agrona.agent
A Java agent that verifies that all memory accesses in DirectBuffer implementations are aligned.
BufferAlignmentAgent() - Constructor for class org.agrona.agent.BufferAlignmentAgent
 
BufferAlignmentAgent.AgentBuilderListener - Class in org.agrona.agent
 
BufferAlignmentException - Exception Class in org.agrona.agent
Runtime Exception thrown by BufferAlignmentAgent when an unaligned memory access is detected.
BufferAlignmentException(String, int, long) - Constructor for exception class org.agrona.agent.BufferAlignmentException
Create exception with details about the unaligned access.
BufferAlignmentInterceptor - Class in org.agrona.agent
Interceptor to be applied when verifying buffer alignment accesses.
BufferAlignmentInterceptor() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor
 
BufferAlignmentInterceptor.CharVerifier - Class in org.agrona.agent
Verifier for char types.
BufferAlignmentInterceptor.DoubleVerifier - Class in org.agrona.agent
Verifier for double types.
BufferAlignmentInterceptor.FloatVerifier - Class in org.agrona.agent
Verifier for float types.
BufferAlignmentInterceptor.IntVerifier - Class in org.agrona.agent
Verifier for int types.
BufferAlignmentInterceptor.LongVerifier - Class in org.agrona.agent
Verifier for long types.
BufferAlignmentInterceptor.ShortVerifier - Class in org.agrona.agent
Verifier for short types.
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
Offset of the java.nio.Buffer#address field.
BYTE_BUFFER_HB_FIELD_OFFSET - Static variable in class org.agrona.BufferUtil
Offset of the java.nio.ByteBuffer#hb field.
BYTE_BUFFER_OFFSET_FIELD_OFFSET - Static variable in class org.agrona.BufferUtil
Offset of the java.nio.ByteBuffer#offset field.
BYTE_PADDING - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
BYTE2CHAR - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
BYTE2HEX - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
BYTE2HEX_PAD - Static variable in class org.agrona.PrintBufferUtil
 
byteArray - Variable in class org.agrona.AbstractMutableDirectBuffer
 
byteArray - Variable in class org.agrona.concurrent.status.AtomicCounter
 
byteArray - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
byteArray - Variable in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
byteArray() - Method in class org.agrona.AbstractMutableDirectBuffer
Get the underlying byte[] if one exists.
byteArray() - Method in interface org.agrona.DirectBuffer
Get the underlying byte[] if one exists.
byteArray() - Method in class org.agrona.ExpandableDirectByteBuffer
Get the underlying byte[] if one exists.
byteBuffer - Variable in class org.agrona.concurrent.status.AtomicCounter
 
byteBuffer - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
byteBuffer - Variable in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
byteBuffer - Variable in class org.agrona.concurrent.UnsafeBuffer
 
byteBuffer - Variable in class org.agrona.ExpandableDirectByteBuffer
 
byteBuffer() - Method in class org.agrona.concurrent.UnsafeBuffer
Get the underlying ByteBuffer if one exists.
byteBuffer() - Method in interface org.agrona.DirectBuffer
Get the underlying ByteBuffer if one exists.
byteBuffer() - Method in class org.agrona.ExpandableArrayBuffer
Get the underlying ByteBuffer if one exists.
byteBuffer() - Method in class org.agrona.ExpandableDirectByteBuffer
Get the underlying ByteBuffer if one exists.
byteOrder - Variable in class org.agrona.io.DirectBufferDataInput
 
byteOrder(ByteOrder) - Method in class org.agrona.io.DirectBufferDataInput
Sets the byte order.
byteToHexStringPadded(int) - Static method in class org.agrona.PrintBufferUtil
Converts the specified byte value into a 2-digit hexadecimal integer.
byteValue() - Method in class org.agrona.collections.MutableInteger
Return value as byte.
byteValue() - Method in class org.agrona.collections.MutableLong
Return value as byte.

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
 
CachedEpochClockPadding - Class in org.agrona.concurrent
Pad out a cacheline to the left of a value to prevent false sharing.
CachedEpochClockPadding() - Constructor for class org.agrona.concurrent.CachedEpochClockPadding
 
CachedEpochClockValue - Class in org.agrona.concurrent
Value for the sequence that is expected to be padded.
CachedEpochClockValue() - Constructor for class org.agrona.concurrent.CachedEpochClockValue
 
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
 
CachedNanoClockPadding - Class in org.agrona.concurrent
Pad out a cacheline to the left of a value to prevent false sharing.
CachedNanoClockPadding() - Constructor for class org.agrona.concurrent.CachedNanoClockPadding
 
CachedNanoClockValue - Class in org.agrona.concurrent
Value for the sequence that is expected to be padded.
CachedNanoClockValue() - Constructor for class org.agrona.concurrent.CachedNanoClockValue
 
cacheHits - Variable in class org.agrona.collections.Int2ObjectCache
 
cacheHits - Variable in class org.agrona.collections.Long2ObjectCache
 
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 - Variable in class org.agrona.collections.Int2ObjectCache
 
cacheMisses - Variable in class org.agrona.collections.Long2ObjectCache
 
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 - Variable in class org.agrona.collections.Int2ObjectCache
 
cachePuts - Variable in class org.agrona.collections.Long2ObjectCache
 
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.
calculateExpansion(int, long) - Static method in class org.agrona.ExpandableArrayBuffer
 
calculateExpansion(int, long) - Static method in class org.agrona.ExpandableDirectByteBuffer
 
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 - Variable in class org.agrona.AbstractMutableDirectBuffer
 
capacity - Variable in class org.agrona.collections.Int2ObjectCache
 
capacity - Variable in class org.agrona.collections.IntLruCache
 
capacity - Variable in class org.agrona.collections.Long2ObjectCache
 
capacity - Variable in class org.agrona.collections.LongLruCache
 
capacity - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
Queue capacity.
capacity - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
capacity - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
capacity - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
capacity - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
capacity - Variable in class org.agrona.ExpandableRingBuffer
 
capacity() - Method in class org.agrona.AbstractMutableDirectBuffer
Get the capacity of the underlying buffer.
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.IntArrayList
The current capacity for the collection.
capacity() - Method in class org.agrona.collections.IntArrayQueue
The current capacity for the collection.
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
Returns cache capacity.
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.LongArrayList
The current capacity for the collection.
capacity() - Method in class org.agrona.collections.LongArrayQueue
The current capacity for the collection.
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
Returns cache capacity.
capacity() - Method in class org.agrona.collections.Object2IntCounterMap
Get the total capacity for the map to which the load factor will be a fraction of.
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.Object2LongCounterMap
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() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
The maximum capacity of this container to hold items.
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 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.status.CountersManager
Capacity as a count of counters which can be allocated.
capacity() - Method in interface org.agrona.DirectBuffer
Get the capacity of the underlying buffer.
capacity() - Method in class org.agrona.ExpandableRingBuffer
Current capacity of the ring buffer in bytes.
capacity(int) - Method in class org.agrona.collections.Int2IntCounterMap
 
capacity(int) - Method in class org.agrona.collections.Int2IntHashMap
 
capacity(int) - Method in class org.agrona.collections.Long2LongCounterMap
 
capacity(int) - Method in class org.agrona.collections.Long2LongHashMap
 
capacity(int) - Method in class org.agrona.collections.Object2ObjectHashMap
 
casTail(ManyToOneConcurrentLinkedQueuePadding1.Node<E>, ManyToOneConcurrentLinkedQueuePadding1.Node<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
charAt(int) - Method in class org.agrona.AsciiSequenceView
CharSequenceJavaFileObject - Class in org.agrona.generation
An implementation of a SimpleJavaFileObject which stores the content in a CharSequence.
CharSequenceJavaFileObject(String, CharSequence) - Constructor for class org.agrona.generation.CharSequenceJavaFileObject
Create file object from class source code.
charset - Variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
charset() - Method in class org.agrona.concurrent.errors.DistinctErrorLog
Charset used to encode errors.
CharVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.CharVerifier
 
checkCapacity(int) - Static method in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Check the buffer capacity is the correct size.
checkCapacity(int, int) - Static method in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Check the buffer capacity is the correct size (a power of 2 + RingBufferDescriptor.TRAILER_LENGTH) and that it satisfies minimum capacity size.
checkCountersCapacity(int) - Method in class org.agrona.concurrent.status.CountersManager
 
checkFileExists(File, String) - Static method in class org.agrona.IoUtil
Check that a file exists and throw an exception if not.
checkIndex(int) - Method in class org.agrona.collections.IntArrayList
 
checkIndex(int) - Method in class org.agrona.collections.LongArrayList
 
checkIndexForAdd(int) - Method in class org.agrona.collections.IntArrayList
 
checkIndexForAdd(int) - Method in class org.agrona.collections.LongArrayList
 
checkInitialTickAllocation(int) - Static method in class org.agrona.DeadlineTimerWheel
 
checkLimit(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Check that a given limit is not greater than the capacity of a buffer from a given offset.
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
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.ExpandableDirectByteBuffer
Check that a given limit is not greater than the capacity of a buffer from a given offset.
checkMessageLength(int) - Method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
checkMsgLength(int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
checkMsgLength(int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
checkResolution(long) - Static method in class org.agrona.DeadlineTimerWheel
 
checkTicksPerWheel(int) - Static method in class org.agrona.DeadlineTimerWheel
 
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.
claimCapacity(AtomicBuffer, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
claimCapacity(AtomicBuffer, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
ClassFileManager<M> - Class in org.agrona.generation
ForwardingJavaFileManager for storing class files which can be looked up by name.
ClassFileManager(M) - Constructor for class org.agrona.generation.ClassFileManager
 
className - Variable in class org.agrona.generation.SpecialisationGenerator.Substitution
 
classObjectByNameMap - Variable in 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.IntArrayQueue
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.LongArrayQueue
clear() - Method in class org.agrona.collections.LongHashSet
clear() - Method in class org.agrona.collections.Object2IntCounterMap
Clear out all entries.
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.Object2LongCounterMap
Clear out all entries.
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.DeadlineTimerWheel
Clear out all scheduled timers in the wheel.
clear() - Method in class org.agrona.generation.StringWriterOutputManager
Clear all source files in this OutputManager and reset the initial package name.
clock - Variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
clock - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
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() - Method in class org.agrona.concurrent.CountedErrorHandler
Close so that CountedErrorHandler.onError(Throwable) will not delegate and instead print to System.err
close() - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
Close error handler so that is does not attempt to write to underlying storage which may be unmapped.
close() - Method in class org.agrona.concurrent.status.AtomicCounter
Close counter and free the counter slot for reuse of connected to CountersManager.
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.
close(int, Consumer<Thread>) - Method in class org.agrona.concurrent.AgentRunner
Stop the running Agent and cleanup.
close(AutoCloseable) - Static method in class org.agrona.CloseHelper
Close a AutoCloseable dealing with nulls and exceptions.
close(ErrorHandler, AutoCloseable) - Static method in class org.agrona.CloseHelper
Close a AutoCloseable delegating exceptions to the ErrorHandler.
closeAll(AutoCloseable...) - Static method in class org.agrona.CloseHelper
Close all provided closeables.
closeAll(Collection<? extends AutoCloseable>) - Static method in class org.agrona.CloseHelper
Close all provided closeables.
closeAll(ErrorHandler, AutoCloseable...) - Static method in class org.agrona.CloseHelper
Close all closeables and delegate exceptions to the ErrorHandler.
closeAll(ErrorHandler, Collection<? extends AutoCloseable>) - Static method in class org.agrona.CloseHelper
Close all closeables and delegate exceptions to the ErrorHandler.
CLOSED - Enum constant in enum class org.agrona.concurrent.DynamicCompositeAgent.Status
Agent has been closed.
CloseHelper - Class in org.agrona
Utility functions to help with using AutoCloseable resources.
CloseHelper() - Constructor for class org.agrona.CloseHelper
 
closer - Variable in class org.agrona.collections.IntLruCache
 
closer - Variable in class org.agrona.collections.LongLruCache
 
COLLECTIONS_PACKAGE - Static variable in class org.agrona.generation.SpecialisationGenerator
 
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.ringbuffer.ManyToOneRingBuffer
Commit message that was written in the previously claimed space thus making it available to the consumer.
commit(int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Commit message that was written in the previously claimed space thus making it available to the consumer.
commit(int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Commit message that was written in the previously claimed space thus making it available to the consumer.
COMMIT - Enum constant in enum class org.agrona.concurrent.ControlledMessageHandler.Action
Continue processing but commit the position as of the end of the current message so that flow control is applied to this point.
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.Object2IntCounterMap
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.Object2LongCounterMap
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.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.
compactChain(int) - Method in class org.agrona.collections.BiInt2ObjectMap
 
compactChain(int) - Method in class org.agrona.collections.Int2IntCounterMap
 
compactChain(int) - Method in class org.agrona.collections.Int2IntHashMap
 
compactChain(int) - Method in class org.agrona.collections.Int2ObjectHashMap
 
compactChain(int) - Method in class org.agrona.collections.IntHashSet
 
compactChain(int) - Method in class org.agrona.collections.Long2LongCounterMap
 
compactChain(int) - Method in class org.agrona.collections.Long2LongHashMap
 
compactChain(int) - Method in class org.agrona.collections.Long2ObjectHashMap
 
compactChain(int) - Method in class org.agrona.collections.LongHashSet
 
compactChain(int) - Method in class org.agrona.collections.Object2IntCounterMap
 
compactChain(int) - Method in class org.agrona.collections.Object2IntHashMap
 
compactChain(int) - Method in class org.agrona.collections.Object2LongCounterMap
 
compactChain(int) - Method in class org.agrona.collections.Object2LongHashMap
 
compactChain(int) - Method in class org.agrona.collections.Object2ObjectHashMap
 
compactChain(int) - Method in class org.agrona.collections.ObjectHashSet
 
compare(int, int) - Static method in class org.agrona.collections.MutableInteger
Compare two values.
compare(long, long) - Static method in class org.agrona.collections.MutableLong
Compare two long values.
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 an int given an expected value.
compareAndSetInt(int, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomic compare and set of an int given an expected value.
compareAndSetLong(int, long, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomic compare and set of a long given an expected value.
compareAndSetLong(int, long, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomic compare and set of a long given an expected value.
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.AbstractMutableDirectBuffer
compile(DiagnosticCollector<JavaFileObject>, JavaCompiler.CompilationTask) - Static method in class org.agrona.generation.CompilerUtil
Execute compilation task and report errors if it fails.
compileAndLoad(String, DiagnosticCollector<JavaFileObject>, JavaFileManager, JavaCompiler.CompilationTask) - Static method in class org.agrona.generation.CompilerUtil
Compile and load a class.
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
 
compose(int, int, int) - Static method in class org.agrona.SemanticVersion
Compose a 4-byte integer with major, minor, and patch version stored in the least significant 3 bytes.
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.
compute(int, int, BiInt2ObjectMap.EntryRemap<? super V, ? extends V>) - Method in class org.agrona.collections.BiInt2ObjectMap
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute(int, IntBinaryOperator) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.compute(Object, BiFunction).
compute(int, IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute(int, IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute(long, LongBinaryOperator) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.compute(Object, BiFunction).
compute(long, LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute(long, LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Attempts to compute a mapping for the specified key and its current mapped value (or null if there is no current mapping).
compute(Integer, BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
compute(Integer, BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
compute(Long, BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
compute(Long, BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
compute(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.agrona.collections.Object2ObjectHashMap
compute(K, ObjectIntToIntFunction<? super K>) - Method in class org.agrona.collections.Object2IntHashMap
Attempts to compute a mapping for the specified key and its current mapped value (or missingValue if there is no current mapping).
compute(K, ObjectLongToLongFunction<? super K>) - Method in class org.agrona.collections.Object2LongHashMap
Attempts to compute a mapping for the specified key and its current mapped value (or missingValue if there is no current mapping).
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, 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(int, IntUnaryOperator) - Method in class org.agrona.collections.Int2IntCounterMap
Try Int2IntCounterMap.get(int) 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(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(long, LongUnaryOperator) - Method in class org.agrona.collections.Long2LongCounterMap
Try Long2LongCounterMap.get(long) 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(Integer, Function<? super Integer, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
computeIfAbsent(Integer, Function<? super Integer, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
computeIfAbsent(Long, Function<? super Long, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
computeIfAbsent(Long, Function<? super Long, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
computeIfAbsent(K, Function<? super K, ? extends V>) - Method in class org.agrona.collections.Object2ObjectHashMap
computeIfAbsent(K, ToIntFunction<? super K>) - Method in class org.agrona.collections.Object2IntCounterMap
Try Object2IntCounterMap.get(Object) a value for a key and if not present then apply mapping function.
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.Object2LongCounterMap
Try Object2LongCounterMap.get(Object) a value for a key and if not present then apply mapping function.
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.
computeIfPresent(int, int, BiInt2ObjectMap.EntryRemap<? super V, ? extends V>) - Method in class org.agrona.collections.BiInt2ObjectMap
If the value for the specified key is present and non-null, attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(int, IntBinaryOperator) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.computeIfPresent(Object, BiFunction).
computeIfPresent(int, IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
If the value for the specified key is present attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(int, IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
If the value for the specified key is present and non-null, attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(long, LongBinaryOperator) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.computeIfPresent(Object, BiFunction).
computeIfPresent(long, LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
If the value for the specified key is present attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(long, LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
If the value for the specified key is present and non-null, attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(Integer, BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
computeIfPresent(Integer, BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
computeIfPresent(Long, BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
computeIfPresent(Long, BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
computeIfPresent(K, BiFunction<? super K, ? super V, ? extends V>) - Method in class org.agrona.collections.Object2ObjectHashMap
computeIfPresent(K, ObjectIntToIntFunction<? super K>) - Method in class org.agrona.collections.Object2IntHashMap
If the value for the specified key is present, attempts to compute a new mapping given the key and its current mapped value.
computeIfPresent(K, ObjectLongToLongFunction<? super K>) - Method in class org.agrona.collections.Object2LongHashMap
If the value for the specified key is present, attempts to compute a new mapping given the key and its current mapped value.
computeRecordIndex(int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
computeRecordIndex(int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
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
Construct a counter manager over buffers containing the values and associated metadata.
ConcurrentCountersManager(AtomicBuffer, AtomicBuffer, Charset) - Constructor for class org.agrona.concurrent.status.ConcurrentCountersManager
Construct a counter manager over buffers containing the values and associated metadata.
ConcurrentCountersManager(AtomicBuffer, AtomicBuffer, Charset, EpochClock, long) - Constructor for class org.agrona.concurrent.status.ConcurrentCountersManager
Create a new counter manager over buffers containing the values and associated metadata.
conditionalSubstitute(String) - Method in class org.agrona.generation.SpecialisationGenerator.Substitution
Perform conditional code substitutions, i.e.
consume(ExpandableRingBuffer.MessageConsumer, int) - Method in class org.agrona.ExpandableRingBuffer
Consume messages up to a limit and pass them to the ExpandableRingBuffer.MessageConsumer.
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.
consumerHeartbeatIndex - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
consumerHeartbeatIndex - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
consumerHeartbeatTime() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
The time of the last consumer heartbeat.
consumerHeartbeatTime() - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
The time of the last consumer heartbeat.
consumerHeartbeatTime() - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
The time of the last consumer heartbeat.
consumerHeartbeatTime(long) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Set 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(long) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Set 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(int) - Method in class org.agrona.collections.Int2IntHashMap.KeySet
Checks if key is contained in the map without boxing.
contains(int) - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
Checks if the value is contained in the map.
contains(int) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
Check if the given key contained in the set without boxing.
contains(int) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
Checks if the key is contained in the map.
contains(int) - Method in class org.agrona.collections.IntHashSet
Contains method that does not box values.
contains(int) - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
Checks if the value is contained in the map.
contains(long) - Method in class org.agrona.collections.Long2LongHashMap.KeySet
Checks if key is contained in the map without boxing.
contains(long) - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
Checks if the value is contained in the map.
contains(long) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
Check if the given key contained in the set without boxing.
contains(long) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
Checks if the key is contained in the map.
contains(long) - Method in class org.agrona.collections.LongHashSet
Contains method that does not box values.
contains(long) - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
Checks if the value is contained in the map.
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.KeySet
contains(Object) - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
contains(Object) - 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(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
contains(Object) - Method in class org.agrona.collections.IntArrayList
contains(Object) - 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(Object) - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
contains(Object) - 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(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
contains(Object) - Method in class org.agrona.collections.LongArrayList
contains(Object) - 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
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
containsAll(IntArrayList) - Method in class org.agrona.collections.IntArrayList
Returns true if this list contains all the elements of the specified list.
containsAll(IntHashSet) - Method in class org.agrona.collections.IntHashSet
IntHashSet specialised variant of {this#containsAll(Collection)}.
containsAll(LongArrayList) - Method in class org.agrona.collections.LongArrayList
Returns true if this list contains all the elements of the specified list.
containsAll(LongHashSet) - Method in class org.agrona.collections.LongHashSet
LongHashSet specialised variant of {this#containsAll(Collection)}.
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(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(int) - Method in class org.agrona.collections.Int2ObjectHashMap
Overloaded version of Map.containsKey(Object) that takes a primitive int key.
containsKey(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
Returns true if this map contains a mapping for the specified 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(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.containsKey(Object) that takes a primitive long key.
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.Int2IntHashMap
containsKey(Object) - Method in class org.agrona.collections.Int2ObjectCache
containsKey(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
containsKey(Object) - Method in class org.agrona.collections.Long2LongHashMap
containsKey(Object) - Method in class org.agrona.collections.Long2ObjectCache
containsKey(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
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
containsKey(K) - Method in class org.agrona.collections.Object2IntCounterMap
Does the map contain a value for a given key which is not Object2IntCounterMap.initialValue().
containsKey(K) - Method in class org.agrona.collections.Object2LongCounterMap
Does the map contain a value for a given key which is not Object2LongCounterMap.initialValue().
containsLong(long) - Method in class org.agrona.collections.LongArrayList
Does the list contain this element value.
containsMissingValue - Variable in class org.agrona.collections.IntHashSet
 
containsMissingValue - Variable in class org.agrona.collections.LongHashSet
 
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(int) - Method in class org.agrona.collections.Object2IntCounterMap
Iterate over the values to see if any match the provided value.
containsValue(int) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version to avoid boxing.
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(long) - Method in class org.agrona.collections.Object2LongCounterMap
Iterate over the values to see if any match the provided value.
containsValue(long) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version to avoid boxing.
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(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(Object) - Method in class org.agrona.collections.Object2LongHashMap
containsValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
Does the map contain the value.
CONTINUE - Enum constant in enum class org.agrona.concurrent.ControlledMessageHandler.Action
Continue processing until limit or no messages with position commit at end of read as the in ControlledMessageHandler.onMessage(int, MutableDirectBuffer, int, int).
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
IdleStrategy which can be controlled by a counter so its mode of operation can be switched between doing nothing (NOOP), busy spinning by calling ThreadHints.onSpinWait(), yielding by calling Thread.yield(), or sleeping for the minimum period by calling LockSupport.parkNanos(long) when work count is zero, so it idles.
ControllableIdleStrategy(StatusIndicatorReader) - Constructor for class org.agrona.concurrent.ControllableIdleStrategy
Configure idle strategy taking an indicator of which strategy should be applied.
ControlledMessageHandler - Interface in org.agrona.concurrent
Callback interface for processing of messages that are read from a buffer.
ControlledMessageHandler.Action - Enum Class in org.agrona.concurrent
controlledRead(ControlledMessageHandler) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Read as many messages as are available to the end of the ring buffer with the handler able to control progress.
controlledRead(ControlledMessageHandler) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Read as many messages as are available to the end of the ring buffer with the handler able to control progress.
controlledRead(ControlledMessageHandler) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Read as many messages as are available to the end of the ring buffer with the handler able to control progress.
controlledRead(ControlledMessageHandler, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Read messages up to a limit of available to the end of the ring buffer with the handler able to control progress.
controlledRead(ControlledMessageHandler, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Read messages up to a limit of available to the end of the ring buffer with the handler able to control progress.
controlledRead(ControlledMessageHandler, int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Read messages up to a limit of available to the end of the ring buffer with the handler able to control progress.
copy(IntHashSet) - Method in class org.agrona.collections.IntHashSet
Copy values from another IntHashSet into this one.
copy(LongHashSet) - Method in class org.agrona.collections.LongHashSet
Copy values from another LongHashSet longo this one.
copy(ObjectHashSet<T>) - Method in class org.agrona.collections.ObjectHashSet
Copy data from the provided ObjectHashSet into this one.
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) - 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, MutableDirectBuffer) - Constructor for class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
Wrap a BroadcastReceiver to simplify the API for receiving messages.
copyValues(Object[]) - Method in class org.agrona.collections.IntHashSet
 
copyValues(Object[]) - Method in class org.agrona.collections.LongHashSet
 
CORRELATION_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the correlation counter value is stored.
correlationIdCounterIndex - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
correlationIdCounterIndex - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
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.
counterId - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
counterId - Variable in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
 
counterOffset(int) - Static method in class org.agrona.concurrent.status.CountersReader
The offset in the counter buffer for a given counterId.
countersManager - Variable in class org.agrona.concurrent.status.AtomicCounter
 
countersManager - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
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) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter manager over two buffers.
CountersManager(AtomicBuffer, AtomicBuffer, Charset) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter manager over two buffers.
CountersManager(AtomicBuffer, AtomicBuffer, Charset, EpochClock, long) - Constructor for class org.agrona.concurrent.status.CountersManager
Create a new counter 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
Create a new output destination based on a name.
currentTick - Variable in class org.agrona.DeadlineTimerWheel
 
currentTickTime() - Method in class org.agrona.DeadlineTimerWheel
Time of current tick of the wheel in DeadlineTimerWheel.timeUnit()s.
currentTickTime(long) - Method in class org.agrona.DeadlineTimerWheel
Set the current tick of the wheel to examine on the next DeadlineTimerWheel.poll(long, org.agrona.DeadlineTimerWheel.TimerHandler, int).
currentTickTime0() - Method in class org.agrona.DeadlineTimerWheel
 
cursor - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 

D

deadline(long) - Method in class org.agrona.DeadlineTimerWheel
Get the deadline for the given timerId.
DeadlineTimerWheel - Class in org.agrona
Timer Wheel for timers scheduled to expire on a deadline, (NOT thread safe).
DeadlineTimerWheel(TimeUnit, long, long, int) - Constructor for class org.agrona.DeadlineTimerWheel
Construct timer wheel and configure timing with default initial allocation.
DeadlineTimerWheel(TimeUnit, long, long, int, int) - Constructor for class org.agrona.DeadlineTimerWheel
Construct timer wheel and configure timing with provided initial allocation.
DeadlineTimerWheel.TimerConsumer - Interface in org.agrona
Consumer of timer entries as deadline to timerId.
DeadlineTimerWheel.TimerHandler - Interface in org.agrona
Handler for processing expired timers.
DecoderFlyweight - Interface in org.agrona.sbe
A flyweight for decoding an SBE type.
decrement() - Method in class org.agrona.collections.MutableInteger
Decrement the value.
decrement() - Method in class org.agrona.collections.MutableLong
Decrement the value.
decrement() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic decrement that will not lose updates across threads.
decrementAndGet() - Method in class org.agrona.collections.MutableInteger
Decrement and get the value.
decrementAndGet() - Method in class org.agrona.collections.MutableLong
Decrement and get the value.
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).
decrementAndGet(K) - Method in class org.agrona.collections.Object2IntCounterMap
Convenience version of Object2IntCounterMap.addAndGet(Object, int) (key, -1).
decrementAndGet(K) - Method in class org.agrona.collections.Object2LongCounterMap
Convenience version of Object2LongCounterMap.addAndGet(Object, long) (key, -1).
decrementOrdered() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic decrement that is not safe across threads.
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_MAX_MEASUREMENT_RETRIES - Static variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
DEFAULT_MAX_PARK_PERIOD_NS - Static variable in class org.agrona.concurrent.BackoffIdleStrategy
Default maximum interval the strategy will park a thread.
DEFAULT_MAX_SPINS - Static variable in class org.agrona.concurrent.BackoffIdleStrategy
Default number of times the strategy will spin without work before going to next state.
DEFAULT_MAX_YIELDS - Static variable in class org.agrona.concurrent.BackoffIdleStrategy
Default number of times the strategy will yield without work before going to next state.
DEFAULT_MEASUREMENT_THRESHOLD_NS - Static variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
DEFAULT_MIN_PARK_PERIOD_NS - Static variable in class org.agrona.concurrent.BackoffIdleStrategy
Default minimum interval the strategy will park a thread.
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.IntArrayQueue
Default representation 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_NULL_VALUE - Static variable in class org.agrona.collections.LongArrayQueue
Default representation of null for an element.
DEFAULT_OWNER_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Default owner id of a counter when none is set.
DEFAULT_REFERENCE_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Default reference id of a counter when none is set.
DEFAULT_REGISTRATION_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Default registration id of a counter when none is set.
DEFAULT_RESAMPLE_INTERVAL_NS - Static variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
DEFAULT_SLEEP_PERIOD_MS - Static variable in class org.agrona.concurrent.SleepingMillisIdleStrategy
Default sleep period when the default constructor is used.
DEFAULT_SLEEP_PERIOD_NS - Static variable in class org.agrona.concurrent.SleepingIdleStrategy
Default sleep period that tends to work as the likely minimum on Linux to be effective.
DEFAULT_TYPE_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Default type id of a counter when none is supplied.
delegate - Variable in class org.agrona.collections.UnmodifiableCollectionView.ReusableIterator
 
DelegatingErrorHandler - Interface in org.agrona
ErrorHandler that can insert into a chain of responsibility, so it handles an error and then delegates on to the next in the chain.
delete() - Method in interface org.agrona.ManagedResource
Delete any resources held.
delete(File, boolean) - Static method in class org.agrona.IoUtil
Recursively delete a file or directory tree.
delete(File, ErrorHandler) - Static method in class org.agrona.IoUtil
Recursively delete a file or directory tree.
deleteDirectory(boolean) - Method in class org.agrona.MarkFile
Delete parent directory.
deleteIfExists(File) - Static method in class org.agrona.IoUtil
Delete file only if it already exists.
deleteIfExists(File, ErrorHandler) - Static method in class org.agrona.IoUtil
Delete file only if it already exists.
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.
digitCount(int) - Static method in class org.agrona.AsciiEncoding
Count number of digits in a positive int value.
digitCount(long) - Static method in class org.agrona.AsciiEncoding
Count number of digits in a positive long value.
DirectBuffer - Interface in org.agrona
Abstraction over a range of buffer types that allows fields to be read in native typed fashion.
DirectBufferDataInput - Class in org.agrona.io
A data input implementation that reads from a DirectBuffer.
DirectBufferDataInput(DirectBuffer) - Constructor for class org.agrona.io.DirectBufferDataInput
Wrap given DirectBuffer.
DirectBufferDataInput(DirectBuffer, int, int) - Constructor for class org.agrona.io.DirectBufferDataInput
Wrap given DirectBuffer.
DirectBufferInputStream - Class in org.agrona.io
An InputStream that wraps a DirectBuffer.
DirectBufferInputStream() - Constructor for class org.agrona.io.DirectBufferInputStream
Default constructor.
DirectBufferInputStream(DirectBuffer) - Constructor for class org.agrona.io.DirectBufferInputStream
Wrap given DirectBuffer.
DirectBufferInputStream(DirectBuffer, int, int) - Constructor for class org.agrona.io.DirectBufferInputStream
Wrap given DirectBuffer.
DirectBufferOutputStream - Class in org.agrona.io
OutputStream that wraps an underlying MutableDirectBuffer.
DirectBufferOutputStream() - Constructor for class org.agrona.io.DirectBufferOutputStream
Default constructor.
DirectBufferOutputStream(MutableDirectBuffer) - Constructor for class org.agrona.io.DirectBufferOutputStream
Constructs output stream wrapping the given buffer.
DirectBufferOutputStream(MutableDirectBuffer, int, int) - Constructor for class org.agrona.io.DirectBufferOutputStream
Constructs output stream wrapping the given buffer at an offset.
disable() - Static method in class org.agrona.concurrent.HighResolutionTimer
Attempt to disable the high resolution timers.
DISABLE_ARRAY_CONTENT_PRINTOUT_PROP_NAME - Static variable in interface org.agrona.DirectBuffer
Deprecated.
DISABLE_BOUNDS_CHECKS_PROP_NAME - Static variable in class org.agrona.concurrent.UnsafeBuffer
 
DISABLE_BOUNDS_CHECKS_PROP_NAME - Static variable in interface org.agrona.DirectBuffer
Name of the system property that specify if the bounds checks should be disabled.
DISABLE_ON_SPIN_WAIT_PROP_NAME - Static variable in class org.agrona.hints.ThreadHints
Set this system property to true to disable ThreadHints.onSpinWait().
disconnectCountersManager() - Method in class org.agrona.concurrent.status.AtomicCounter
Disconnect from CountersManager if allocated, so it can be closed without freeing the slot.
disjunction(Collection<T>, Predicate<T>) - Static method in class org.agrona.collections.ObjectHashSet
 
distinctErrorLog() - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
The wrapped log.
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(AtomicBuffer, EpochClock, Charset) - Constructor for class org.agrona.concurrent.errors.DistinctErrorLog
Create a new error log that will be written to a provided AtomicBuffer.
DistinctErrorLog.DistinctObservation - Class in org.agrona.concurrent.errors
 
DistinctObservation(Throwable, int) - Constructor for class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
distinctObservations - Variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
DoNotSub - Annotation Interface 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
Return value as double.
doubleValue() - Method in class org.agrona.collections.MutableLong
Return value as double.
DoubleVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.DoubleVerifier
 
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
An agent should implement this method to do its work.
doWork() - Method in class org.agrona.concurrent.DynamicCompositeAgent
An agent should implement this method to do its work.
doWork(IdleStrategy, Agent) - Method in class org.agrona.concurrent.AgentRunner
 
drain(Consumer<E>) - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
Drain the number of elements present in a collection at the time the operation starts.
drain(Consumer<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
Drain the number of elements present in a collection at the time the operation starts.
drain(Consumer<E>) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
Drain the number of elements present in a collection at the time the operation starts.
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 class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
Drain the minimum of a limit and the number of elements present in a collection at the time the operation starts.
drain(Consumer<E>, int) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
Drain the minimum of a limit and the number of elements present in a collection at the time the operation starts.
drain(Consumer<E>, int) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
Drain the minimum of a limit and 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
Drain available elements into the provided Collection up to a provided maximum limit of elements.
drainTo(Collection<? super E>, int) - Method in class org.agrona.concurrent.ManyToOneConcurrentArrayQueue
Drain available elements into the provided Collection up to a provided maximum limit of elements.
drainTo(Collection<? super E>, int) - Method in class org.agrona.concurrent.OneToOneConcurrentArrayQueue
Drain available elements into the provided Collection up to a provided maximum limit of elements.
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.
DST_DIR - Static variable in class org.agrona.generation.SpecialisationGenerator
 
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 Class in org.agrona.concurrent
Enum to indicate the current status of a DynamicCompositeAgent.
DynamicPackageOutputManager - Interface in org.agrona.generation
Extended version of the OutputManager allowing the specification of packages for selected outputs.

E

element() - Method in class org.agrona.collections.IntArrayQueue
element() - Method in class org.agrona.collections.LongArrayQueue
element() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
element() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
elementInt() - Method in class org.agrona.collections.IntArrayQueue
Peek at the element on the head of the queue without boxing.
elementLong() - Method in class org.agrona.collections.LongArrayQueue
Peek at the element on the head of the queue without boxing.
elements - Variable in class org.agrona.collections.IntArrayList
 
elements - Variable in class org.agrona.collections.IntArrayQueue
 
elements - Variable in class org.agrona.collections.LongArrayList
 
elements - Variable in class org.agrona.collections.LongArrayQueue
 
elements - Variable in class org.agrona.collections.UnmodifiableCollectionView
 
empty - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
EMPTY_AGENTS - Static variable in class org.agrona.concurrent.DynamicCompositeAgent
 
EMPTY_BOOLEAN_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty boolean array.
EMPTY_BYTE_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty byte array.
EMPTY_CHAR_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty char array.
EMPTY_DOUBLE_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty double array.
EMPTY_FLOAT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty float array.
EMPTY_INT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty int array.
EMPTY_LONG_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty boolean array.
EMPTY_OBJECT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty Object array.
EMPTY_SHORT_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty short array.
EMPTY_STRING - Static variable in class org.agrona.PrintBufferUtil
 
EMPTY_STRING_ARRAY - Static variable in class org.agrona.collections.ArrayUtil
Empty String array.
enable() - Static method in class org.agrona.concurrent.HighResolutionTimer
Attempt to enable high resolution timers.
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
Deprecated.
endOffset(long) - Static method in class org.agrona.AsciiEncoding
Deprecated.
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.
ensureCapacity(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
ensureCapacity(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
 
ensureCapacity(int, int) - Method in class org.agrona.ExpandableArrayBuffer
 
ensureCapacity(int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
 
ensureCapacity(T[], int) - Static method in class org.agrona.collections.ArrayUtil
Ensure an array has the required capacity.
ensureCapacityPrivate(int) - Method in class org.agrona.collections.IntArrayList
 
ensureCapacityPrivate(int) - Method in class org.agrona.collections.LongArrayList
 
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
Ensure the directory exists, i.e.
ensureDirectoryIsRecreated(File, String, BiConsumer<String, String>) - Static method in class org.agrona.IoUtil
Create a directory, removing previous directory if it already exists.
ensureMarkFileLink(File, File, String) - Static method in class org.agrona.MarkFile
Ensure a link file exists if required for the actual mark file.
entries - Variable in class org.agrona.collections.Int2IntCounterMap
 
entries - Variable in class org.agrona.collections.Int2IntHashMap
 
entries - Variable in class org.agrona.collections.Long2LongCounterMap
 
entries - Variable in class org.agrona.collections.Long2LongHashMap
 
entries - Variable in class org.agrona.collections.Object2ObjectHashMap
 
entryIterator - Variable in class org.agrona.collections.Int2IntHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Int2ObjectHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Long2LongHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Long2ObjectHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Object2IntHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Object2LongHashMap.EntrySet
 
entryIterator - Variable in class org.agrona.collections.Object2ObjectHashMap.EntrySet
 
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 - Variable in class org.agrona.collections.Int2IntHashMap
 
entrySet - Variable in class org.agrona.collections.Int2ObjectCache
 
entrySet - Variable in class org.agrona.collections.Int2ObjectHashMap
 
entrySet - Variable in class org.agrona.collections.Long2LongHashMap
 
entrySet - Variable in class org.agrona.collections.Long2ObjectCache
 
entrySet - Variable in class org.agrona.collections.Long2ObjectHashMap
 
entrySet - Variable in class org.agrona.collections.Object2IntHashMap
 
entrySet - Variable in class org.agrona.collections.Object2LongHashMap
 
entrySet - Variable in class org.agrona.collections.Object2ObjectHashMap
 
entrySet() - Method in class org.agrona.collections.Int2IntHashMap
entrySet() - Method in class org.agrona.collections.Int2ObjectCache
entrySet() - Method in class org.agrona.collections.Int2ObjectHashMap
entrySet() - Method in class org.agrona.collections.Long2LongHashMap
entrySet() - Method in class org.agrona.collections.Long2ObjectCache
entrySet() - Method in class org.agrona.collections.Long2ObjectHashMap
entrySet() - Method in class org.agrona.collections.Object2IntHashMap
entrySet() - Method in class org.agrona.collections.Object2LongHashMap
entrySet() - Method in class org.agrona.collections.Object2ObjectHashMap
EntrySet() - Constructor for class org.agrona.collections.Int2IntHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Int2ObjectCache.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Int2ObjectHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Long2LongHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Long2ObjectCache.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Long2ObjectHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Object2IntHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Object2LongHashMap.EntrySet
 
EntrySet() - Constructor for class org.agrona.collections.Object2ObjectHashMap.EntrySet
 
EPOCH_BITS - Static variable in class org.agrona.concurrent.SnowflakeIdGenerator
Number of bits used for the timestamp giving 69 years from SnowflakeIdGenerator.timestampOffsetMs().
epochClock - Variable in class org.agrona.concurrent.status.CountersManager
 
EpochClock - Interface in org.agrona.concurrent
Retrieves the number of milliseconds since 1 Jan 1970 UTC.
EpochMicroClock - Interface in org.agrona.concurrent
Clock representing the time in microseconds since 1 Jan 1970 UTC.
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
Clock representing the time in nanoseconds since 1 Jan 1970 UTC.
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.AbstractMutableDirectBuffer
equals(Object) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
equals(Object) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
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.EntryIterator.MapEntry
equals(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
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.EntryIterator.MapEntry
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.EntryIterator.MapEntry
equals(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
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.EntryIterator
equals(Object) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
equals(Object) - Method in class org.agrona.collections.Object2IntHashMap
equals(Object) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
equals(Object) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
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.EntryIterator.MapEntry
equals(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
equals(Object) - Method in class org.agrona.collections.ObjectHashSet
equals(StackTraceElement[], StackTraceElement[]) - Static method in class org.agrona.concurrent.errors.DistinctErrorLog
 
equals(Throwable, Throwable) - Static method in class org.agrona.concurrent.errors.DistinctErrorLog
 
equals(IntArrayList) - Method in class org.agrona.collections.IntArrayList
Type-safe overload of the IntArrayList.equals(Object) method.
equals(LongArrayList) - Method in class org.agrona.collections.LongArrayList
Type-safe overload of the LongArrayList.equals(Object) method.
ErrorConsumer - Interface in org.agrona.concurrent.errors
Callback handler for consuming errors encountered in a DistinctErrorLog.
errorCounter - Variable in class org.agrona.concurrent.AgentInvoker
 
errorCounter - Variable in class org.agrona.concurrent.AgentRunner
 
errorCounter - Variable in class org.agrona.concurrent.CountedErrorHandler
 
errorHandler - Variable in class org.agrona.concurrent.AgentInvoker
 
errorHandler - Variable in class org.agrona.concurrent.AgentRunner
 
errorHandler - Variable in class org.agrona.concurrent.CountedErrorHandler
 
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 encoded as UTF-8 errors.
ErrorLogReader() - Constructor for class org.agrona.concurrent.errors.ErrorLogReader
 
errorOverflow - Variable in class org.agrona.concurrent.errors.LoggingErrorHandler
 
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 an int value and apply mask to get a remainder that will be even.
evenHash(long, int) - Static method in class org.agrona.collections.Hashing
Generate an even hash for a long value and apply mask to get a remainder that will be even.
evictionConsumer - Variable in class org.agrona.collections.Int2ObjectCache
 
evictionConsumer - Variable in class org.agrona.collections.Long2ObjectCache
 
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
Default constructor.
ExpandableDirectBufferOutputStream(MutableDirectBuffer) - Constructor for class org.agrona.io.ExpandableDirectBufferOutputStream
ExpandableDirectBufferOutputStream(MutableDirectBuffer, int) - Constructor for class org.agrona.io.ExpandableDirectBufferOutputStream
Wrap given MutableDirectBuffer at a given offset.
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.
ExpandableRingBuffer - Class in org.agrona
Ring-buffer for storing messages which can expand to accommodate the messages written into it.
ExpandableRingBuffer() - Constructor for class org.agrona.ExpandableRingBuffer
Create a new ring buffer which is initially compact and empty, has potential for ExpandableRingBuffer.MAX_CAPACITY, and using a direct ByteBuffer.
ExpandableRingBuffer(int, int, boolean) - Constructor for class org.agrona.ExpandableRingBuffer
Create a new ring buffer providing configuration for initial and max capacity, plus whether it is direct or not.
ExpandableRingBuffer.MessageConsumer - Interface in org.agrona
Consumers of messages implement this interface and pass it to ExpandableRingBuffer.consume(MessageConsumer, int).
extractNodeId(long) - Method in class org.agrona.concurrent.SnowflakeIdGenerator
 
extractSequence(long) - Method in class org.agrona.concurrent.SnowflakeIdGenerator
 
extractTimestamp(long) - Method in class org.agrona.concurrent.SnowflakeIdGenerator
 

F

factory - Variable in class org.agrona.collections.IntLruCache
 
factory - Variable in class org.agrona.collections.LongLruCache
 
failAction(Consumer<Thread>, Thread, String) - Method in class org.agrona.concurrent.AgentRunner
 
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.
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.
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.
FIELD_UPDATER - Static variable in class org.agrona.concurrent.CachedEpochClock
 
FIELD_UPDATER - Static variable in class org.agrona.concurrent.CachedNanoClock
 
fill(FileChannel, long, long, byte) - Static method in class org.agrona.IoUtil
Fill region of a file with a given byte value.
FILLER - Static variable in class org.agrona.IoUtil
 
find(DistinctErrorLog.DistinctObservation[], Throwable) - Static method in class org.agrona.concurrent.errors.DistinctErrorLog
 
findByRegistrationId(long) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over allocated counters and find the first matching a given registration id.
findByTypeIdAndRegistrationId(int, long) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over allocated counters and find the first matching a given type id and registration id.
findNext() - Method in class org.agrona.collections.Int2IntHashMap.AbstractIterator
Advance to the next entry.
findNext() - Method in class org.agrona.collections.Int2ObjectCache.AbstractIterator
Find next element.
findNext() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
Find the next element.
findNext() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
findNext() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
Advance to the next entry.
findNext() - Method in class org.agrona.collections.Long2ObjectCache.AbstractIterator
Find next element.
findNext() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
Find the next element.
findNext() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
findNext() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
Find next element.
findNext() - Method in class org.agrona.collections.Object2LongHashMap.AbstractIterator
Find next element.
findNext() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
Find next element.
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.
findNextPositivePowerOfTwo(long) - 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
Return value as float.
floatValue() - Method in class org.agrona.collections.MutableLong
Return value as float.
FloatVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.FloatVerifier
 
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(int, ExpandableRingBuffer.MessageConsumer, int) - Method in class org.agrona.ExpandableRingBuffer
Iterate encoded contents and pass messages to the ExpandableRingBuffer.MessageConsumer which can stop by returning false.
forEach(BiConsumer<? super Integer, ? super Integer>) - Method in class org.agrona.collections.Int2IntHashMap
forEach(BiConsumer<? super Integer, ? super V>) - Method in class org.agrona.collections.Int2ObjectCache
forEach(BiConsumer<? super Integer, ? super V>) - Method in class org.agrona.collections.Int2ObjectHashMap
forEach(BiConsumer<? super Long, ? super Long>) - Method in class org.agrona.collections.Long2LongHashMap
forEach(BiConsumer<? super Long, ? super V>) - Method in class org.agrona.collections.Long2ObjectCache
forEach(BiConsumer<? super Long, ? super V>) - Method in class org.agrona.collections.Long2ObjectHashMap
forEach(BiConsumer<? super K, ? super Integer>) - Method in class org.agrona.collections.Object2IntHashMap
forEach(BiConsumer<? super K, ? super Long>) - Method in class org.agrona.collections.Object2LongHashMap
forEach(BiConsumer<? super K, ? super V>) - Method in class org.agrona.collections.Object2ObjectHashMap
forEach(Consumer<? super Integer>) - Method in class org.agrona.collections.IntArrayList
forEach(Consumer<? super Integer>) - Method in class org.agrona.collections.IntArrayQueue
forEach(Consumer<? super Long>) - Method in class org.agrona.collections.LongArrayList
forEach(Consumer<? super Long>) - Method in class org.agrona.collections.LongArrayQueue
forEach(Consumer<? super K>) - Method in class org.agrona.collections.Object2ObjectHashMap.KeySet
forEach(Consumer<? super T>) - Method in class org.agrona.collections.ObjectHashSet
forEach(Consumer<? super V>) - Method in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
forEach(Consumer<? super V>) - Method in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
forEach(Consumer<? super V>) - Method in class org.agrona.collections.Object2ObjectHashMap.ValueCollection
forEach(Consumer<V>) - Method in class org.agrona.collections.BiInt2ObjectMap
Iterate over the contents of the map
forEach(ObjIntConsumer<K>) - Method in class org.agrona.collections.Object2IntCounterMap
Iterate over all value in the map which are not at Object2IntCounterMap.initialValue().
forEach(ObjLongConsumer<K>) - Method in class org.agrona.collections.Object2LongCounterMap
Iterate over all value in the map which are not at Object2LongCounterMap.initialValue().
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(IntObjConsumer<String>) - Method in class org.agrona.concurrent.status.CountersReader
Iterate over all labels in the label buffer.
forEach(LongLongConsumer) - Method in class org.agrona.collections.Long2LongCounterMap
Iterate over all value in the map which are not at Long2LongCounterMap.initialValue().
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(ExpandableRingBuffer.MessageConsumer, int) - Method in class org.agrona.ExpandableRingBuffer
Iterate encoded contents and pass messages to the ExpandableRingBuffer.MessageConsumer which can stop by returning false.
forEachInt(IntConsumer) - Method in class org.agrona.collections.IntArrayList
Iterate over the collection without boxing.
forEachInt(IntConsumer) - Method in class org.agrona.collections.IntArrayQueue
Iterate over the collection without boxing.
forEachInt(IntConsumer) - Method in class org.agrona.collections.IntHashSet
Iterate over the collection without boxing.
forEachInt(IntIntConsumer) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised forEach implementation.
forEachInt(IntObjConsumer<? super V>) - Method in class org.agrona.collections.Int2ObjectCache
Implementation of the Int2ObjectCache.forEach(BiConsumer) that avoids boxing of keys.
forEachInt(IntObjConsumer<V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised implementation of Map.forEach(BiConsumer).
forEachInt(ObjIntConsumer<? super K>) - Method in class org.agrona.collections.Object2IntHashMap
Performs the given action for each entry in this map until all entries have been processed or the action throws an exception.
forEachLong(LongConsumer) - Method in class org.agrona.collections.LongArrayList
Iterate over the collection without boxing.
forEachLong(LongConsumer) - Method in class org.agrona.collections.LongArrayQueue
Iterate over the collection without boxing.
forEachLong(LongConsumer) - Method in class org.agrona.collections.LongHashSet
Iterate over the collection without boxing.
forEachLong(LongLongConsumer) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised forEach implementation.
forEachLong(LongObjConsumer<? super V>) - Method in class org.agrona.collections.Long2ObjectCache
Implementation of the Long2ObjectCache.forEach(BiConsumer) that avoids boxing of keys.
forEachLong(LongObjConsumer<V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised implementation of Map.forEach(BiConsumer).
forEachLong(ObjLongConsumer<? super K>) - Method in class org.agrona.collections.Object2LongHashMap
Performs the given action for each entry in this map until all entries have been processed or the action throws an exception.
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 the counter identified by counterId.
free(int) - Method in class org.agrona.concurrent.status.CountersManager
Free the counter identified by counterId.
free(ByteBuffer) - Static method in class org.agrona.BufferUtil
Free direct ByteBuffer by invoking Cleaner on it.
free(DirectBuffer) - Static method in class org.agrona.BufferUtil
Free the underlying direct ByteBuffer by invoking Cleaner on it.
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.
freeList - Variable in class org.agrona.concurrent.status.CountersManager
 
freeToReuseTimeoutMs - Variable in class org.agrona.concurrent.status.CountersManager
 
FROM_HEX_DIGIT_TABLE - Static variable in class org.agrona.BitUtil
 
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.
fullFence() - Static method in class org.agrona.concurrent.MemoryAccess
Ensures that loads and stores before the fence will not be reordered with loads and stores after the fence.

G

generateRandomisedId() - Static method in class org.agrona.BitUtil
Generate a randomised integer over [Integer.MIN_VALUE, Integer.MAX_VALUE].
get() - Method in class org.agrona.collections.MutableBoolean
Get the current value.
get() - Method in class org.agrona.collections.MutableInteger
Get the value.
get() - Method in class org.agrona.collections.MutableLong
Get the value.
get() - Method in class org.agrona.collections.MutableReference
Get the current value of the reference.
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 the current position of a component without memory ordering semantics.
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
Get the current position of a component without memory ordering semantics.
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 a value using provided key avoiding boxing.
get(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.get(Object) that takes a primitive int key.
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(int) - Method in class org.agrona.collections.LongArrayList
get(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
Retrieve a value from the map.
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 a value using provided key avoiding boxing.
get(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.get(Object) that takes a primitive long key.
get(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
get(Object) - Method in class org.agrona.collections.Int2IntHashMap
get(Object) - Method in class org.agrona.collections.Int2ObjectCache
get(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
get(Object) - Method in class org.agrona.collections.Long2LongHashMap
get(Object) - Method in class org.agrona.collections.Long2ObjectCache
get(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
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(K) - Method in class org.agrona.collections.Object2IntCounterMap
Get the value of a counter associated with a key or Object2IntCounterMap.initialValue() if not found.
get(K) - Method in class org.agrona.collections.Object2LongCounterMap
Get the value of a counter associated with a key or Object2LongCounterMap.initialValue() if not found.
getAndAdd(int) - Method in class org.agrona.collections.MutableInteger
Get the value and add delta to it.
getAndAdd(int, int) - Method in class org.agrona.collections.Int2IntCounterMap
Add amount to the current value associated with this key.
getAndAdd(long) - Method in class org.agrona.collections.MutableLong
Get the value and add delta to it.
getAndAdd(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Add an increment to the counter that will not lose updates across threads.
getAndAdd(long, long) - Method in class org.agrona.collections.Long2LongCounterMap
Add amount to the current value associated with this key.
getAndAdd(K, int) - Method in class org.agrona.collections.Object2IntCounterMap
Add amount to the current value associated with this key.
getAndAdd(K, long) - Method in class org.agrona.collections.Object2LongCounterMap
Add amount to the current value associated with this key.
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(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomically add a delta to a value at a location returning the previous contents.
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(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomically add a delta to a value at a location returning the previous contents.
getAndAddOrdered(long) - Method in class org.agrona.concurrent.status.AtomicCounter
Add an increment to the counter with ordered store semantics.
getAndDecrement() - Method in class org.agrona.collections.MutableInteger
Get the value and decrement it.
getAndDecrement() - Method in class org.agrona.collections.MutableLong
Get the value and decrement it.
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).
getAndDecrement(K) - Method in class org.agrona.collections.Object2IntCounterMap
Convenience version of Object2IntCounterMap.getAndAdd(Object, int) (key, -1).
getAndDecrement(K) - Method in class org.agrona.collections.Object2LongCounterMap
Convenience version of Object2LongCounterMap.getAndAdd(Object, long) (key, -1).
getAndIncrement() - Method in class org.agrona.collections.MutableInteger
Get and increment the value.
getAndIncrement() - Method in class org.agrona.collections.MutableLong
Get and increment the value.
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).
getAndIncrement(K) - Method in class org.agrona.collections.Object2IntCounterMap
Convenience version of Object2IntCounterMap.getAndAdd(Object, int) (key, 1).
getAndIncrement(K) - Method in class org.agrona.collections.Object2LongCounterMap
Convenience version of Object2LongCounterMap.getAndAdd(Object, 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(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomically exchange a value at a location returning the previous contents.
getAndSetLong(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Atomically exchange a value at a location returning the previous contents.
getAndSetLong(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Atomically exchange a value at a location returning the previous contents.
getByte(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get the value at a given index.
getByte(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getBytes() - Method in class org.agrona.generation.JavaClassObject
Get the raw bytes for a class file.
getBytes(int, byte[]) - Method in class org.agrona.AbstractMutableDirectBuffer
Get from the underlying buffer into a supplied byte array.
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 class org.agrona.AbstractMutableDirectBuffer
Get bytes 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, ByteBuffer, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get from the underlying buffer into a supplied ByteBuffer current Buffer.position().
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 class org.agrona.AbstractMutableDirectBuffer
Get from the underlying buffer into a supplied ByteBuffer at an offset.
getBytes(int, ByteBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Get from the underlying buffer into a supplied ByteBuffer at an offset.
getBytes(int, MutableDirectBuffer, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get bytes from this DirectBuffer into the provided MutableDirectBuffer at given indices.
getBytes(int, MutableDirectBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Get bytes from this DirectBuffer into the provided MutableDirectBuffer at given indices.
getBytes(MutableDirectBuffer, int) - Method in class org.agrona.AsciiSequenceView
Copy the bytes from a view into a provided buffer.
getByteVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getByteVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
Get the value at a given index with volatile semantics.
getChar(int) - Method in class org.agrona.AbstractMutableDirectBuffer
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.AbstractMutableDirectBuffer
Get the value at a given index.
getChar(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
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(int) - Method in class org.agrona.concurrent.UnsafeBuffer
Get the value at a given index with volatile semantics.
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 as a volatile read.
getCounterOwnerId(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the owner id for a given counter id as a normal read.
getCounterReferenceId(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the reference id for a given counter id as a normal read.
getCounterRegistrationId(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the registration id for a given counter id as a volatile read.
getCounterState(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the state for a given counter id as a volatile read.
getCounterTypeId(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the type id for a given counter id.
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(int) - Method in class org.agrona.AbstractMutableDirectBuffer
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.AbstractMutableDirectBuffer
Get the value at a given index.
getDouble(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
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.
getFileMode(FileChannel.MapMode) - Static method in class org.agrona.IoUtil
 
getFloat(int) - Method in class org.agrona.AbstractMutableDirectBuffer
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.AbstractMutableDirectBuffer
Get the value at a given index.
getFloat(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getFreeForReuseDeadline(int) - Method in class org.agrona.concurrent.status.CountersReader
Get the deadline (ms) for when a given counter id may be reused.
getInt(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get the value at a given index.
getInt(int) - Method in class org.agrona.collections.IntArrayList
Get the element at a given index without boxing.
getInt(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getInt(int, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Get the value at a given index.
getInt(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getIntKey() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
Returns the key of the current entry.
getIntKey() - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
Get key of the current entry.
getIntKey() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
Get key without boxing.
getIntValue() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
Returns the value of the current entry.
getIntValue() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
Get int value without boxing.
getIntVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getIntVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
Get the value at a given index with volatile semantics.
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.Int2IntHashMap.EntryIterator.MapEntry
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.Int2ObjectHashMap.EntryIterator.MapEntry
getKey() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
getKey() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
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.Long2ObjectHashMap.EntryIterator.MapEntry
getKey() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
getKey() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
getKey() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
getKey() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
getKey() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
getKey() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
getKind() - Method in class org.agrona.generation.JavaClassObject
getLong(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get the value at a given index.
getLong(int) - Method in class org.agrona.collections.LongArrayList
Get the element at a given index without boxing.
getLong(int) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getLong(int, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Get the value at a given index.
getLong(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getLongKey() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
Returns the key of the current entry.
getLongKey() - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
Get key of the current entry.
getLongKey() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
Get key without boxing.
getLongValue() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
Returns the value of the current entry.
getLongValue() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
Get long value without boxing.
getLongVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getLongVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
Get the value at a given index with volatile semantics.
getMapped(int) - Method in class org.agrona.collections.Int2ObjectHashMap
Get mapped value without boxing the key.
getMapped(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Get mapped value without boxing the key.
getMapped(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
 
getMapping(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
 
getOrDefault(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(int, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Retrieve a value from the map or defaultValue if this map contains not mapping for the key.
getOrDefault(int, V) - Method in class org.agrona.collections.Int2ObjectCache
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(int, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(long, V) - Method in class org.agrona.collections.Long2ObjectCache
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(Object, int) - Method in class org.agrona.collections.Object2IntHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
getOrDefault(Object, long) - Method in class org.agrona.collections.Object2LongHashMap
Returns the value to which the specified key is mapped, or defaultValue if this map contains no mapping for the key.
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.
getProperty(String) - Static method in class org.agrona.SystemUtil
Get the value of a System.getProperty(String) with the exception that if the value is SystemUtil.NULL_PROPERTY_VALUE then return null.
getProperty(String, String) - Static method in class org.agrona.SystemUtil
Get the value of a System.getProperty(String, String) with the exception that if the value is SystemUtil.NULL_PROPERTY_VALUE then return null, otherwise if the value is not set then return the default value.
getShort(int) - Method in class org.agrona.AbstractMutableDirectBuffer
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.AbstractMutableDirectBuffer
Get the value at a given index.
getShort(int, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get the value at a given index.
getShortVolatile(int) - Method in interface org.agrona.concurrent.AtomicBuffer
Get the value at a given index with volatile semantics.
getShortVolatile(int) - Method in class org.agrona.concurrent.UnsafeBuffer
Get the value at a given index with volatile semantics.
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
Get a CharSequence which represents the source file.
getSources() - Method in class org.agrona.generation.StringWriterOutputManager
Get a Map of all source files.
getStringAscii(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get part of a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int, int) - Method in interface org.agrona.DirectBuffer
Get part of a String from bytes encoded in ASCII format that is length prefixed.
getStringAscii(int, int, Appendable) - Method in class org.agrona.AbstractMutableDirectBuffer
Get part of a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, int, Appendable) - Method in interface org.agrona.DirectBuffer
Get part of a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, Appendable) - Method in class org.agrona.AbstractMutableDirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, Appendable) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, Appendable, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, Appendable, ByteOrder) - Method in interface org.agrona.DirectBuffer
Get a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
getStringAscii(int, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
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.
getStringUtf8(int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get a String from bytes encoded in UTF-8 format that is length prefixed.
getStringUtf8(int) - 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 class org.agrona.AbstractMutableDirectBuffer
Get part of 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, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
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.
getStringWithoutLengthAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get an encoded ASCII String from the buffer that does not have a length prefix.
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, Appendable) - Method in class org.agrona.AbstractMutableDirectBuffer
Get an encoded ASCII String from the buffer that does not have a length prefix and append to an Appendable.
getStringWithoutLengthAscii(int, int, Appendable) - Method in interface org.agrona.DirectBuffer
Get an encoded ASCII String from the buffer that does not have a length prefix and append to an Appendable.
getStringWithoutLengthUtf8(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Get an encoded UTF-8 String from the buffer that does not have a length prefix.
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.
getUnsignedByte(DirectBuffer, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
Gets an unsigned byte at the specified absolute index in a buffer.
getValue() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
getValue() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
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.Int2ObjectHashMap.EntryIterator.MapEntry
getValue() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
getValue() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
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.Long2ObjectHashMap.EntryIterator.MapEntry
getValue() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
getValue() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
getValue() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
getValue() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
getValue() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
getValue() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
getValue(K) - Method in class org.agrona.collections.Object2IntHashMap
Overloaded version of Map.get(Object) that takes a primitive int key.
getValue(K) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.get(Object) that takes a primitive long key.
getVolatile() - Method in class org.agrona.concurrent.status.AtomicLongPosition
Get the current position of a component with volatile semantics.
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
Get the current position of a component with volatile semantics.
getVolatile() - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
Get the current status indication of a component with volatile semantics.
getWeak() - Method in class org.agrona.concurrent.status.AtomicCounter
Get the value of the counter using weak ordering semantics.

H

handleError(Throwable) - Method in class org.agrona.concurrent.AgentInvoker
 
handleError(Throwable) - Method in class org.agrona.concurrent.AgentRunner
 
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(int, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for an int value and apply mask to get remainder.
hash(long) - Static method in class org.agrona.collections.Hashing
Generate a hash for a long value.
hash(long, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for a long value and apply mask to get a remainder.
hash(Object, int) - Static method in class org.agrona.collections.Hashing
Generate a hash for an object and apply mask to get a remainder.
hashCode() - Method in class org.agrona.AbstractMutableDirectBuffer
hashCode() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
hashCode() - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
hashCode() - Method in class org.agrona.collections.Int2IntHashMap
hashCode() - Method in class org.agrona.collections.Int2ObjectCache
hashCode() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
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.EntryIterator.MapEntry
hashCode() - Method in class org.agrona.collections.Long2LongHashMap
hashCode() - Method in class org.agrona.collections.Long2ObjectCache
hashCode() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
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.EntryIterator
hashCode() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
hashCode() - Method in class org.agrona.collections.Object2IntHashMap
hashCode() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
hashCode() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
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.EntryIterator.MapEntry
hashCode() - Method in class org.agrona.collections.Object2ObjectHashMap
hashCode() - Method in class org.agrona.collections.ObjectHashSet
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.Int2IntHashMap.AbstractIterator
Check if there are more elements remaining.
hasNext() - Method in class org.agrona.collections.Int2ObjectCache.AbstractIterator
hasNext() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
hasNext() - Method in class org.agrona.collections.IntArrayQueue.IntIterator
hasNext() - Method in class org.agrona.collections.IntHashSet.IntIterator
hasNext() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
Check if there are more elements remaining.
hasNext() - Method in class org.agrona.collections.Long2ObjectCache.AbstractIterator
hasNext() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
hasNext() - Method in class org.agrona.collections.LongArrayQueue.LongIterator
hasNext() - Method in class org.agrona.collections.LongHashSet.LongIterator
hasNext() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
hasNext() - Method in class org.agrona.collections.Object2LongHashMap.AbstractIterator
hasNext() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
Check if there is next element to iterate.
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 - Variable in class org.agrona.collections.IntArrayQueue
 
head - Variable in class org.agrona.collections.LongArrayQueue
 
head - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueueConsumer
Head index.
head - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueueHead
Head of queue.
head - Variable in class org.agrona.ExpandableRingBuffer
 
head() - Method in class org.agrona.ExpandableRingBuffer
Head position in the buffer from which bytes are consumed forward toward the ExpandableRingBuffer.tail().
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
Offset of the head field.
HEAD_OFFSET - Static variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
Offset of the head field.
HEAD_POSITION_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the head value is stored.
headCache - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueueProducer
Cached head index.
headCachePositionIndex - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
headCachePositionIndex - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
HEADER_ALIGNMENT - Static variable in class org.agrona.ExpandableRingBuffer
Alignment in bytes for the beginning of message header.
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.
HEADER_LENGTH - Static variable in class org.agrona.ExpandableRingBuffer
Length of encapsulating header.
headOrdered(ManyToOneConcurrentLinkedQueuePadding1.Node<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
headPositionIndex - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
headPositionIndex - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
HEX_DIGIT_TABLE - Static variable in class org.agrona.BitUtil
 
HEX_PADDING - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
hexDump(byte[]) - Static method in class org.agrona.PrintBufferUtil
Returns a hex dump of the specified byte array.
hexDump(byte[], int, int) - Static method in class org.agrona.PrintBufferUtil
Returns a hex dump of the specified byte array's subregion.
hexDump(byte[], int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
 
hexDump(DirectBuffer) - Static method in class org.agrona.PrintBufferUtil
Returns a hex dump of the specified buffer's readable bytes.
hexDump(DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil
Returns a hex dump of the specified buffer's subregion.
hexDump(DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
 
HEXDUMP_ROW_PREFIXES - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
HEXDUMP_TABLE - Static variable in class org.agrona.PrintBufferUtil.HexUtil
 
HexUtil() - Constructor for class org.agrona.PrintBufferUtil.HexUtil
 
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 use of high-resolution timers on Windows by a bit of hackery.
HighResolutionTimer() - Constructor for class org.agrona.concurrent.HighResolutionTimer
 
highWaterMarkId - Variable in class org.agrona.concurrent.status.CountersManager
 

I

id - Variable in class org.agrona.concurrent.status.AtomicCounter
 
id - Variable in class org.agrona.concurrent.status.AtomicLongPosition
 
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
Identifier for this position.
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
Identifier for this position.
id() - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
Identifier for this status indicator.
IdGenerator - Interface in org.agrona.concurrent
Generates unique identifiers that fit in a 64-bit word.
idle() - Method in class org.agrona.concurrent.BackoffIdleStrategy
Perform current idle action (e.g.
idle() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
Perform current idle action (e.g.
idle() - Method in class org.agrona.concurrent.ControllableIdleStrategy
Perform current idle action (e.g.
idle() - Method in interface org.agrona.concurrent.IdleStrategy
Perform current idle action (e.g.
idle() - 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.SleepingIdleStrategy
Perform current idle action (e.g.
idle() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
Perform current idle action (e.g.
idle() - Method in class org.agrona.concurrent.YieldingIdleStrategy
Perform current idle action (e.g.
idle(int) - Method in class org.agrona.concurrent.BackoffIdleStrategy
Perform current idle action (e.g.
idle(int) - Method in class org.agrona.concurrent.BusySpinIdleStrategy
Note: this implementation will result in no safepoint poll once inlined.
idle(int) - Method in class org.agrona.concurrent.ControllableIdleStrategy
Idle based on current status indication value
idle(int) - 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(int) - Method in class org.agrona.concurrent.SleepingIdleStrategy
Perform current idle action (e.g.
idle(int) - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
Perform current idle action (e.g.
idle(int) - Method in class org.agrona.concurrent.YieldingIdleStrategy
Perform current idle action (e.g.
idleStrategy - Variable in class org.agrona.concurrent.AgentRunner
 
IdleStrategy - Interface in org.agrona.concurrent
Idle strategy for use by threads when they do not have work to do.
increaseCapacity() - Method in class org.agrona.collections.BiInt2ObjectMap
 
increaseCapacity() - Method in class org.agrona.collections.Int2IntCounterMap
 
increaseCapacity() - Method in class org.agrona.collections.Int2IntHashMap
 
increaseCapacity() - Method in class org.agrona.collections.Int2ObjectHashMap
 
increaseCapacity() - Method in class org.agrona.collections.IntArrayQueue
 
increaseCapacity() - Method in class org.agrona.collections.IntHashSet
 
increaseCapacity() - Method in class org.agrona.collections.Long2LongCounterMap
 
increaseCapacity() - Method in class org.agrona.collections.Long2LongHashMap
 
increaseCapacity() - Method in class org.agrona.collections.Long2ObjectHashMap
 
increaseCapacity() - Method in class org.agrona.collections.LongArrayQueue
 
increaseCapacity() - Method in class org.agrona.collections.LongHashSet
 
increaseCapacity() - Method in class org.agrona.collections.Object2IntCounterMap
 
increaseCapacity() - Method in class org.agrona.collections.Object2IntHashMap
 
increaseCapacity() - Method in class org.agrona.collections.Object2LongCounterMap
 
increaseCapacity() - Method in class org.agrona.collections.Object2LongHashMap
 
increaseCapacity() - Method in class org.agrona.collections.Object2ObjectHashMap
 
increaseCapacity() - Method in class org.agrona.collections.ObjectHashSet
 
increaseCapacity(long, int) - Method in class org.agrona.DeadlineTimerWheel
 
increment() - Method in class org.agrona.collections.MutableInteger
Increment the value.
increment() - Method in class org.agrona.collections.MutableLong
Increment the value.
increment() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic increment that will not lose updates across threads.
incrementAndGet() - Method in class org.agrona.collections.MutableInteger
Increment and return the value.
incrementAndGet() - Method in class org.agrona.collections.MutableLong
Increment and return the value.
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).
incrementAndGet(K) - Method in class org.agrona.collections.Object2IntCounterMap
Convenience version of Object2IntCounterMap.addAndGet(Object, int) (key, 1).
incrementAndGet(K) - Method in class org.agrona.collections.Object2LongCounterMap
Convenience version of Object2LongCounterMap.addAndGet(Object, long) (key, 1).
incrementOrdered() - Method in class org.agrona.concurrent.status.AtomicCounter
Perform an atomic increment that is not safe across threads.
index - Variable in exception class org.agrona.agent.BufferAlignmentException
 
index - Variable in class org.agrona.collections.IntArrayQueue.IntIterator
 
index - Variable in class org.agrona.collections.LongArrayQueue.LongIterator
 
index() - Method in exception class org.agrona.agent.BufferAlignmentException
Returns an index at which unaligned access occurred.
indexInTickArray(long) - Static method in class org.agrona.DeadlineTimerWheel
 
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.
INIT - Enum constant in enum class org.agrona.concurrent.DynamicCompositeAgent.Status
Agent is being initialised and has not yet been started.
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.
INITIAL_TICK_ALLOCATION - Static variable in class org.agrona.DeadlineTimerWheel
 
initialCurrentNanoTime - Variable in class org.agrona.concurrent.OffsetEpochNanoClock.TimeFields
 
initialNanoTime - Variable in class org.agrona.concurrent.OffsetEpochNanoClock.TimeFields
 
initialPackageName - Variable in class org.agrona.generation.StringWriterOutputManager
 
initialValue - Variable in class org.agrona.collections.Int2IntCounterMap
 
initialValue - Variable in class org.agrona.collections.Long2LongCounterMap
 
initialValue - Variable in class org.agrona.collections.Object2IntCounterMap
 
initialValue - Variable in class org.agrona.collections.Object2LongCounterMap
 
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.
initialValue() - Method in class org.agrona.collections.Object2IntCounterMap
The value to be used as a null marker in the map.
initialValue() - Method in class org.agrona.collections.Object2LongCounterMap
The value to be used as a null marker in the map.
insertPaddingRecord(AtomicBuffer, int, int) - Static method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
INSTANCE - Static variable in class org.agrona.collections.NullReference
Single instance of the NullReference class.
INSTANCE - Static variable in class org.agrona.concurrent.BusySpinIdleStrategy
As there is no instance state then this object can be used to save on allocation.
INSTANCE - Static variable in class org.agrona.concurrent.NoOpIdleStrategy
As there is no instance state then this object can be used to save on allocation.
INSTANCE - Static variable in class org.agrona.concurrent.NoOpLock
As there is no instance state then this object can be used to save on allocation.
INSTANCE - Static variable in class org.agrona.concurrent.SystemEpochClock
As there is no instance state then this object can be used to save on allocation.
INSTANCE - Static variable in class org.agrona.concurrent.SystemNanoClock
As there is no instance state then this object can be used to save on allocation.
INSTANCE - Static variable in class org.agrona.concurrent.YieldingIdleStrategy
As there is no instance state then this object can be used to save on allocation.
instrumentation - Static variable in class org.agrona.agent.BufferAlignmentAgent
 
INSUFFICIENT_CAPACITY - Static variable in interface org.agrona.concurrent.ringbuffer.RingBuffer
Buffer has insufficient capacity to record a message or satisfy RingBuffer.tryClaim(int, int) request.
INSUFFICIENT_SPACE - Static variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
INT_DIGITS - Static variable in class org.agrona.AsciiEncoding
 
INT_MAX_DIGITS - Static variable in class org.agrona.AsciiEncoding
Maximum number of digits in a US-ASCII-encoded int.
INT_POW_10 - Static variable in class org.agrona.AsciiEncoding
Power of ten for int values.
Int2IntCounterMap - Class in org.agrona.collections
An 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
Construct a new counter map with the initial value for the counter provided.
Int2IntHashMap - Class in org.agrona.collections
An 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(Int2IntHashMap) - Constructor for class org.agrona.collections.Int2IntHashMap
Copy construct a new map from an existing one.
Int2IntHashMap.AbstractIterator - Class in org.agrona.collections
Base iterator implementation.
Int2IntHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys and values.
Int2IntHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Int2IntHashMap.EntrySet - Class in org.agrona.collections
Set of entries which supports optionally cached iterators to avoid allocation.
Int2IntHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Int2IntHashMap.KeyIterator.nextValue().
Int2IntHashMap.KeySet - Class in org.agrona.collections
Set of keys which supports optional cached iterators to avoid allocation.
Int2IntHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which supports optionally cached iterators to avoid allocation.
Int2IntHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values which supports access to unboxed values.
Int2NullableObjectHashMap<V> - Class in org.agrona.collections
Variation of Int2ObjectHashMap that allows null values.
Int2NullableObjectHashMap() - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
Constructs map with default settings.
Int2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Int2NullableObjectHashMap
Constructs map with given initial capacity and load factory and enables caching of iterators.
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
Constructs cache with provided configuration.
Int2ObjectCache.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Int2ObjectCache.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys via Int2ObjectCache.EntryIterator.getIntKey().
Int2ObjectCache.EntrySet - Class in org.agrona.collections
Set of entries which supports cached iterator to avoid allocation.
Int2ObjectCache.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Int2ObjectCache.KeyIterator.nextInt().
Int2ObjectCache.KeySet - Class in org.agrona.collections
A key set implementation which supports cached iterator to avoid allocation.
Int2ObjectCache.ValueCollection - Class in org.agrona.collections
Collection of values which supports cached iterator to avoid allocation.
Int2ObjectCache.ValueIterator - Class in org.agrona.collections
An iterator over values.
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
Constructs map with Int2ObjectHashMap.MIN_CAPACITY, Hashing.DEFAULT_LOAD_FACTOR and enables caching of iterators.
Int2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Int2ObjectHashMap
Constructs map with given initial capacity and load factory and enables caching of iterators.
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.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Int2ObjectHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys via Int2ObjectHashMap.EntryIterator.getIntKey().
Int2ObjectHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Int2ObjectHashMap.EntrySet - Class in org.agrona.collections
Set of entries which supports access via an optionally cached iterator to avoid allocation.
Int2ObjectHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Int2ObjectHashMap.KeyIterator.nextInt().
Int2ObjectHashMap.KeySet - Class in org.agrona.collections
Set of keys which supports optionally cached iterators to avoid allocation.
Int2ObjectHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which supports optionally cached iterators to avoid allocation.
Int2ObjectHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values.
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, int) - Constructor for class org.agrona.collections.IntArrayList
Create a new list that wraps an existing arrays without copying it.
IntArrayList(int, int) - Constructor for class org.agrona.collections.IntArrayList
Construct a new list.
IntArrayQueue - Class in org.agrona.collections
Queue of ints which stores the elements without boxing.
IntArrayQueue() - Constructor for class org.agrona.collections.IntArrayQueue
Construct a new queue defaulting to IntArrayQueue.MIN_CAPACITY capacity, IntArrayQueue.DEFAULT_NULL_VALUE and cached iterators.
IntArrayQueue(int) - Constructor for class org.agrona.collections.IntArrayQueue
Construct a new queue defaulting to IntArrayQueue.MIN_CAPACITY capacity and cached iterators.
IntArrayQueue(int, int) - Constructor for class org.agrona.collections.IntArrayQueue
Construct a new queue default to cached iterators.
IntArrayQueue(int, int, boolean) - Constructor for class org.agrona.collections.IntArrayQueue
Construct a new queue providing all the config options.
IntArrayQueue.IntIterator - Class in org.agrona.collections
Specialised Iterator from which the value can be retrieved without boxing via IntArrayQueue.IntIterator.nextValue().
INTEGER_ABSOLUTE_MIN_VALUE - Static variable in class org.agrona.AsciiEncoding
An absolute value of the Integer.MIN_VALUE as long.
intForEach(IntIntConsumer) - Method in class org.agrona.collections.Int2IntHashMap
intForEach(IntObjConsumer<V>) - Method in class org.agrona.collections.Int2ObjectHashMap
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, iterator caching support and 0 as a missing value.
IntHashSet(int) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed capacity, Hashing.DEFAULT_LOAD_FACTOR, iterator caching support and 0 as a missing value.
IntHashSet(int, float) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed initial capacity, load factor, iterator caching support and 0 as a missing value.
IntHashSet(int, float, boolean) - Constructor for class org.agrona.collections.IntHashSet
Construct a hash set with a proposed initial capacity, load factor, iterator caching support and -1 as a missing value.
IntHashSet.IntIterator - Class in org.agrona.collections
Iterator which supports unboxed access to the values via IntHashSet.IntIterator.nextValue().
IntIntConsumer - Interface in org.agrona.collections
Primitive specialisation of a BiConsumer for a pair of ints.
IntIntFunction - Interface in org.agrona.collections
Primitive specialisation of a BiFunction for a pair of ints.
IntIntPredicate - Interface in org.agrona.collections
Primitive specialisation of a BiPredicate for a pair of ints.
IntIterator() - Constructor for class org.agrona.collections.IntArrayQueue.IntIterator
 
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.
IntObjectToObjectFunction<T,R> - Interface in org.agrona.collections
This is an (int, Object) -> Object primitive specialisation of a BiFunction.
IntObjPredicate<T> - Interface in org.agrona.collections
This is an (int, Object) primitive specialisation of a BiPredicate.
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
Return value as int.
intValue() - Method in class org.agrona.collections.MutableLong
Return value as int.
IntVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.IntVerifier
 
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 for dealing with files, especially mapping and un-mapping.
IoUtil() - Constructor for class org.agrona.IoUtil
 
isActive(MappedByteBuffer, EpochClock, long, int, int, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
Check if MarkFile is active, i.e.
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 - Variable in class org.agrona.concurrent.AgentInvoker
 
isClosed - Variable in class org.agrona.concurrent.AgentRunner
 
isClosed - Variable in class org.agrona.concurrent.CountedErrorHandler
 
isClosed - Variable in class org.agrona.concurrent.errors.LoggingErrorHandler
 
isClosed - Variable in class org.agrona.concurrent.status.AtomicCounter
 
isClosed - Variable in class org.agrona.concurrent.status.AtomicLongPosition
 
isClosed - Variable in class org.agrona.concurrent.status.UnsafeBufferPosition
 
isClosed - Variable in class org.agrona.MarkFile
 
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.CountedErrorHandler
Has this instance been closed.
isClosed() - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
Is this LoggingErrorHandler closed.
isClosed() - Method in class org.agrona.concurrent.status.AtomicCounter
Has this counter been closed?
isClosed() - Method in class org.agrona.concurrent.status.AtomicLongPosition
Has this Position been closed?
isClosed() - Method in class org.agrona.concurrent.status.Position
Has this Position been closed?
isClosed() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
Has this Position been closed?
isClosed() - Method in class org.agrona.MarkFile
Checks if MarkFile is closed.
isDebuggerAttached() - Static method in class org.agrona.SystemUtil
Is a debugger attached to the JVM?
isDigit(byte) - Static method in class org.agrona.AsciiEncoding
Check if the value is an ASCII-encoded digit.
isDirect - Variable in class org.agrona.ExpandableRingBuffer
 
isDirect() - Method in class org.agrona.ExpandableRingBuffer
Is the ByteBuffer used for backing storage direct, that is off Java heap, or not.
isEightDigitAsciiEncodedNumber(long) - Static method in class org.agrona.AsciiEncoding
Checks if the provided value represents an ASCII-encoded number which contains exactly eight digits.
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.IntArrayQueue
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.LongArrayQueue
isEmpty() - Method in class org.agrona.collections.LongHashSet
isEmpty() - Method in class org.agrona.collections.Object2IntCounterMap
Is the map empty.
isEmpty() - Method in class org.agrona.collections.Object2IntHashMap
isEmpty() - Method in class org.agrona.collections.Object2LongCounterMap
Is the map empty.
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() - Method in class org.agrona.ExpandableRingBuffer
Is the ring buffer currently empty.
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 int value even.
isEven(long) - Static method in class org.agrona.BitUtil
Is a long value even.
isExpandable() - Method in class org.agrona.concurrent.UnsafeBuffer
Is this buffer expandable to accommodate putting data into it beyond the current capacity?
isExpandable() - Method in class org.agrona.ExpandableArrayBuffer
Is this buffer expandable to accommodate putting data into it beyond the current capacity?
isExpandable() - Method in class org.agrona.ExpandableDirectByteBuffer
Is this buffer expandable to accommodate putting data into it beyond the current capacity?
isExpandable() - Method in interface org.agrona.MutableDirectBuffer
Is this buffer expandable to accommodate putting data into it beyond the current capacity?
isFourDigitsAsciiEncodedNumber(int) - Static method in class org.agrona.AsciiEncoding
Checks if the provided value represents an ASCII-encoded number which contains exactly four digits.
isLinux() - Static method in class org.agrona.SystemUtil
Is the operating system likely to be Linux based on SystemUtil.osName().
isOutOfBounds(int, int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
Determine if the requested index and length will fit within capacity.
isPositionValid - Variable in class org.agrona.collections.Int2IntHashMap.AbstractIterator
Is current position valid.
isPositionValid - Variable in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
isPositionValid - Variable in class org.agrona.collections.IntHashSet.IntIterator
 
isPositionValid - Variable in class org.agrona.collections.Long2LongHashMap.AbstractIterator
Is current position valid.
isPositionValid - Variable in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
isPositionValid - Variable in class org.agrona.collections.LongHashSet.LongIterator
 
isPositionValid - Variable in class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
isPositionValid - Variable in class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
isPositionValid - Variable in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
Is position valid.
isPositionValid - Variable in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
isPowerOfTwo(int) - Static method in class org.agrona.BitUtil
Is a value a positive power of 2.
isPowerOfTwo(long) - 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 - Variable in class org.agrona.concurrent.AgentInvoker
 
isRunning - Variable in class org.agrona.concurrent.AgentRunner
 
isRunning() - Method in class org.agrona.concurrent.AgentInvoker
Has the Agent been running?
isStarted - Variable in class org.agrona.concurrent.AgentInvoker
 
isStarted() - Method in class org.agrona.concurrent.AgentInvoker
Has the Agent been started?
isWindows() - Static method in class org.agrona.SystemUtil
Is the operating system likely to be Windows based on SystemUtil.osName().
isWithinThreshold - Variable in class org.agrona.concurrent.OffsetEpochNanoClock.TimeFields
 
isWithinThreshold() - Method in class org.agrona.concurrent.OffsetEpochNanoClock
Gets whether the clock sampled the initial time offset accurately.
isX64Arch() - Static method in class org.agrona.SystemUtil
Is the operating system architecture (SystemUtil.osArch()) represents an x86-based system.
isX64Arch(String) - Static method in class org.agrona.SystemUtil
 
ITERATION_THRESHOLD - Static variable in class org.agrona.nio.TransportPoller
Threshold beyond which individual channel/socket polling will swap to using a Selector.
ITERATION_THRESHOLD_DEFAULT - Static variable in class org.agrona.nio.TransportPoller
Default threshold beyond which individual channel/socket polling will swap to using a Selector.
ITERATION_THRESHOLD_PROP_NAME - Static variable in class org.agrona.nio.TransportPoller
System property name for the threshold beyond which individual channel/socket polling will swap to using a Selector.
iterator - Variable in class org.agrona.collections.Int2ObjectCache.EntrySet
 
iterator - Variable in class org.agrona.collections.Int2ObjectCache.KeySet
 
iterator - Variable in class org.agrona.collections.Int2ObjectCache.ValueCollection
 
iterator - Variable in class org.agrona.collections.IntArrayQueue
 
iterator - Variable in class org.agrona.collections.IntHashSet
 
iterator - Variable in class org.agrona.collections.Long2ObjectCache.EntrySet
 
iterator - Variable in class org.agrona.collections.Long2ObjectCache.KeySet
 
iterator - Variable in class org.agrona.collections.Long2ObjectCache.ValueCollection
 
iterator - Variable in class org.agrona.collections.LongArrayQueue
 
iterator - Variable in class org.agrona.collections.LongHashSet
 
iterator - Variable in class org.agrona.collections.ObjectHashSet
 
iterator - Variable in class org.agrona.collections.UnmodifiableCollectionView
 
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.IntArrayQueue
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.LongArrayQueue
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

J

JavaClassObject - Class in org.agrona.generation
A SimpleJavaFileObject that is used to store the bytes for a java class in memory.
JavaClassObject(String, JavaFileObject.Kind) - Constructor for class org.agrona.generation.JavaClassObject
Create an instance for a given class name.

K

k - Variable in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
 
k - Variable in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
 
KEY_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the key is stored.
keyIterator - Variable in class org.agrona.collections.Int2IntHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Int2ObjectHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Long2LongHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Long2ObjectHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Object2IntHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Object2LongHashMap.KeySet
 
keyIterator - Variable in class org.agrona.collections.Object2ObjectHashMap.KeySet
 
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
 
keyPosition() - Method in class org.agrona.collections.Int2IntHashMap.AbstractIterator
Returns position of the key of the current entry.
keyPosition() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
Returns position of the key of the current entry.
keyPosition() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
keys - Variable in class org.agrona.collections.BiInt2ObjectMap
 
keys - Variable in class org.agrona.collections.Int2ObjectCache
 
keys - Variable in class org.agrona.collections.Int2ObjectHashMap
 
keys - Variable in class org.agrona.collections.IntLruCache
 
keys - Variable in class org.agrona.collections.Long2ObjectCache
 
keys - Variable in class org.agrona.collections.Long2ObjectHashMap
 
keys - Variable in class org.agrona.collections.LongLruCache
 
keys - Variable in class org.agrona.collections.Object2IntCounterMap
 
keys - Variable in class org.agrona.collections.Object2IntHashMap
 
keys - Variable in class org.agrona.collections.Object2LongCounterMap
 
keys - Variable in class org.agrona.collections.Object2LongHashMap
 
keySet - Variable in class org.agrona.collections.Int2IntHashMap
 
keySet - Variable in class org.agrona.collections.Int2ObjectCache
 
keySet - Variable in class org.agrona.collections.Int2ObjectHashMap
 
keySet - Variable in class org.agrona.collections.Long2LongHashMap
 
keySet - Variable in class org.agrona.collections.Long2ObjectCache
 
keySet - Variable in class org.agrona.collections.Long2ObjectHashMap
 
keySet - Variable in class org.agrona.collections.Object2IntHashMap
 
keySet - Variable in class org.agrona.collections.Object2LongHashMap
 
keySet - Variable in class org.agrona.collections.Object2ObjectHashMap
 
keySet() - Method in class org.agrona.collections.Int2IntHashMap
keySet() - Method in class org.agrona.collections.Int2ObjectCache
keySet() - Method in class org.agrona.collections.Int2ObjectHashMap
keySet() - Method in class org.agrona.collections.Long2LongHashMap
keySet() - Method in class org.agrona.collections.Long2ObjectCache
keySet() - Method in class org.agrona.collections.Long2ObjectHashMap
keySet() - Method in class org.agrona.collections.Object2IntHashMap
keySet() - Method in class org.agrona.collections.Object2LongHashMap
keySet() - Method in class org.agrona.collections.Object2ObjectHashMap
KeySet() - Constructor for class org.agrona.collections.Int2IntHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Int2ObjectCache.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Int2ObjectHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Long2LongHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Long2ObjectCache.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Long2ObjectHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Object2IntHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Object2LongHashMap.KeySet
 
KeySet() - Constructor for class org.agrona.collections.Object2ObjectHashMap.KeySet
 

L

label - Variable in class org.agrona.console.ContinueBarrier
 
label() - Method in class org.agrona.concurrent.status.AtomicCounter
Return the label for the counter within the CountersManager.
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
Charset for the label.
labelCharset() - Method in class org.agrona.concurrent.status.CountersReader
The Charset used for the encoded label.
labelValue(AtomicBuffer, int) - Method in class org.agrona.concurrent.status.CountersReader
 
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 - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
lappedCount() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Get the number of times the transmitter has lapped this receiver around the buffer.
LAST_DIGIT_MASK - Static variable in class org.agrona.BitUtil
 
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.
latch - Variable in class org.agrona.concurrent.ShutdownSignalBarrier
 
latch - Variable in class org.agrona.concurrent.SigIntBarrier
 
LATCHES - Static variable in class org.agrona.concurrent.ShutdownSignalBarrier
 
LATEST_COUNTER_OFFSET - Static variable in class org.agrona.concurrent.broadcast.BroadcastBufferDescriptor
Offset within the trailer for where the latest sequence value is stored.
latestCounterIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
latestCounterIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
length - Variable in class org.agrona.AsciiSequenceView
 
length - Variable in class org.agrona.io.DirectBufferDataInput
 
length - Variable in class org.agrona.io.DirectBufferInputStream
 
length - Variable in class org.agrona.io.DirectBufferOutputStream
 
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.
limit() - Method in interface org.agrona.sbe.MessageFlyweight
The current limit in the buffer at which the message is being encoded or decoded.
limit(int) - Method in interface org.agrona.sbe.MessageFlyweight
The current limit in the buffer at which the message is being encoded or decoded.
loadFactor - Variable in class org.agrona.collections.BiInt2ObjectMap
 
loadFactor - Variable in class org.agrona.collections.Int2IntCounterMap
 
loadFactor - Variable in class org.agrona.collections.Int2IntHashMap
 
loadFactor - Variable in class org.agrona.collections.Int2ObjectHashMap
 
loadFactor - Variable in class org.agrona.collections.IntHashSet
 
loadFactor - Variable in class org.agrona.collections.Long2LongCounterMap
 
loadFactor - Variable in class org.agrona.collections.Long2LongHashMap
 
loadFactor - Variable in class org.agrona.collections.Long2ObjectHashMap
 
loadFactor - Variable in class org.agrona.collections.LongHashSet
 
loadFactor - Variable in class org.agrona.collections.Object2IntCounterMap
 
loadFactor - Variable in class org.agrona.collections.Object2IntHashMap
 
loadFactor - Variable in class org.agrona.collections.Object2LongCounterMap
 
loadFactor - Variable in class org.agrona.collections.Object2LongHashMap
 
loadFactor - Variable in class org.agrona.collections.Object2ObjectHashMap
 
loadFactor - Variable in class org.agrona.collections.ObjectHashSet
 
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.Object2IntCounterMap
Get the load factor applied for resize operations.
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.Object2LongCounterMap
Get the load factor applied for resize operations.
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.
loadProperties(PropertyAction, InputStream) - Static method in class org.agrona.SystemUtil
 
loadPropertiesFile(String) - Static method in class org.agrona.SystemUtil
Load system properties from a given filename or url with default to PropertyAction.REPLACE.
loadPropertiesFile(PropertyAction, 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 with default to PropertyAction.REPLACE.
loadPropertiesFiles(PropertyAction, String...) - Static method in class org.agrona.SystemUtil
Load system properties from a given set of filenames or URLs.
lock - Variable in class org.agrona.concurrent.status.ConcurrentCountersManager
 
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.
log - Variable in class org.agrona.concurrent.errors.LoggingErrorHandler
 
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.
LONG_DIGITS - Static variable in class org.agrona.AsciiEncoding
 
LONG_MAX_DIGITS - Static variable in class org.agrona.AsciiEncoding
Maximum number of digits in a US-ASCII-encoded long.
LONG_MAX_VALUE_DIGITS - Static variable in class org.agrona.AsciiEncoding
Long.MAX_VALUE split into components by 8 digits max.
LONG_MIN_VALUE_DIGITS - Static variable in class org.agrona.AsciiEncoding
Long.MIN_VALUE split into components by 8 digits max.
LONG_POW_10 - Static variable in class org.agrona.AsciiEncoding
Power of ten for long values.
Long2LongCounterMap - Class in org.agrona.collections
An open-addressing with linear probing hash map specialised for primitive key and counter pairs.
Long2LongCounterMap(int, float, long) - Constructor for class org.agrona.collections.Long2LongCounterMap
Construct a new counter map with the initial value for the counter provided.
Long2LongCounterMap(long) - Constructor for class org.agrona.collections.Long2LongCounterMap
Construct a new counter map with the initial value for the counter provided.
Long2LongHashMap - Class in org.agrona.collections
An open-addressing with linear probing hash map specialised for primitive key and value pairs.
Long2LongHashMap(int, float, long) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap(int, float, long, boolean) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap(long) - Constructor for class org.agrona.collections.Long2LongHashMap
 
Long2LongHashMap(Long2LongHashMap) - Constructor for class org.agrona.collections.Long2LongHashMap
Copy construct a new map from an existing one.
Long2LongHashMap.AbstractIterator - Class in org.agrona.collections
Base iterator implementation.
Long2LongHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys and values.
Long2LongHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Long2LongHashMap.EntrySet - Class in org.agrona.collections
Set of entries which supports optionally cached iterators to avoid allocation.
Long2LongHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Long2LongHashMap.KeyIterator.nextValue().
Long2LongHashMap.KeySet - Class in org.agrona.collections
Set of keys which supports optional cached iterators to avoid allocation.
Long2LongHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which supports optionally cached iterators to avoid allocation.
Long2LongHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values which supports access to unboxed values.
Long2NullableObjectHashMap<V> - Class in org.agrona.collections
Variation of Long2ObjectHashMap that allows null values.
Long2NullableObjectHashMap() - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
Constructs map with default settings.
Long2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Long2NullableObjectHashMap
Constructs map with given initial capacity and load factory and enables caching of iterators.
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
Constructs cache with provided configuration.
Long2ObjectCache.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Long2ObjectCache.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys via Long2ObjectCache.EntryIterator.getLongKey().
Long2ObjectCache.EntrySet - Class in org.agrona.collections
Set of entries which supports cached iterator to avoid allocation.
Long2ObjectCache.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Long2ObjectCache.KeyIterator.nextLong().
Long2ObjectCache.KeySet - Class in org.agrona.collections
A key set implementation which supports cached iterator to avoid allocation.
Long2ObjectCache.ValueCollection - Class in org.agrona.collections
Collection of values which supports cached iterator to avoid allocation.
Long2ObjectCache.ValueIterator - Class in org.agrona.collections
An iterator over values.
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
Constructs map with Long2ObjectHashMap.MIN_CAPACITY, Hashing.DEFAULT_LOAD_FACTOR and enables caching of iterators.
Long2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Long2ObjectHashMap
Constructs map with given initial capacity and load factory and enables caching of iterators.
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.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Long2ObjectHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which supports access to unboxed keys via Long2ObjectHashMap.EntryIterator.getLongKey().
Long2ObjectHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Long2ObjectHashMap.EntrySet - Class in org.agrona.collections
Set of entries which supports access via an optionally cached iterator to avoid allocation.
Long2ObjectHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys which supports access to unboxed keys via Long2ObjectHashMap.KeyIterator.nextLong().
Long2ObjectHashMap.KeySet - Class in org.agrona.collections
Set of keys which supports optionally cached iterators to avoid allocation.
Long2ObjectHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which supports optionally cached iterators to avoid allocation.
Long2ObjectHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values.
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.
LongArrayQueue - Class in org.agrona.collections
Queue of longs which stores the elements without boxing.
LongArrayQueue() - Constructor for class org.agrona.collections.LongArrayQueue
Construct a new queue defaulting to LongArrayQueue.MIN_CAPACITY capacity, LongArrayQueue.DEFAULT_NULL_VALUE and cached iterators.
LongArrayQueue(int, long) - Constructor for class org.agrona.collections.LongArrayQueue
Construct a new queue default to cached iterators.
LongArrayQueue(int, long, boolean) - Constructor for class org.agrona.collections.LongArrayQueue
Construct a new queue providing all the config options.
LongArrayQueue(long) - Constructor for class org.agrona.collections.LongArrayQueue
Construct a new queue defaulting to LongArrayQueue.MIN_CAPACITY capacity and cached iterators.
LongArrayQueue.LongIterator - Class in org.agrona.collections
Specialised Iterator from which the value can be retrieved without boxing via LongArrayQueue.LongIterator.nextValue().
longForEach(LongLongConsumer) - Method in class org.agrona.collections.Long2LongHashMap
longForEach(LongObjConsumer<V>) - Method in class org.agrona.collections.Long2ObjectHashMap
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, iterator caching support and 0 as a missing value.
LongHashSet(int) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed capacity, Hashing.DEFAULT_LOAD_FACTOR, iterator caching support and 0 as a missing value.
LongHashSet(int, float) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed initial capacity, load factor, iterator caching support and 0 as a missing value.
LongHashSet(int, float, boolean) - Constructor for class org.agrona.collections.LongHashSet
Construct a hash set with a proposed initial capacity, load factor, iterator caching support and -1 as a missing value.
LongHashSet.LongIterator - Class in org.agrona.collections
Iterator which supports unboxed access to the values via LongHashSet.LongIterator.nextValue().
LongIterator() - Constructor for class org.agrona.collections.LongArrayQueue.LongIterator
 
LongIterator() - Constructor for class org.agrona.collections.LongHashSet.LongIterator
 
LongLongConsumer - Interface in org.agrona.collections
Primitive specialisation of a BiConsumer for a pair of longs.
LongLongFunction - Interface in org.agrona.collections
Primitive specialisation of a BiFunction for a pair of longs.
LongLongPredicate - Interface in org.agrona.collections
Primitive specialisation of a BiPredicate for a pair of longs.
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.
LongObjConsumer<T> - Interface in org.agrona.collections
This is an (long, Object) primitive specialisation of a BiConsumer.
LongObjectToObjectFunction<T,R> - Interface in org.agrona.collections
This is an (long, Object) -> Object primitive specialisation of a BiFunction.
LongObjPredicate<T> - Interface in org.agrona.collections
This is an (long, Object) primitive specialisation of a BiPredicate.
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
Return value as long.
longValue() - Method in class org.agrona.collections.MutableLong
Return value as long.
LongVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.LongVerifier
 
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.SpecialisationGenerator
Main method.
major(int) - Static method in class org.agrona.SemanticVersion
Get the major version from a composite value.
makeMostRecent(int, Object, int) - Method in class org.agrona.collections.IntLruCache
 
makeMostRecent(long, Object, int) - Method in class org.agrona.collections.LongLruCache
 
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
Constructs a queue with the requested capacity.
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
Constructs an empty queue.
ManyToOneConcurrentLinkedQueueHead<E> - Class in org.agrona.concurrent
Value for the head that is expected to be padded.
ManyToOneConcurrentLinkedQueueHead() - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueueHead
 
ManyToOneConcurrentLinkedQueuePadding1 - Class in org.agrona.concurrent
Pad out a cache line to the left of a tail to prevent false sharing.
ManyToOneConcurrentLinkedQueuePadding1() - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
ManyToOneConcurrentLinkedQueuePadding1.Node<E> - Class in org.agrona.concurrent
 
ManyToOneConcurrentLinkedQueuePadding2<E> - Class in org.agrona.concurrent
Pad out a cache line between the tail and the head to prevent false sharing.
ManyToOneConcurrentLinkedQueuePadding2() - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
ManyToOneConcurrentLinkedQueueTail<E> - Class in org.agrona.concurrent
Value for the tail that is expected to be padded.
ManyToOneConcurrentLinkedQueueTail() - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueueTail
 
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_PRIVATE - Static variable in class org.agrona.IoUtil
 
MAP_READ_ONLY - Static variable in class org.agrona.IoUtil
 
MAP_READ_WRITE - Static variable in class org.agrona.IoUtil
 
MapEntry(int, int) - Constructor for class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
Constructs entry with given key and value.
MapEntry(int, V) - Constructor for class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
 
MapEntry(long, long) - Constructor for class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
Constructs entry with given key and value.
MapEntry(long, V) - Constructor for class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
 
MapEntry(K, int) - Constructor for class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
 
MapEntry(K, long) - Constructor for class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
 
MapEntry(K, V) - Constructor for class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
 
mapExistingFile(File, String) - Static method in class org.agrona.IoUtil
Check that file exists, open file, and return MappedByteBuffer for entire file as FileChannel.MapMode.READ_WRITE.
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 as FileChannel.MapMode.READ_WRITE.
mapExistingFile(File, FileChannel.MapMode, String) - Static method in class org.agrona.IoUtil
Check that file exists, open file, and return MappedByteBuffer for entire file for a given FileChannel.MapMode.
mapExistingFile(File, FileChannel.MapMode, String, long, long) - Static method in class org.agrona.IoUtil
Check that file exists, open file, and return MappedByteBuffer for only region specified for a given FileChannel.MapMode.
mapExistingFile(File, Consumer<String>, long, long) - Static method in class org.agrona.MarkFile
Map existing MarkFile.
mapExistingMarkFile(File, int, int, long, EpochClock, IntConsumer, Consumer<String>) - Static method in class org.agrona.MarkFile
Map existing 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
Map new of existing MarkFile.
mapNullValue(Object) - Method in class org.agrona.collections.BiInt2NullableObjectMap
 
mapNullValue(Object) - Method in class org.agrona.collections.BiInt2ObjectMap
Interceptor for masking null values.
mapNullValue(Object) - Method in class org.agrona.collections.Int2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
Interceptor for masking null values.
mapNullValue(Object) - Method in class org.agrona.collections.Long2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
Longerceptor for masking null values.
mapNullValue(Object) - Method in class org.agrona.collections.Object2NullableObjectHashMap
 
mapNullValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
Handle incoming null value and optionally replace with another non-null counterpart.
mappedBuffer - Variable in class org.agrona.MarkFile
 
mappedByteBuffer() - Method in class org.agrona.MarkFile
Returns the underlying MappedByteBuffer.
markFile - Variable in class org.agrona.MarkFile
 
markFile() - Method in class org.agrona.MarkFile
Returns MarkFile.
MarkFile - Class in org.agrona
A MarkFile is used to mark the presence of a running component and to track liveness.
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, 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, 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.
markSupported() - Method in class org.agrona.io.DirectBufferInputStream
mask - Variable in class org.agrona.collections.Int2ObjectCache
 
mask - Variable in class org.agrona.collections.Long2ObjectCache
 
mask - Variable in class org.agrona.ExpandableRingBuffer
 
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.ArrayUtil
Maximum capacity to which an array can grow.
MAX_CAPACITY - Static variable in class org.agrona.ExpandableRingBuffer
Maximum capacity to which the ring buffer can grow which is 1 GB.
MAX_G_VALUE - Static variable in class org.agrona.SystemUtil
 
MAX_INTEGER_VALUE - Static variable in class org.agrona.AsciiEncoding
US-ASCII-encoded byte representation of the Integer.MAX_VALUE.
MAX_K_VALUE - Static variable in class org.agrona.SystemUtil
 
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.
MAX_LONG_VALUE - Static variable in class org.agrona.AsciiEncoding
US-ASCII-encoded byte representation of the Long.MAX_VALUE.
MAX_M_VALUE - Static variable in class org.agrona.SystemUtil
 
MAX_NODE_ID_AND_SEQUENCE_BITS - Static variable in class org.agrona.concurrent.SnowflakeIdGenerator
Total number of bits used to represent the distributed node and the sequence within a millisecond.
maxCapacity - Variable in class org.agrona.ExpandableRingBuffer
 
maxCapacity() - Method in class org.agrona.ExpandableRingBuffer
The maximum capacity to which the buffer can expand.
maxCounterId - Variable in class org.agrona.concurrent.status.CountersReader
Max counter ID.
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.
maxMeasurementRetries - Variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
maxMsgLength - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
maxMsgLength - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
maxMsgLength - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
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.
maxNodeId - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
maxNodeId() - Method in class org.agrona.concurrent.SnowflakeIdGenerator
The max node identity value possible given the configured number of node ID bits.
maxParkPeriodNs - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Max park period in nanoseconds.
maxSequence - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
maxSequence() - Method in class org.agrona.concurrent.SnowflakeIdGenerator
The max sequence value possible given the configured number of sequence bits.
maxSpins - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Max number of spins.
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.
maxValue() - Method in class org.agrona.collections.Object2IntCounterMap
Get the maximum value stored in the map.
maxValue() - Method in class org.agrona.collections.Object2LongCounterMap
Get the maximum value stored in the map.
maxYields - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Max number of yields.
measurementThresholdNs - Variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
MemoryAccess - Class in org.agrona.concurrent
Memory access operations which encapsulate the use of Unsafe.
MemoryAccess() - Constructor for class org.agrona.concurrent.MemoryAccess
 
merge(int, int, IntIntFunction) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.merge(Object, Object, BiFunction).
merge(int, int, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.BiInt2ObjectMap
If the specified key is not already associated with a value or is associated with null, associates it with the given non-null value.
merge(int, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
If the specified key is not already associated with a value or is associated with null, associates it with the given non-null value.
merge(int, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.merge(Object, Object, BiFunction).
merge(long, long, LongLongFunction) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.merge(Object, Object, BiFunction).
merge(long, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
If the specified key is not already associated with a value or is associated with null, associates it with the given non-null value.
merge(long, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.merge(Object, Object, BiFunction).
merge(Integer, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
merge(Integer, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
merge(Long, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
merge(Long, V, BiFunction<? super V, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
merge(K, int, IntIntFunction) - Method in class org.agrona.collections.Object2IntHashMap
If the specified key is not already associated with a value associates it with the given value.
merge(K, long, LongLongFunction) - Method in class org.agrona.collections.Object2LongHashMap
If the specified key is not already associated with a value associates it with the given value.
MESSAGE_LENGTH_OFFSET - Static variable in class org.agrona.ExpandableRingBuffer
 
MESSAGE_TYPE_DATA - Static variable in class org.agrona.ExpandableRingBuffer
 
MESSAGE_TYPE_OFFSET - Static variable in class org.agrona.ExpandableRingBuffer
 
MESSAGE_TYPE_PADDING - Static variable in class org.agrona.ExpandableRingBuffer
 
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 metadata record in bytes.
metaDataBuffer - Variable in class org.agrona.concurrent.status.CountersReader
Meta-data buffer.
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
Time in microseconds since 1 Jan 1970 UTC.
MIN_CAPACITY - Static variable in class org.agrona.collections.BiInt2ObjectMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Int2IntCounterMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Int2IntHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Int2ObjectHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.IntArrayQueue
Minimum capacity for the queue which must also be a power of 2.
MIN_CAPACITY - Static variable in class org.agrona.collections.Long2LongCounterMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Long2LongHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Long2ObjectHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.LongArrayQueue
Minimum capacity for the queue which must also be a power of 2.
MIN_CAPACITY - Static variable in class org.agrona.collections.Object2IntCounterMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Object2IntHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Object2LongCounterMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Object2LongHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.collections.Object2ObjectHashMap
 
MIN_CAPACITY - Static variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Minimal required capacity of the ring buffer excluding RingBufferDescriptor.TRAILER_LENGTH.
MIN_CAPACITY - Static variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Minimal required capacity of the ring buffer excluding RingBufferDescriptor.TRAILER_LENGTH.
MIN_INTEGER_VALUE - Static variable in class org.agrona.AsciiEncoding
US-ASCII-encoded byte representation of the Integer.MIN_VALUE.
MIN_LONG_VALUE - Static variable in class org.agrona.AsciiEncoding
US-ASCII-encoded byte representation of the Long.MIN_VALUE.
minor(int) - Static method in class org.agrona.SemanticVersion
Get the minor version from a composite value.
minParkPeriodNs - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Min park period in nanoseconds.
MINUS_SIGN - Static variable in class org.agrona.AsciiEncoding
Byte value of the minus sign ('-').
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.
minValue() - Method in class org.agrona.collections.Object2IntCounterMap
Get the minimum value stored in the map.
minValue() - Method in class org.agrona.collections.Object2LongCounterMap
Get the minimum value stored in the map.
MISSING_VALUE - Static variable in class org.agrona.collections.IntHashSet
 
MISSING_VALUE - Static variable in class org.agrona.collections.LongHashSet
 
MISSING_VALUE - Static variable in class org.agrona.collections.ObjectHashSet
 
missingValue - Variable in class org.agrona.collections.Int2IntHashMap
 
missingValue - Variable in class org.agrona.collections.Long2LongHashMap
 
missingValue - Variable in class org.agrona.collections.Object2IntHashMap
 
missingValue - Variable in class org.agrona.collections.Object2LongHashMap
 
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
Default constructor.
MutableInteger(int) - Constructor for class org.agrona.collections.MutableInteger
Creates an instance with a value.
MutableLong - Class in org.agrona.collections
Holder for a long value that is mutable.
MutableLong() - Constructor for class org.agrona.collections.MutableLong
Default constructor.
MutableLong(long) - Constructor for class org.agrona.collections.MutableLong
Creates an instance with a value.
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
The number of ticks in nanoseconds the clock has advanced since starting.
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.OffsetEpochNanoClock
Time in nanoseconds since 1 Jan 1970 UTC.
nanoTime() - Method in class org.agrona.concurrent.SystemEpochNanoClock
Time in nanoseconds since 1 Jan 1970 UTC.
nanoTime() - Method in class org.agrona.concurrent.SystemNanoClock
The number of ticks in nanoseconds the clock has advanced since starting.
NATIVE_BYTE_ORDER - Static variable in class org.agrona.BufferUtil
Native byte order.
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(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.
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 CountersReader.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.
NEWLINE - Static variable in class org.agrona.PrintBufferUtil
 
newObservation(long, Throwable) - Method in class org.agrona.concurrent.errors.DistinctErrorLog
 
next - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1.Node
 
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.AbstractIterator
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.AbstractIterator
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.IntArrayQueue.IntIterator
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.AbstractIterator
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.AbstractIterator
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.LongArrayQueue.LongIterator
next() - Method in class org.agrona.collections.LongHashSet.LongIterator
next() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
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.AbstractIterator
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
next(int, int) - Static method in class org.agrona.BitUtil
Cycles indices of an array one at a time in a forward fashion.
next(int, int) - Static method in class org.agrona.collections.Int2IntCounterMap
 
next(int, int) - Static method in class org.agrona.collections.Int2IntHashMap
 
next(int, int) - Static method in class org.agrona.collections.IntHashSet
 
next(int, int) - Static method in class org.agrona.collections.Long2LongCounterMap
 
next(int, int) - Static method in class org.agrona.collections.Long2LongHashMap
 
next(int, int) - Static method in class org.agrona.collections.LongHashSet
 
next(int, int) - Static method in class org.agrona.collections.Object2ObjectHashMap
 
next(int, int) - Static method in class org.agrona.collections.ObjectHashSet
 
next(ErrorHandler) - Method in interface org.agrona.DelegatingErrorHandler
Set the next ErrorHandler to be called in a chain.
NEXT_OFFSET - Static variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
Offset of the next field.
nextCorrelationId() - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Get the next value that can be used for a correlation id on a 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 a 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 a message when a response needs to be correlated.
nextCounterId() - Method in class org.agrona.concurrent.status.CountersManager
 
nextId() - Method in interface org.agrona.concurrent.IdGenerator
Generate the next unique id.
nextId() - Method in class org.agrona.concurrent.SnowflakeIdGenerator
Generate the next id in sequence.
nextInt() - Method in class org.agrona.collections.Int2ObjectCache.KeyIterator
Return next key without boxing.
nextInt() - Method in class org.agrona.collections.Int2ObjectHashMap.KeyIterator
Return next key without boxing.
nextInt() - Method in class org.agrona.collections.Object2IntHashMap.ValueIterator
Get next value without boxing.
nextLong() - Method in class org.agrona.collections.Long2ObjectCache.KeyIterator
Return next key without boxing.
nextLong() - Method in class org.agrona.collections.Long2ObjectHashMap.KeyIterator
Return next key without boxing.
nextLong() - Method in class org.agrona.collections.Object2LongHashMap.ValueIterator
Get next value without boxing.
nextOffset - Variable in class org.agrona.concurrent.errors.DistinctErrorLog
 
nextOrdered(ManyToOneConcurrentLinkedQueuePadding1.Node<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1.Node
 
nextRecord - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
nextValue() - Method in class org.agrona.collections.Int2IntHashMap.KeyIterator
Return next key.
nextValue() - Method in class org.agrona.collections.Int2IntHashMap.ValueIterator
Return next value.
nextValue() - Method in class org.agrona.collections.IntArrayQueue.IntIterator
Get the next value from the iterator without boxing.
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
Return next key.
nextValue() - Method in class org.agrona.collections.Long2LongHashMap.ValueIterator
Return next value.
nextValue() - Method in class org.agrona.collections.LongArrayQueue.LongIterator
Get the next value from the iterator without boxing.
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
 
Node(E) - Constructor for class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1.Node
 
NODE_ID_BITS_DEFAULT - Static variable in class org.agrona.concurrent.SnowflakeIdGenerator
Default number of bits used to represent the distributed node or application which is 10 bits allowing for 1024 nodes (0-1023).
nodeBits - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
nodeId() - Method in class org.agrona.concurrent.SnowflakeIdGenerator
Node identity which scopes the id generation.
nodeIdAndSequenceBits - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
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 controlled so will go with default of ControllableIdleStrategy.PARK.
NOT_FREE_TO_REUSE - Static variable in class org.agrona.concurrent.status.CountersReader
Deadline to indicate counter is not free to be reused.
NOT_IDLE - Static variable in class org.agrona.concurrent.BackoffIdleStrategyData
Denotes a non-idle state.
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
UTF-8-encoded byte representation of the "null" string.
NULL_COUNTER_ID - Static variable in class org.agrona.concurrent.status.CountersReader
Can be used to representing a null counter id when passed as an argument.
NULL_DEADLINE - Static variable in class org.agrona.DeadlineTimerWheel
Represents a deadline not set in the wheel.
NULL_PROPERTY_VALUE - Static variable in class org.agrona.SystemUtil
Value a System.getProperties() can be set to so that null will be returned as if the property was not set.
NullReference - Class in org.agrona.collections
Sentinel value used in collections supporting null value references.
NullReference() - Constructor for class org.agrona.collections.NullReference
 
nullValue - Variable in class org.agrona.collections.IntArrayList
 
nullValue - Variable in class org.agrona.collections.IntArrayQueue
 
nullValue - Variable in class org.agrona.collections.LongArrayList
 
nullValue - Variable in class org.agrona.collections.LongArrayQueue
 
nullValue() - Method in class org.agrona.collections.IntArrayList
The value representing a null element.
nullValue() - Method in class org.agrona.collections.IntArrayQueue
The value representing a null element.
nullValue() - Method in class org.agrona.collections.LongArrayList
The value representing a null element.
nullValue() - Method in class org.agrona.collections.LongArrayQueue
The value representing a null element.

O

Object2IntCounterMap<K> - Class in org.agrona.collections
An open-addressing with linear probing hash map specialised for object and primitive counter pairs.
Object2IntCounterMap(int) - Constructor for class org.agrona.collections.Object2IntCounterMap
Construct a new counter map with the initial value for the counter provided.
Object2IntCounterMap(int, float, int) - Constructor for class org.agrona.collections.Object2IntCounterMap
Construct a new counter map with the initial value for the counter provided.
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.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Object2IntHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which can provide unboxed access and optionally avoid allocation.
Object2IntHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Object2IntHashMap.EntrySet - Class in org.agrona.collections
Set of entries which can optionally cache iterators to avoid allocation.
Object2IntHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys.
Object2IntHashMap.KeySet - Class in org.agrona.collections
Set of keys that can optionally cache iterators to avoid allocation.
Object2IntHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which can optionally cache iterators to avoid allocation.
Object2IntHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values providing unboxed access via Object2IntHashMap.ValueIterator.nextInt().
Object2LongCounterMap<K> - Class in org.agrona.collections
An open-addressing with linear probing hash map specialised for object and primitive counter pairs.
Object2LongCounterMap(int, float, long) - Constructor for class org.agrona.collections.Object2LongCounterMap
Construct a new counter map with the initial value for the counter provided.
Object2LongCounterMap(long) - Constructor for class org.agrona.collections.Object2LongCounterMap
Construct a new counter map with the initial value for the counter provided.
Object2LongHashMap<K> - Class in org.agrona.collections
Map implementation specialised for long values using open addressing and linear probing for cache efficient access.
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(long) - Constructor for class org.agrona.collections.Object2LongHashMap
Construct a map with default capacity and load factor.
Object2LongHashMap(Object2LongHashMap<K>) - Constructor for class org.agrona.collections.Object2LongHashMap
Copy construct a new map from an existing one.
Object2LongHashMap.AbstractIterator<T> - Class in org.agrona.collections
Base iterator implementation that contains basic logic of traversing the element in the backing array.
Object2LongHashMap.EntryIterator - Class in org.agrona.collections
Iterator over entries which can provide unboxed access and optionally avoid allocation.
Object2LongHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Object2LongHashMap.EntrySet - Class in org.agrona.collections
Set of entries which can optionally cache iterators to avoid allocation.
Object2LongHashMap.KeyIterator - Class in org.agrona.collections
Iterator over keys.
Object2LongHashMap.KeySet - Class in org.agrona.collections
Set of keys that can optionally cache iterators to avoid allocation.
Object2LongHashMap.ValueCollection - Class in org.agrona.collections
Collection of values which can optionally cache iterators to avoid allocation.
Object2LongHashMap.ValueIterator - Class in org.agrona.collections
Iterator over values providing unboxed access via Object2LongHashMap.ValueIterator.nextLong().
Object2NullableObjectHashMap<K,V> - Class in org.agrona.collections
Variation of Object2ObjectHashMap that allows null values.
Object2NullableObjectHashMap() - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
Default constructor.
Object2NullableObjectHashMap(int, float) - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
Defaults to avoiding allocation.
Object2NullableObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
 
Object2NullableObjectHashMap(Object2ObjectHashMap<K, V>) - Constructor for class org.agrona.collections.Object2NullableObjectHashMap
Copy construct a new map from an existing one.
Object2ObjectHashMap<K,V> - Class in org.agrona.collections
An open-addressing with linear probing hash map, same algorithm as Int2IntHashMap.
Object2ObjectHashMap() - Constructor for class org.agrona.collections.Object2ObjectHashMap
Default constructor, i.e.
Object2ObjectHashMap(int, float) - Constructor for class org.agrona.collections.Object2ObjectHashMap
Create a map with initial capacity and load factor.
Object2ObjectHashMap(int, float, boolean) - Constructor for class org.agrona.collections.Object2ObjectHashMap
 
Object2ObjectHashMap(Object2ObjectHashMap<K, V>) - Constructor for class org.agrona.collections.Object2ObjectHashMap
Copy construct a new map from an existing one.
Object2ObjectHashMap.AbstractIterator - Class in org.agrona.collections
Base iterator impl.
Object2ObjectHashMap.EntryIterator - Class in org.agrona.collections
An iterator over entries.
Object2ObjectHashMap.EntryIterator.MapEntry - Class in org.agrona.collections
An Map.Entry implementation.
Object2ObjectHashMap.EntrySet - Class in org.agrona.collections
An entry set implementation.
Object2ObjectHashMap.KeyIterator - Class in org.agrona.collections
An iterator over keys.
Object2ObjectHashMap.KeySet - Class in org.agrona.collections
A key set implementation.
Object2ObjectHashMap.ValueCollection - Class in org.agrona.collections
A collection of values.
Object2ObjectHashMap.ValueIterator - Class in org.agrona.collections
An iterator over values.
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
Iterator over the set which can be optionally cached to avoid allocation.
ObjectIntToIntFunction<T> - Interface in org.agrona.collections
This is an (Object, int) -> int primitive specialisation of a BiFunction.
ObjectIterator() - Constructor for class org.agrona.collections.ObjectHashSet.ObjectIterator
 
ObjectLongToLongFunction<T> - Interface in org.agrona.collections
This is an (Object, long) -> long primitive specialisation of a BiFunction.
ObjIntConsumer<T> - Interface in org.agrona.collections
This is an (Object, i) primitive specialisation of a BiConsumer.
ObjIntPredicate<T> - Interface in org.agrona.collections
This is an (Object, int) primitive specialisation of a BiPredicate.
ObjLongConsumer<T> - Interface in org.agrona.collections
This is an (Object, i) primitive specialisation of a BiConsumer.
ObjLongPredicate<T> - Interface in org.agrona.collections
This is an (Object, long) primitive specialisation of a BiPredicate.
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
offer(Integer) - Method in class org.agrona.collections.IntArrayQueue
offer(Long) - Method in class org.agrona.collections.LongArrayQueue
offerInt(int) - Method in class org.agrona.collections.IntArrayQueue
Offer an element to the tail of the queue without boxing.
offerLong(long) - Method in class org.agrona.collections.LongArrayQueue
Offer an element to the tail of the queue without boxing.
offset - Variable in class org.agrona.AsciiSequenceView
 
offset - Variable in class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
offset - Variable in class org.agrona.io.DirectBufferInputStream
 
offset - Variable in class org.agrona.io.DirectBufferOutputStream
 
offset - Variable in class org.agrona.io.ExpandableDirectBufferOutputStream
 
offset() - Method in class org.agrona.AsciiSequenceView
Gets the offset into the underlying buffer.
offset() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
The offset for the beginning of the next message in the transmission stream.
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.
OffsetEpochNanoClock - Class in org.agrona.concurrent
An accurate, zero-gc, pure-java, EpochNanoClock that calculates an initial epoch nano time based on System.currentTimeMillis() and then uses that offset to adjust the return value of System.nanoTime() to the UNIX epoch.
OffsetEpochNanoClock() - Constructor for class org.agrona.concurrent.OffsetEpochNanoClock
Constructs the clock with default configuration.
OffsetEpochNanoClock(int, long, long) - Constructor for class org.agrona.concurrent.OffsetEpochNanoClock
Constructs the clock with custom configuration parameters.
OffsetEpochNanoClock.TimeFields - Class in org.agrona.concurrent
 
ON_SPIN_WAIT_ENABLED - Static variable in class org.agrona.hints.ThreadHints
 
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.
onComplete(String, ClassLoader, JavaModule, boolean) - Method in class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
onDiscovery(String, ClassLoader, JavaModule, boolean) - Method in class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
onError(String, ClassLoader, JavaModule, boolean, Throwable) - Method in class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
onError(Throwable) - Method in class org.agrona.concurrent.CountedErrorHandler
Callback to notify of an error that has occurred when processing an operation or event.
onError(Throwable) - Method in class org.agrona.concurrent.errors.LoggingErrorHandler
Callback to notify of an error that has occurred when processing an operation or event.
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
Constructs queue with the requested capacity.
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.
onIgnored(TypeDescription, ClassLoader, JavaModule, boolean) - Method in class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
onMessage(int, MutableDirectBuffer, int, int) - Method in interface org.agrona.concurrent.ControlledMessageHandler
Called for the processing of each message read from a buffer in turn.
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.
onMessage(MutableDirectBuffer, int, int, int) - Method in interface org.agrona.ExpandableRingBuffer.MessageConsumer
Called for the processing of each message from a buffer in turn.
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 has expired.
onTransformation(TypeDescription, ClassLoader, JavaModule, boolean, DynamicType) - Method in class org.agrona.agent.BufferAlignmentAgent.AgentBuilderListener
 
openOutputStream() - Method in class org.agrona.generation.JavaClassObject
org.agrona - package org.agrona
Data structures and utilities useful for building high-performance Java applications.
org.agrona.agent - package org.agrona.agent
Java agent for instrumenting DirectBuffer implementations to verify aligned access.
org.agrona.collections - package org.agrona.collections
Collections classes that support primitive types and tend to be cache friendly.
org.agrona.concurrent - package org.agrona.concurrent
Concurrent data structures and utilities that support both on and off Java heap usage.
org.agrona.concurrent.broadcast - package org.agrona.concurrent.broadcast
Data structure for broadcasting messages from one source to many receivers via shared memory.
org.agrona.concurrent.errors - package org.agrona.concurrent.errors
A logger which provides a summary of distinct stacktrace based errors with counts and times.
org.agrona.concurrent.ringbuffer - package org.agrona.concurrent.ringbuffer
IPC ring buffers for messaging via shared memory.
org.agrona.concurrent.status - package org.agrona.concurrent.status
Counters for indicating status and telemetry which can be put in shared memory for live inspection.
org.agrona.console - package org.agrona.console
Utilities for interacting with a user via the console.
org.agrona.generation - package org.agrona.generation
Utilities to support code generation and compilation in-memory.
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
Bridging classes for allowing direct buffers implementations of DirectBuffer and MutableDirectBuffer to be used with Java IO streams.
org.agrona.nio - package org.agrona.nio
Utilities to help with Java NIO and allocation issues like on selectors.
org.agrona.sbe - package org.agrona.sbe
Common interfaces which can apply to SBE messages to support abstract usage.
OS_ARCH - Static variable in class org.agrona.SystemUtil
 
OS_NAME - Static variable in class org.agrona.SystemUtil
 
osArch() - Static method in class org.agrona.SystemUtil
Returns the name of the operating system architecture.
osName() - Static method in class org.agrona.SystemUtil
Get the name of the operating system as a lower case String.
outputDir - Variable in class org.agrona.generation.PackageOutputManager
 
OutputManager - Interface in org.agrona.generation
Abstraction that manages the destination of generated output.
OWNER_ID_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the owner id field is stored.

P

p000 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p000 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p000 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p000 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p000 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p000 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p001 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p001 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p001 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p001 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p001 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p001 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p002 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p002 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p002 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p002 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p002 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p002 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p003 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p003 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p003 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p003 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p003 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p003 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p004 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p004 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p004 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p004 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p004 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p004 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p005 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p005 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p005 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p005 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p005 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p005 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p006 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p006 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p006 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p006 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p006 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p006 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p007 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p007 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p007 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p007 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p007 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p007 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p008 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p008 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p008 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p008 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p008 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p008 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p009 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p009 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p009 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p009 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p009 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p009 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p010 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p010 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p010 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p010 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p010 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p010 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p011 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p011 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p011 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p011 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p011 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p011 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p012 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p012 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p012 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p012 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p012 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p012 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p013 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p013 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p013 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p013 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p013 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p013 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p014 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p014 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p014 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p014 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p014 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p014 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p015 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p015 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p015 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p015 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p015 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p015 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p016 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p016 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p016 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p016 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p016 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p016 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p017 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p017 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p017 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p017 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p017 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p017 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p018 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p018 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p018 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p018 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p018 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p018 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p019 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p019 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p019 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p019 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p019 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p019 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p020 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p020 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p020 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p020 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p020 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p020 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p021 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p021 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p021 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p021 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p021 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p021 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p022 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p022 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p022 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p022 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p022 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p022 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p023 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p023 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p023 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p023 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p023 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p023 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p024 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p024 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p024 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p024 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p024 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p024 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p025 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p025 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p025 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p025 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p025 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p025 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p026 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p026 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p026 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p026 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p026 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p026 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p027 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p027 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p027 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p027 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p027 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p027 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p028 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p028 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p028 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p028 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p028 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p028 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p029 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p029 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p029 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p029 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p029 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p029 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p030 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p030 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p030 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p030 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p030 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p030 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p031 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p031 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p031 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p031 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p031 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p031 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p032 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p032 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p032 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p032 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p032 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p032 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p033 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p033 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p033 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p033 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p033 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p033 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p034 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p034 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p034 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p034 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p034 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p034 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p035 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p035 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p035 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p035 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p035 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p035 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p036 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p036 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p036 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p036 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p036 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p036 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p037 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p037 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p037 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p037 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p037 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p037 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p038 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p038 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p038 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p038 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p038 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p038 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p039 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p039 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p039 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p039 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p039 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p039 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p040 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p040 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p040 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p040 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p040 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p040 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p041 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p041 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p041 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p041 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p041 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p041 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p042 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p042 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p042 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p042 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p042 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p042 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p043 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p043 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p043 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p043 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p043 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p043 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p044 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p044 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p044 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p044 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p044 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p044 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p045 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p045 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p045 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p045 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p045 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p045 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p046 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p046 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p046 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p046 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p046 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p046 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p047 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p047 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p047 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p047 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p047 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p047 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p048 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p048 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p048 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p048 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p048 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p048 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p049 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p049 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p049 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p049 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p049 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p049 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p050 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p050 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p050 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p050 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p050 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p050 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p051 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p051 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p051 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p051 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p051 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p051 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p052 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p052 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p052 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p052 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p052 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p052 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p053 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p053 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p053 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p053 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p053 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p053 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p054 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p054 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p054 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p054 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p054 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p054 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p055 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p055 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p055 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p055 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p055 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p055 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p056 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p056 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p056 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p056 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p056 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p056 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p057 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p057 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p057 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p057 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p057 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p057 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p058 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p058 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p058 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p058 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p058 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p058 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p059 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p059 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p059 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p059 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p059 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p059 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p060 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p060 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p060 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p060 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p060 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p060 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p061 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p061 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p061 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p061 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p061 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p061 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p062 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p062 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p062 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p062 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p062 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p062 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p063 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding1
 
p063 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingLhs
 
p063 - Variable in class org.agrona.concurrent.BackoffIdleStrategyPrePad
 
p063 - Variable in class org.agrona.concurrent.CachedEpochClockPadding
 
p063 - Variable in class org.agrona.concurrent.CachedNanoClockPadding
 
p063 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
 
p064 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p064 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p064 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p064 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p064 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p064 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p065 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p065 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p065 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p065 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p065 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p065 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p066 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p066 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p066 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p066 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p066 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p066 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p067 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p067 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p067 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p067 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p067 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p067 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p068 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p068 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p068 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p068 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p068 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p068 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p069 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p069 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p069 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p069 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p069 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p069 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p070 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p070 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p070 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p070 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p070 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p070 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p071 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p071 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p071 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p071 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p071 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p071 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p072 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p072 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p072 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p072 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p072 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p072 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p073 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p073 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p073 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p073 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p073 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p073 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p074 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p074 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p074 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p074 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p074 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p074 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p075 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p075 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p075 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p075 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p075 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p075 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p076 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p076 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p076 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p076 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p076 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p076 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p077 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p077 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p077 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p077 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p077 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p077 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p078 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p078 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p078 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p078 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p078 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p078 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p079 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p079 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p079 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p079 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p079 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p079 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p080 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p080 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p080 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p080 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p080 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p080 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p081 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p081 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p081 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p081 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p081 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p081 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p082 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p082 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p082 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p082 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p082 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p082 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p083 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p083 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p083 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p083 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p083 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p083 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p084 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p084 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p084 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p084 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p084 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p084 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p085 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p085 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p085 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p085 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p085 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p085 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p086 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p086 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p086 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p086 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p086 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p086 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p087 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p087 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p087 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p087 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p087 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p087 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p088 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p088 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p088 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p088 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p088 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p088 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p089 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p089 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p089 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p089 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p089 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p089 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p090 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p090 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p090 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p090 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p090 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p090 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p091 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p091 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p091 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p091 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p091 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p091 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p092 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p092 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p092 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p092 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p092 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p092 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p093 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p093 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p093 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p093 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p093 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p093 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p094 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p094 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p094 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p094 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p094 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p094 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p095 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p095 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p095 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p095 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p095 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p095 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p096 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p096 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p096 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p096 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p096 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p096 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p097 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p097 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p097 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p097 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p097 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p097 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p098 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p098 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p098 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p098 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p098 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p098 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p099 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p099 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p099 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p099 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p099 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p099 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p100 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p100 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p100 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p100 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p100 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p100 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p101 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p101 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p101 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p101 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p101 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p101 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p102 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p102 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p102 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p102 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p102 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p102 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p103 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p103 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p103 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p103 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p103 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p103 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p104 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p104 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p104 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p104 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p104 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p104 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p105 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p105 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p105 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p105 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p105 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p105 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p106 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p106 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p106 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p106 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p106 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p106 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p107 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p107 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p107 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p107 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p107 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p107 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p108 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p108 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p108 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p108 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p108 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p108 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p109 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p109 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p109 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p109 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p109 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p109 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p110 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p110 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p110 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p110 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p110 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p110 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p111 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p111 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p111 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p111 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p111 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p111 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p112 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p112 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p112 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p112 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p112 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p112 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p113 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p113 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p113 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p113 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p113 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p113 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p114 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p114 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p114 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p114 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p114 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p114 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p115 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p115 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p115 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p115 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p115 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p115 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p116 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p116 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p116 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p116 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p116 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p116 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p117 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p117 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p117 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p117 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p117 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p117 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p118 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p118 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p118 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p118 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p118 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p118 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p119 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p119 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p119 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p119 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p119 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p119 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p120 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p120 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p120 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p120 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p120 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p120 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p121 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p121 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p121 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p121 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p121 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p121 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p122 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p122 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p122 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p122 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p122 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p122 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p123 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p123 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p123 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p123 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p123 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p123 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p124 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p124 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p124 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p124 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p124 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p124 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p125 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p125 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p125 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p125 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p125 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p125 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p126 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p126 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p126 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p126 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p126 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p126 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p127 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding2
 
p127 - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorPaddingRhs
 
p127 - Variable in class org.agrona.concurrent.BackoffIdleStrategy
 
p127 - Variable in class org.agrona.concurrent.CachedEpochClock
 
p127 - Variable in class org.agrona.concurrent.CachedNanoClock
 
p127 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding2
 
p128 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p128 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p129 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p129 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p130 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p130 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p131 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p131 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p132 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p132 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p133 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p133 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p134 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p134 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p135 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p135 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p136 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p136 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p137 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p137 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p138 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p138 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p139 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p139 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p140 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p140 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p142 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p142 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p143 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p143 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p144 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p144 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p145 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p145 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p146 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p146 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p147 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p147 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p148 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p148 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p149 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p149 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p150 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p150 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p151 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p151 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p152 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p152 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p153 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p153 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p154 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p154 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p155 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p155 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p156 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p156 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p157 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p157 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p158 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p158 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p159 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p159 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p160 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p160 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p161 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p161 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p162 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p162 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p163 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p163 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p164 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p164 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p165 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p165 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p166 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p166 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p167 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p167 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p168 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p168 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p169 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p169 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p170 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p170 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p171 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p171 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p172 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p172 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p173 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p173 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p174 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p174 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p175 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p175 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p176 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p176 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p177 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p177 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p178 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p178 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p179 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p179 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p180 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p180 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p181 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p181 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p182 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p182 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p183 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p183 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p184 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p184 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p185 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p185 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p186 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p186 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p187 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p187 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p189 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p189 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p190 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p190 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p191 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p191 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p192 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p192 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
p193 - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueuePadding3
 
p193 - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
packageName - Variable in class org.agrona.generation.StringWriterOutputManager
 
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 interface org.agrona.concurrent.ringbuffer.RingBuffer
Record type is padding to prevent fragmentation in the buffer.
parentDir - Variable in class org.agrona.MarkFile
 
parentDirectory() - Method in class org.agrona.MarkFile
Returns parent directory.
PARK - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
Apply SleepingIdleStrategy with minimum sleep interval.
PARK_PERIOD_NANOSECONDS - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
 
PARKING - Static variable in class org.agrona.concurrent.BackoffIdleStrategyData
Denotes a parking state.
parkPeriodNs - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Park period in nanoseconds.
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.
parseEightDigitsLittleEndian(long) - Static method in class org.agrona.AsciiEncoding
Parses an eight-digit number out of an ASCII-encoded value assuming little-endian byte order.
parseFourDigitsLittleEndian(int) - Static method in class org.agrona.AsciiEncoding
Parses a four-digit number out of an ASCII-encoded value assuming little-endian byte order.
parseIntAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Parse the ASCII encoded integer value at a given index.
parseIntAscii(int, int) - Method in interface org.agrona.DirectBuffer
Parse the ASCII encoded integer value at a given index.
parseIntAscii(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
Parse an ASCII encoded int from a CharSequence.
parseIntOrDefault(String, int) - Static method in class org.agrona.Strings
Parse an int from a String.
parseLongAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Parse the ASCII encoded long integer value at a given index.
parseLongAscii(int, int) - Method in interface org.agrona.DirectBuffer
Parse the ASCII encoded long integer value at a given index.
parseLongAscii(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
Parse an ASCII encoded long from a CharSequence.
parseLongAsciiOverflowCheck(int, int, int[], int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
parseLongAsciiOverflowCheck(CharSequence, int, int, int[], int, int) - Static method in class org.agrona.AsciiEncoding
 
parseNaturalIntAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Parse the ASCII encoded int sized natural value at a given index.
parseNaturalIntAscii(int, int) - Method in interface org.agrona.DirectBuffer
Parse the ASCII encoded int sized natural value at a given index.
parseNaturalLongAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Parse the ASCII encoded long sized natural value at a given index.
parseNaturalLongAscii(int, int) - Method in interface org.agrona.DirectBuffer
Parse the ASCII encoded long sized natural value at a given index.
parsePositiveIntAscii(int, int, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
parsePositiveIntAscii(CharSequence, int, int, int, int) - Static method in class org.agrona.AsciiEncoding
 
parsePositiveIntAsciiOverflowCheck(int, int, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
parsePositiveIntAsciiOverflowCheck(CharSequence, int, int, int, int) - Static method in class org.agrona.AsciiEncoding
 
parsePositiveLongAscii(int, int, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
parsePositiveLongAscii(CharSequence, int, int, int, int) - Static method in class org.agrona.AsciiEncoding
 
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.
patch(int) - Static method in class org.agrona.SemanticVersion
Get the patch version from a composite value.
peek() - Method in class org.agrona.collections.IntArrayQueue
peek() - Method in class org.agrona.collections.LongArrayQueue
peek() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
peek() - Method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
peek() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
peekInt() - Method in class org.agrona.collections.IntArrayQueue
Peek at the element on the head of the queue without boxing.
peekLong() - Method in class org.agrona.collections.LongArrayQueue
Peek at the element on the head of the queue without boxing.
persist(Map<String, CharSequence>) - Static method in class org.agrona.generation.CompilerUtil
Persist source files to disc.
PID - Static variable in class org.agrona.SystemUtil
 
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.collections.IntArrayQueue
poll() - Method in class org.agrona.collections.LongArrayQueue
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.
pollIndex - Variable in class org.agrona.DeadlineTimerWheel
 
pollInt() - Method in class org.agrona.collections.IntArrayQueue
Poll the element from the head of the queue without boxing.
pollLong() - Method in class org.agrona.collections.LongArrayQueue
Poll the element from the head of the queue without boxing.
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.
posCounter - Variable in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
posCounter - Variable in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
posCounter - Variable in class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
posCounter - Variable in class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
position - Variable in class org.agrona.collections.Int2ObjectCache.AbstractIterator
 
position - Variable in class org.agrona.collections.Long2ObjectCache.AbstractIterator
 
position - Variable in class org.agrona.io.DirectBufferDataInput
 
position - Variable in class org.agrona.io.DirectBufferInputStream
 
position - Variable in class org.agrona.io.DirectBufferOutputStream
 
position - Variable in class org.agrona.io.ExpandableDirectBufferOutputStream
 
position() - Method in class org.agrona.collections.Int2ObjectCache.AbstractIterator
Position of the current element.
position() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
Position of the current element.
position() - Method in class org.agrona.collections.Long2ObjectCache.AbstractIterator
Position of the current element.
position() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
Position of the current element.
position() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
Position of the current element.
position() - Method in class org.agrona.collections.Object2LongHashMap.AbstractIterator
Position of the current element.
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.
position(int[]) - Method in class org.agrona.collections.IntHashSet.IntIterator
 
position(long[]) - Method in class org.agrona.collections.LongHashSet.LongIterator
 
position(T[]) - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
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
 
positionCounter - Variable in class org.agrona.collections.Int2IntHashMap.AbstractIterator
 
positionCounter - Variable in class org.agrona.collections.IntHashSet.IntIterator
 
positionCounter - Variable in class org.agrona.collections.Long2LongHashMap.AbstractIterator
 
positionCounter - Variable in class org.agrona.collections.LongHashSet.LongIterator
 
positionCounter - Variable in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
positionCounter - Variable in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
premain(String, Instrumentation) - Static method in class org.agrona.agent.BufferAlignmentAgent
Invoked when the agent is launched with the JVM and before the main application.
prepend(DistinctErrorLog.DistinctObservation[], DistinctErrorLog.DistinctObservation) - Static method in class org.agrona.concurrent.errors.DistinctErrorLog
 
present(Map<?, ?>, Object, String) - Static method in class org.agrona.Verify
Verify that a map contains an entry for a given key.
PRESERVE - Enum constant in enum class org.agrona.PropertyAction
Preserve existing property value if one exists.
prettyHexDump(DirectBuffer) - Static method in class org.agrona.PrintBufferUtil
Returns a hexadecimal dump of the specified DirectBuffer that is easy to read by humans.
prettyHexDump(DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil.HexUtil
 
prettyHexDump(DirectBuffer, int, int) - Static method in class org.agrona.PrintBufferUtil
Returns a hexadecimal dump of the specified DirectBuffer that is easy to read by humans, starting at the given offset using the given length.
previous(int, int) - Static method in class org.agrona.BitUtil
Cycles indices of an array one at a time in a backwards fashion.
primitiveType - Variable in class org.agrona.generation.SpecialisationGenerator.Substitution
 
PrintBufferUtil - Class in org.agrona
Useful utils to hex dump the Agrona's buffers.
PrintBufferUtil() - Constructor for class org.agrona.PrintBufferUtil
 
PrintBufferUtil.HexUtil - Class in org.agrona
 
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.
PropertyAction - Enum Class in org.agrona
Action to be taken for each property loaded into system properties.
PropertyAction() - Constructor for enum class org.agrona.PropertyAction
 
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
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.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
Set the position to a new proposedValue if greater than the current value without memory ordering semantics.
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
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.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
Set the position to the new proposedValue if greater than the current value with memory ordering semantics.
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) - Method in class org.agrona.collections.Int2IntCounterMap
Put the value for a key in the map.
put(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Put a key value pair in the map.
put(int, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Put a value into the map.
put(int, V) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.put(Object, Object) that takes a primitive int key.
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 in the map.
put(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Put a key value pair in the map.
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
Overloaded version of Map.put(Object, Object) that takes a primitive long key.
put(Integer, Integer) - Method in class org.agrona.collections.Int2IntHashMap
put(Integer, V) - Method in class org.agrona.collections.Int2ObjectCache
put(Integer, V) - Method in class org.agrona.collections.Int2ObjectHashMap
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.Long2ObjectHashMap
put(K, int) - Method in class org.agrona.collections.Object2IntCounterMap
Put the value for a key in the map.
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.Object2LongCounterMap
Put the value for a key in the map.
put(K, long) - Method in class org.agrona.collections.Object2LongHashMap
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, Long) - Method in class org.agrona.collections.Object2LongHashMap
put(K, V) - 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
putAll(Int2IntHashMap) - Method in class org.agrona.collections.Int2IntHashMap
Put all values from the given map into this map without allocation.
putAll(Int2ObjectCache<? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
Put all values from the given map into this one without allocation.
putAll(Int2ObjectHashMap<? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Put all values from the given map into this one without allocation.
putAll(Long2LongHashMap) - Method in class org.agrona.collections.Long2LongHashMap
Put all values from the given map longo this map without allocation.
putAll(Long2ObjectCache<? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
Put all values from the given map longo this one without allocation.
putAll(Long2ObjectHashMap<? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Put all values from the given map longo this one without allocation.
putAll(Object2IntHashMap<? extends K>) - Method in class org.agrona.collections.Object2IntHashMap
Puts all values from the given map to this map.
putAll(Object2LongHashMap<? extends K>) - Method in class org.agrona.collections.Object2LongHashMap
Puts all values from the given map to this map.
putByte(int, byte) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putByte(int, byte) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putBytes(int, byte[]) - Method in class org.agrona.AbstractMutableDirectBuffer
Put an array of src into the underlying buffer.
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 class org.agrona.AbstractMutableDirectBuffer
Put an array 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 class org.agrona.AbstractMutableDirectBuffer
Put bytes into the underlying buffer for the view.
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 class org.agrona.AbstractMutableDirectBuffer
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 class org.agrona.AbstractMutableDirectBuffer
Put bytes from a source DirectBuffer into this MutableDirectBuffer at given indices.
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(int, byte) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with volatile semantics.
putChar(int, char) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putChar(int, char) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putChar(int, char, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putChar(int, char, ByteOrder) - 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(int, char) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with volatile semantics.
putDouble(int, double) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putDouble(int, double) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putDouble(int, double, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putDouble(int, double, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putFloat(int, float) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putFloat(int, float) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putFloat(int, float, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putFloat(int, float, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putIfAbsent(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.putIfAbsent(Object, Object) method.
putIfAbsent(int, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
If the specified key is not already associated with a value (or is mapped to null) associates it with the given value and returns null, else returns the current value.
putIfAbsent(int, V) - Method in class org.agrona.collections.Int2ObjectCache
If the specified key is not already associated with a value (or is mapped to null) associates it with the given value and returns null, else returns the current value.
putIfAbsent(int, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.putIfAbsent(Object, Object).
putIfAbsent(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.putIfAbsent(Object, Object) method.
putIfAbsent(long, V) - Method in class org.agrona.collections.Long2ObjectCache
If the specified key is not already associated with a value (or is mapped to null) associates it with the given value and returns null, else returns the current value.
putIfAbsent(long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.putIfAbsent(Object, Object).
putIfAbsent(Integer, Integer) - Method in class org.agrona.collections.Int2IntHashMap
putIfAbsent(Integer, V) - Method in class org.agrona.collections.Int2ObjectCache
putIfAbsent(Long, Long) - Method in class org.agrona.collections.Long2LongHashMap
putIfAbsent(Long, V) - Method in class org.agrona.collections.Long2ObjectCache
putIfAbsent(K, int) - Method in class org.agrona.collections.Object2IntHashMap
If the specified key is not already associated with a value associates it with the given value and returns Object2IntHashMap.missingValue(), else returns the current value.
putIfAbsent(K, long) - Method in class org.agrona.collections.Object2LongHashMap
If the specified key is not already associated with a value associates it with the given value and returns Object2LongHashMap.missingValue(), else returns the current value.
putIfAbsent(K, Integer) - Method in class org.agrona.collections.Object2IntHashMap
putIfAbsent(K, Long) - Method in class org.agrona.collections.Object2LongHashMap
putInt(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putInt(int, int) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putInt(int, int, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putInt(int, int, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putIntAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Puts an ASCII encoded int into the buffer.
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(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with ordered semantics.
putIntVolatile(int, int) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putIntVolatile(int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with volatile semantics.
putLabel(int, String) - Method in class org.agrona.concurrent.status.CountersManager
 
putLong(int, long) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putLong(int, long) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putLong(int, long, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putLong(int, long, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putLongAscii(int, long) - Method in class org.agrona.AbstractMutableDirectBuffer
Puts an ASCII encoded long integer into the buffer.
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(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with ordered store semantics.
putLongVolatile(int, long) - Method in interface org.agrona.concurrent.AtomicBuffer
Put a value to a given index with volatile semantics.
putLongVolatile(int, long) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with volatile semantics.
putNaturalIntAscii(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Puts an ASCII encoded int sized natural number into the buffer.
putNaturalIntAscii(int, int) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded int sized natural number into the buffer.
putNaturalIntAsciiFromEnd(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a natural number starting at its end position.
putNaturalIntAsciiFromEnd(int, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a natural number starting at its end position.
putNaturalLongAscii(int, long) - Method in class org.agrona.AbstractMutableDirectBuffer
Puts an ASCII encoded long sized natural number into the buffer.
putNaturalLongAscii(int, long) - Method in interface org.agrona.MutableDirectBuffer
Puts an ASCII encoded long sized natural number into the buffer.
putNaturalPaddedIntAscii(int, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a natural number with a specified maximum length.
putNaturalPaddedIntAscii(int, int, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a natural number with a specified maximum length.
putPositiveIntAscii(byte[], long, int, int) - Static method in class org.agrona.AbstractMutableDirectBuffer
 
putPositiveLongAscii(byte[], long, long, int) - Static method in class org.agrona.AbstractMutableDirectBuffer
 
putShort(int, short) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putShort(int, short) - Method in interface org.agrona.MutableDirectBuffer
Put a value to a given index.
putShort(int, short, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Put a value to a given index.
putShort(int, short, ByteOrder) - 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(int, short) - Method in class org.agrona.concurrent.UnsafeBuffer
Put a value to a given index with volatile semantics.
putStringAscii(int, CharSequence) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a CharSequence as ASCII bytes to the buffer with a length prefix.
putStringAscii(int, CharSequence) - Method in interface org.agrona.MutableDirectBuffer
Encode a CharSequence as ASCII bytes to the buffer with a length prefix.
putStringAscii(int, CharSequence, ByteOrder) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a CharSequence as ASCII bytes to the buffer with a length prefix.
putStringAscii(int, CharSequence, ByteOrder) - Method in interface org.agrona.MutableDirectBuffer
Encode a CharSequence as ASCII bytes to the buffer with a length prefix.
putStringAscii(int, String) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a String as ASCII bytes to the buffer with a length prefix.
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 class org.agrona.AbstractMutableDirectBuffer
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(int, String) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a String as UTF-8 bytes to the buffer with a length prefix.
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, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a String as UTF-8 bytes the buffer with a length prefix with a maximum encoded size check.
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) - Method in class org.agrona.AbstractMutableDirectBuffer
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, ByteOrder, int) - Method in class org.agrona.AbstractMutableDirectBuffer
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, CharSequence) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a CharSequence as ASCII bytes in the buffer without a length prefix.
putStringWithoutLengthAscii(int, CharSequence) - Method in interface org.agrona.MutableDirectBuffer
Encode a CharSequence as ASCII bytes in the buffer without a length prefix.
putStringWithoutLengthAscii(int, CharSequence, int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a CharSequence as ASCII bytes in the buffer without a length prefix taking a range of the value.
putStringWithoutLengthAscii(int, CharSequence, int, int) - Method in interface org.agrona.MutableDirectBuffer
Encode a CharSequence as ASCII bytes in the buffer without a length prefix taking a range of the value.
putStringWithoutLengthAscii(int, String) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a String as ASCII bytes in the buffer without a length prefix.
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 class org.agrona.AbstractMutableDirectBuffer
Encode a String as ASCII bytes in the buffer without a length prefix taking a range of the value.
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(int, String) - Method in class org.agrona.AbstractMutableDirectBuffer
Encode a String as UTF-8 bytes in the buffer without a length prefix.
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.
quietCloseAll(AutoCloseable...) - Static method in class org.agrona.CloseHelper
Close all closeables in closeables.
quietCloseAll(Collection<? extends AutoCloseable>) - Static method in class org.agrona.CloseHelper
Close all closeables in closeables.

R

read() - Method in class org.agrona.io.DirectBufferInputStream
read(byte[], int, int) - Method in class org.agrona.io.DirectBufferInputStream
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) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Read as many messages as are available to the end of the ring buffer.
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 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, 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, 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.
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
 
readBoolean() - Method in class org.agrona.io.DirectBufferDataInput
readByte() - Method in class org.agrona.io.DirectBufferDataInput
readChar() - Method in class org.agrona.io.DirectBufferDataInput
readDouble() - Method in class org.agrona.io.DirectBufferDataInput
readEightBytesLittleEndian(CharSequence, int) - Static method in class org.agrona.AsciiEncoding
 
readFloat() - Method in class org.agrona.io.DirectBufferDataInput
readFourBytesLittleEndian(CharSequence, int) - Static method in class org.agrona.AsciiEncoding
 
readFully(byte[]) - Method in class org.agrona.io.DirectBufferDataInput
readFully(byte[], int, int) - Method in class org.agrona.io.DirectBufferDataInput
readInt() - Method in class org.agrona.io.DirectBufferDataInput
readLine() - Method in class org.agrona.io.DirectBufferDataInput
readLine(Appendable) - Method in class org.agrona.io.DirectBufferDataInput
Reads the next line of text from the input stream.
readLong() - Method in class org.agrona.io.DirectBufferDataInput
readShort() - Method in class org.agrona.io.DirectBufferDataInput
readStringAscii() - Method in class org.agrona.io.DirectBufferDataInput
Reads in a string that has been encoded using ASCII format by MutableDirectBuffer.putStringAscii(int, CharSequence).
readStringAscii(Appendable) - Method in class org.agrona.io.DirectBufferDataInput
Get a String from bytes encoded in ASCII format that is length prefixed and append to an Appendable.
readStringUTF8() - Method in class org.agrona.io.DirectBufferDataInput
Reads in a string that has been encoded using UTF-8 format by MutableDirectBuffer.putStringUtf8(int, String).
readUnsignedByte() - Method in class org.agrona.io.DirectBufferDataInput
readUnsignedShort() - Method in class org.agrona.io.DirectBufferDataInput
readUTF() - Method in class org.agrona.io.DirectBufferDataInput
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.
receiver - Variable in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
 
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.
RecordDescriptor - Class in org.agrona.concurrent.broadcast
Description of the structure for a record in the broadcast buffer.
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.broadcast.RecordDescriptor
 
RecordDescriptor() - Constructor for class org.agrona.concurrent.ringbuffer.RecordDescriptor
 
recordOffset - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
ref - Variable in class org.agrona.collections.MutableReference
For convenient access.
REFERENCE_ID_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the reference id field is stored.
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.
register(String, Runnable) - Static method in class org.agrona.concurrent.SigInt
 
REGISTRATION_ID_OFFSET - Static variable in class org.agrona.concurrent.status.CountersReader
Offset in the record at which the registration id field is stored.
rehash(int) - Method in class org.agrona.collections.BiInt2ObjectMap
 
rehash(int) - Method in class org.agrona.collections.Int2IntCounterMap
 
rehash(int) - Method in class org.agrona.collections.Int2IntHashMap
 
rehash(int) - Method in class org.agrona.collections.Int2ObjectHashMap
 
rehash(int) - Method in class org.agrona.collections.IntHashSet
 
rehash(int) - Method in class org.agrona.collections.Long2LongCounterMap
 
rehash(int) - Method in class org.agrona.collections.Long2LongHashMap
 
rehash(int) - Method in class org.agrona.collections.Long2ObjectHashMap
 
rehash(int) - Method in class org.agrona.collections.LongHashSet
 
rehash(int) - Method in class org.agrona.collections.Object2IntCounterMap
 
rehash(int) - Method in class org.agrona.collections.Object2IntHashMap
 
rehash(int) - Method in class org.agrona.collections.Object2LongCounterMap
 
rehash(int) - Method in class org.agrona.collections.Object2LongHashMap
 
rehash(int) - Method in class org.agrona.collections.Object2ObjectHashMap
 
rehash(int) - Method in class org.agrona.collections.ObjectHashSet
 
releaseFence() - Static method in class org.agrona.concurrent.MemoryAccess
Ensures that loads and stores before the fence will not be reordered with stores after the fence.
remaining - Variable in class org.agrona.collections.Int2IntHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Int2ObjectCache.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.IntHashSet.IntIterator
 
remaining - Variable in class org.agrona.collections.Long2LongHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Long2ObjectCache.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.LongHashSet.LongIterator
 
remaining - Variable in class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
remaining - Variable in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
remaining() - Method in class org.agrona.collections.Int2IntHashMap.AbstractIterator
Number of remaining elements.
remaining() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
Number of remaining elements.
remaining() - Method in class org.agrona.collections.IntHashSet.IntIterator
Returns number of remaining (not yet visited) elements.
remaining() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
Number of remaining elements.
remaining() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
Number of remaining elements.
remaining() - Method in class org.agrona.collections.LongHashSet.LongIterator
Returns number of remaining (not yet visited) elements.
remaining() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
Return number of remaining elements.
remaining() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
Return number of remaining elements.
remaining() - Method in class org.agrona.io.DirectBufferDataInput
Return the number of bytes remaining in the buffer.
remainingCapacity() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
Get the remaining capacity for elements in the container given the current size.
remainingCapacity() - Method in interface org.agrona.concurrent.Pipe
Get the remaining capacity for elements in the container given the current size.
remove() - Method in class org.agrona.collections.Int2IntHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.Int2ObjectCache.AbstractIterator
remove() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.IntArrayQueue
remove() - Method in class org.agrona.collections.IntHashSet.IntIterator
remove() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.Long2ObjectCache.AbstractIterator
remove() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.LongArrayQueue
remove() - Method in class org.agrona.collections.LongHashSet.LongIterator
remove() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.Object2LongHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
remove() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
remove() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
remove() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
remove() - Method in class org.agrona.concurrent.ShutdownSignalBarrier
Remove the barrier from the shutdown signals.
remove(int) - Method in class org.agrona.collections.Int2IntCounterMap
Remove a counter value for a given key.
remove(int) - Method in class org.agrona.collections.Int2IntHashMap
Remove value from the map using given key avoiding boxing.
remove(int) - Method in class org.agrona.collections.Int2ObjectCache
Overloaded version of Map.remove(Object) that takes a primitive int key.
remove(int) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
Removes key and the corresponding value from the map.
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(int) - Method in class org.agrona.collections.IntHashSet
Specialised version of {this#remove(Object)} for int.
remove(int) - Method in class org.agrona.collections.LongArrayList
Remove at a given index.
remove(int, int) - Method in class org.agrona.collections.BiInt2ObjectMap
Remove a value from the map and return the value.
remove(int, int) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.remove(Object, Object).
remove(int, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(int, V) - Method in class org.agrona.collections.Int2ObjectCache
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(int, V) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.remove(Object, Object).
remove(long) - Method in class org.agrona.collections.Long2LongCounterMap
Remove a counter value for a given key.
remove(long) - Method in class org.agrona.collections.Long2LongHashMap
Remove value from the map using given key avoiding boxing.
remove(long) - Method in class org.agrona.collections.Long2ObjectCache
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(long) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
Removes key and the corresponding value from the map.
remove(long) - Method in class org.agrona.collections.Long2ObjectHashMap
Overloaded version of Map.remove(Object) that takes a primitive long key.
remove(long) - Method in class org.agrona.collections.LongHashSet
Specialised version of {this#remove(Object)} for long.
remove(long, long) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.remove(Object, Object).
remove(long, V) - Method in class org.agrona.collections.Long2ObjectCache
Removes the entry for the specified key only if it is currently mapped to the specified value.
remove(long, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.remove(Object, Object).
remove(Object) - Method in class org.agrona.collections.Int2IntHashMap
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache.EntrySet
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache
remove(Object) - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
remove(Object) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
remove(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
remove(Object) - Method in class org.agrona.collections.IntArrayList
remove(Object) - Method in class org.agrona.collections.IntHashSet
remove(Object) - Method in class org.agrona.collections.Long2LongHashMap
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache.EntrySet
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache
remove(Object) - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
remove(Object) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
remove(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
remove(Object) - Method in class org.agrona.collections.LongArrayList
remove(Object) - Method in class org.agrona.collections.LongHashSet
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(Object) - Method in class org.agrona.collections.ObjectHashSet
 
remove(Object) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
remove(Object) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
remove(Object, int) - Method in class org.agrona.collections.Object2IntHashMap
Primitive overload of the Map.remove(Object, Object) that avoids boxing on the value.
remove(Object, long) - Method in class org.agrona.collections.Object2LongHashMap
Primitive overload of the Map.remove(Object, Object) that avoids boxing on the value.
remove(Object, Object) - Method in class org.agrona.collections.Int2IntHashMap
remove(Object, Object) - Method in class org.agrona.collections.Int2ObjectCache
remove(Object, Object) - Method in class org.agrona.collections.Int2ObjectHashMap
remove(Object, Object) - Method in class org.agrona.collections.Long2LongHashMap
remove(Object, Object) - Method in class org.agrona.collections.Long2ObjectCache
remove(Object, Object) - Method in class org.agrona.collections.Long2ObjectHashMap
remove(Object, Object) - Method in class org.agrona.collections.Object2IntHashMap
remove(Object, Object) - Method in class org.agrona.collections.Object2LongHashMap
remove(K) - Method in class org.agrona.collections.Object2IntCounterMap
Remove a counter value for a given key.
remove(K) - Method in class org.agrona.collections.Object2LongCounterMap
Remove a counter value for a given key.
remove(Agent) - Method in class org.agrona.concurrent.DynamicCompositeAgent
 
remove(T[], int) - Static method in class org.agrona.collections.ArrayUtil
Remove an element from an array resulting in a new array if the index was inside the array otherwise the old array.
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.
removeAgent - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
removeAll(Collection<?>) - Method in class org.agrona.collections.IntHashSet
removeAll(Collection<?>) - Method in class org.agrona.collections.LongHashSet
removeAll(Collection<?>) - Method in class org.agrona.collections.ObjectHashSet
removeAll(Collection<?>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
removeAll(Collection<?>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
removeAll(IntArrayList) - Method in class org.agrona.collections.IntArrayList
Removes all of this collection's elements that are also contained in the specified list.
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(LongArrayList) - Method in class org.agrona.collections.LongArrayList
Removes all of this collection's elements that are also contained in the specified list.
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(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
removeAt(int) - Method in class org.agrona.collections.IntArrayList
Remove at a given index.
removeAt(int) - Method in class org.agrona.collections.LongArrayList
Remove at a given index.
removedCount() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
The number of items removed from this container since creation.
removedCount() - Method in interface org.agrona.concurrent.Pipe
The number of items removed from this container since creation.
removeIf(Predicate<? super Integer>) - Method in class org.agrona.collections.Int2ObjectCache.KeySet
removeIf(Predicate<? super Integer>) - Method in class org.agrona.collections.IntHashSet
removeIf(Predicate<? super Long>) - Method in class org.agrona.collections.Long2ObjectCache.KeySet
removeIf(Predicate<? super Long>) - Method in class org.agrona.collections.LongHashSet
removeIf(Predicate<? super Map.Entry<Integer, V>>) - Method in class org.agrona.collections.Int2ObjectCache.EntrySet
removeIf(Predicate<? super Map.Entry<Long, V>>) - Method in class org.agrona.collections.Long2ObjectCache.EntrySet
removeIf(Predicate<? super V>) - Method in class org.agrona.collections.Int2ObjectCache.ValueCollection
removeIf(Predicate<? super V>) - Method in class org.agrona.collections.Long2ObjectCache.ValueCollection
removeIf(List<T>, Predicate<T>) - Static method in class org.agrona.collections.CollectionUtil
Remove element from a list if it matches a predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.Int2IntHashMap.KeySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.Int2IntHashMap.ValueCollection
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.Int2ObjectHashMap.KeySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.IntArrayList
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.IntHashSet
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntPredicate) - Method in class org.agrona.collections.Object2IntHashMap.ValueCollection
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntIntPredicate) - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(IntObjPredicate<V>) - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfInt(ObjIntPredicate<? super K>) - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.Long2LongHashMap.KeySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.Long2LongHashMap.ValueCollection
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.Long2ObjectHashMap.KeySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.LongArrayList
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.LongHashSet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongPredicate) - Method in class org.agrona.collections.Object2LongHashMap.ValueCollection
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongLongPredicate) - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(LongObjPredicate<V>) - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeIfLong(ObjLongPredicate<? super K>) - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
Removes all the elements of this collection that satisfy the given predicate.
removeInt() - Method in class org.agrona.collections.IntArrayQueue
Remove the element at the head of the queue without boxing.
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 key and returns a primitive int value.
removeKey(K) - Method in class org.agrona.collections.Object2LongHashMap
Overloaded version of Map.remove(Object) that takes a key and returns a primitive long value.
removeLong() - Method in class org.agrona.collections.LongArrayQueue
Remove the element at the head of the queue without boxing.
removeLong(long) - Method in class org.agrona.collections.LongArrayList
Remove the first instance of a value if found in the list.
removeTrailingSlashes(StringBuilder) - Static method in class org.agrona.IoUtil
Remove trailing slash characters from a builder leaving the remaining characters.
removeTransformer() - Static method in class org.agrona.agent.BufferAlignmentAgent
Remove the bytecode transformer and associated bytecode weaving so the alignment checks are not made.
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, int, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(int, int, V, V) - Method in class org.agrona.collections.BiInt2ObjectMap
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(int, V) - Method in class org.agrona.collections.Int2ObjectCache
Replaces the entry for the specified key only if it is currently mapped to some value.
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.Int2ObjectCache
Replaces the entry for the specified key only if currently mapped to the specified value.
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.Long2ObjectCache
Replaces the entry for the specified key only if it is currently mapped to some value.
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.Long2ObjectCache
Replaces the entry for the specified key only if currently mapped to the specified value.
replace(long, V, V) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.replace(Object, Object, Object)
replace(Integer, Integer) - Method in class org.agrona.collections.Int2IntHashMap
replace(Integer, Integer, Integer) - Method in class org.agrona.collections.Int2IntHashMap
replace(Integer, V) - Method in class org.agrona.collections.Int2ObjectCache
replace(Integer, V, V) - Method in class org.agrona.collections.Int2ObjectCache
replace(Long, Long) - Method in class org.agrona.collections.Long2LongHashMap
replace(Long, Long, Long) - Method in class org.agrona.collections.Long2LongHashMap
replace(Long, V) - Method in class org.agrona.collections.Long2ObjectCache
replace(Long, V, V) - Method in class org.agrona.collections.Long2ObjectCache
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)
REPLACE - Enum constant in enum class org.agrona.PropertyAction
Replace existing property value if one exists.
replaceAll(BiFunction<? super Integer, ? super Integer, ? extends Integer>) - Method in class org.agrona.collections.Int2IntHashMap
replaceAll(BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
replaceAll(BiFunction<? super Integer, ? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
replaceAll(BiFunction<? super Long, ? super Long, ? extends Long>) - Method in class org.agrona.collections.Long2LongHashMap
replaceAll(BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
replaceAll(BiFunction<? super Long, ? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
replaceAllInt(IntIntFunction) - Method in class org.agrona.collections.Int2IntHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
replaceAllInt(IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectCache
Replaces each entry's value with the result of invoking the given function on that entry until all entries have been processed or the function throws an exception.
replaceAllInt(IntObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Int2ObjectHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
replaceAllInt(ObjectIntToIntFunction<? super K>) - Method in class org.agrona.collections.Object2IntHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
replaceAllLong(LongLongFunction) - Method in class org.agrona.collections.Long2LongHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
replaceAllLong(LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectCache
Replaces each entry's value with the result of invoking the given function on that entry until all entries have been processed or the function throws an exception.
replaceAllLong(LongObjectToObjectFunction<? super V, ? extends V>) - Method in class org.agrona.collections.Long2ObjectHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
replaceAllLong(ObjectLongToLongFunction<? super K>) - Method in class org.agrona.collections.Object2LongHashMap
Primitive specialised version of Map.replaceAll(BiFunction).
resampleIntervalNs - Variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
reset() - Method in class org.agrona.AsciiSequenceView
Reset the view to null.
reset() - Method in class org.agrona.collections.Int2IntHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.Int2ObjectCache.AbstractIterator
 
reset() - Method in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.IntArrayQueue.IntIterator
 
reset() - Method in class org.agrona.collections.IntHashSet.IntIterator
 
reset() - Method in class org.agrona.collections.Long2LongHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.Long2ObjectCache.AbstractIterator
 
reset() - Method in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.LongArrayQueue.LongIterator
 
reset() - Method in class org.agrona.collections.LongHashSet.LongIterator
 
reset() - Method in class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
reset() - Method in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
reset() - Method in class org.agrona.collections.UnmodifiableCollectionView.ReusableIterator
 
reset() - Method in class org.agrona.concurrent.BackoffIdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset() - Method in class org.agrona.concurrent.BusySpinIdleStrategy
Reset the internal state in preparation for entering an idle state again.
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 the internal state in preparation for entering an idle state again.
reset() - Method in class org.agrona.concurrent.SleepingIdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset() - Method in class org.agrona.concurrent.SleepingMillisIdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset() - Method in class org.agrona.concurrent.YieldingIdleStrategy
Reset the internal state in preparation for entering an idle state again.
reset(int) - Method in class org.agrona.ExpandableRingBuffer
Reset the buffer with a new capacity and empty state.
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(int) - Method in class org.agrona.ExpandableRingBuffer
 
resizeNotifier - Variable in class org.agrona.collections.ObjectHashSet
 
resizeNotifier(IntConsumer) - Method in class org.agrona.collections.ObjectHashSet
Add a Consumer that will be called when the collection is re-sized.
resizeThreshold - Variable in class org.agrona.collections.BiInt2ObjectMap
 
resizeThreshold - Variable in class org.agrona.collections.Int2IntCounterMap
 
resizeThreshold - Variable in class org.agrona.collections.Int2IntHashMap
 
resizeThreshold - Variable in class org.agrona.collections.Int2ObjectHashMap
 
resizeThreshold - Variable in class org.agrona.collections.IntHashSet
 
resizeThreshold - Variable in class org.agrona.collections.Long2LongCounterMap
 
resizeThreshold - Variable in class org.agrona.collections.Long2LongHashMap
 
resizeThreshold - Variable in class org.agrona.collections.Long2ObjectHashMap
 
resizeThreshold - Variable in class org.agrona.collections.LongHashSet
 
resizeThreshold - Variable in class org.agrona.collections.Object2IntCounterMap
 
resizeThreshold - Variable in class org.agrona.collections.Object2IntHashMap
 
resizeThreshold - Variable in class org.agrona.collections.Object2LongCounterMap
 
resizeThreshold - Variable in class org.agrona.collections.Object2LongHashMap
 
resizeThreshold - Variable in class org.agrona.collections.Object2ObjectHashMap
 
resizeThreshold - Variable in class org.agrona.collections.ObjectHashSet
 
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.Object2IntCounterMap
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.Object2LongCounterMap
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.
resolutionBitsToShift - Variable in class org.agrona.DeadlineTimerWheel
 
ResourceConsumer<T> - Interface in org.agrona.generation
Consumer of a resource which can throw IOExceptions.
retainAll(Collection<?>) - Method in class org.agrona.collections.IntHashSet
retainAll(Collection<?>) - Method in class org.agrona.collections.LongHashSet
retainAll(Collection<?>) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
retainAll(Collection<?>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
retainAll(IntArrayList) - Method in class org.agrona.collections.IntArrayList
Retains only the elements in this list that are contained in the specified list.
retainAll(IntHashSet) - Method in class org.agrona.collections.IntHashSet
Alias for IntHashSet.retainAll(Collection) for the specialized case when retaining on another IntHashSet, avoids boxing and allocations.
retainAll(LongArrayList) - Method in class org.agrona.collections.LongArrayList
Retains only the elements in this list that are contained in the specified list.
retainAll(LongHashSet) - Method in class org.agrona.collections.LongHashSet
Alias for LongHashSet.retainAll(Collection) for the specialized case when retaining on another LongHashSet, avoids boxing and allocations.
rethrow(Throwable) - Static method in class org.agrona.LangUtil
 
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 - Variable in class org.agrona.concurrent.CompositeAgent
 
roleName - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
roleName() - Method in interface org.agrona.concurrent.Agent
Get the name of this agent's role.
roleName() - Method in class org.agrona.concurrent.CompositeAgent
Get the name of this agent's role.
roleName() - Method in class org.agrona.concurrent.DynamicCompositeAgent
Get the name of this agent's role.
run() - Method in class org.agrona.concurrent.AgentRunner
Run an Agent.
run() - Static method in class org.agrona.concurrent.HighResolutionTimer
 

S

sample() - Method in class org.agrona.concurrent.OffsetEpochNanoClock
Explicitly resample the initial seeds.
sbeBlockLength() - Method in interface org.agrona.sbe.MessageFlyweight
The length of the root block in bytes.
sbeDecodedLength() - Method in interface org.agrona.sbe.MessageDecoderFlyweight
Gets the total length of this flyweight by moving from the end of the block though all the variable length fields.
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.
scanBackToConfirmStillZeroed(AtomicBuffer, int, int) - Static method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
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.
scratchBuffer - Variable in class org.agrona.concurrent.broadcast.CopyBroadcastReceiver
 
selectNowWithoutProcessing() - Method in class org.agrona.nio.TransportPoller
Explicit call to Selector.selectNow() followed by clearing out the set without processing.
selector - Variable in class org.agrona.nio.TransportPoller
Reference to the Selector for the transport.
SemanticVersion - Class in org.agrona
Store and extract a semantic version in a 4 byte integer.
SemanticVersion() - Constructor for class org.agrona.SemanticVersion
 
SEQUENCE_BITS_DEFAULT - Static variable in class org.agrona.concurrent.SnowflakeIdGenerator
Default number of bits used to represent the sequence within a millisecond which is 12 bits supporting 4,096,000 ids per-second per-node.
sequenceArrayOffset(long, long) - Static method in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
sequenceBits - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
sequences - Variable in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
SEQUENCES_ARRAY_BASE - Static variable in class org.agrona.concurrent.ManyToManyConcurrentArrayQueue
 
sequenceToBufferOffset(long, long) - Static method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
Compute buffer offset based on the given sequence and the mask.
serialVersionUID - Static variable in exception class org.agrona.agent.BufferAlignmentException
 
serialVersionUID - Static variable in exception class org.agrona.AsciiNumberFormatException
 
serialVersionUID - Static variable in class org.agrona.collections.MutableInteger
 
serialVersionUID - Static variable in class org.agrona.collections.MutableLong
 
serialVersionUID - Static variable in exception class org.agrona.concurrent.AgentTerminationException
 
set(boolean) - Method in class org.agrona.collections.MutableBoolean
Set the current value.
set(int) - Method in class org.agrona.collections.MutableInteger
Set the value.
set(int, Integer) - Method in class org.agrona.collections.IntArrayList
set(int, Long) - Method in class org.agrona.collections.LongArrayList
set(long) - Method in class org.agrona.collections.MutableLong
Set the value.
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
Sets the current position of the component without memory ordering semantics.
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
Sets the current position of the component without memory ordering semantics.
set(T) - Method in class org.agrona.collections.MutableReference
Set the current value of the reference.
setCounterKey(int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter key by on counter id, using a consumer callback to update the key metadata buffer.
setCounterKey(int, Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter key by on counter id, using a consumer callback to update the key metadata buffer.
setCounterKey(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter key by on counter id, copying the key metadata from the supplied buffer.
setCounterKey(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter key by on counter id, copying the key metadata from the supplied buffer.
setCounterLabel(int, String) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter label by counter id.
setCounterLabel(int, String) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter label by counter id.
setCounterOwnerId(int, long) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter owner id for a counter id.
setCounterOwnerId(int, long) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter owner id for a counter id.
setCounterReferenceId(int, long) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter reference id for a counter id.
setCounterReferenceId(int, long) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter reference id for a counter id.
setCounterRegistrationId(int, long) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter registration id for a counter id with ordered memory ordering.
setCounterRegistrationId(int, long) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter registration id for a counter id with ordered memory ordering.
setCounterValue(int, long) - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
Set an AtomicCounter value based for a counter id with ordered memory ordering.
setCounterValue(int, long) - Method in class org.agrona.concurrent.status.CountersManager
Set an AtomicCounter value based for a counter id with ordered memory ordering.
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(int, int, byte) - Method in class org.agrona.AbstractMutableDirectBuffer
Set a region of memory to a given byte value.
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
Sets the current position of the component with ordered memory semantics.
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
Sets the current position of the component with ordered memory semantics.
setOrdered(long) - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
Sets the current status indication of the component with ordered atomic memory semantics.
setPackageName(String) - Method in interface org.agrona.generation.DynamicPackageOutputManager
Sets the package name to be used by the Writer obtained through the very next call to OutputManager.createOutput(java.lang.String).
setPackageName(String) - Method in class org.agrona.generation.StringWriterOutputManager
Set the package name to be used for source files.
setSize - Variable in class org.agrona.collections.Int2ObjectCache
 
setSize - Variable in class org.agrona.collections.Long2ObjectCache
 
setSizeShift - Variable in class org.agrona.collections.Int2ObjectCache
 
setSizeShift - Variable in class org.agrona.collections.Long2ObjectCache
 
setValue(int) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
Sets the value of the current entry.
setValue(int) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
Set value at current position without boxing.
setValue(long) - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
Sets the value of the current entry.
setValue(long) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
Set value at current position without boxing.
setValue(Integer) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
setValue(Integer) - Method in class org.agrona.collections.Int2IntHashMap.EntryIterator
setValue(Integer) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
setValue(Integer) - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator
setValue(Long) - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
setValue(Long) - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator
setValue(Long) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
setValue(Long) - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator
setValue(V) - Method in class org.agrona.collections.Int2ObjectCache.EntryIterator
setValue(V) - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
setValue(V) - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator
setValue(V) - Method in class org.agrona.collections.Long2ObjectCache.EntryIterator
setValue(V) - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
setValue(V) - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator
setValue(V) - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
setValue(V) - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator
setVolatile(long) - Method in class org.agrona.concurrent.status.AtomicLongPosition
Sets the current position of the component with volatile memory semantics.
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
Sets the current position of the component with volatile memory semantics.
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
Offset of the sharedHeadCache field.
sharedHeadCache - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueueProducer
Shared cached head index.
SHIFT_FOR_SCALE - Static variable in class org.agrona.concurrent.AbstractConcurrentArrayQueue
Shift for scale.
shortValue() - Method in class org.agrona.collections.MutableInteger
Return value as short.
shortValue() - Method in class org.agrona.collections.MutableLong
Return value as short.
ShortVerifier() - Constructor for class org.agrona.agent.BufferAlignmentInterceptor.ShortVerifier
 
SHOULD_BOUNDS_CHECK - Static variable in class org.agrona.concurrent.UnsafeBuffer
 
SHOULD_BOUNDS_CHECK - Static variable in interface org.agrona.DirectBuffer
Should bounds-checks operations be done or not.
shouldAvoidAllocation - Variable in class org.agrona.collections.Int2IntHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Int2ObjectHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.IntArrayQueue
 
shouldAvoidAllocation - Variable in class org.agrona.collections.IntHashSet
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Long2LongHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Long2ObjectHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.LongArrayQueue
 
shouldAvoidAllocation - Variable in class org.agrona.collections.LongHashSet
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Object2IntHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Object2LongHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.Object2ObjectHashMap
 
shouldAvoidAllocation - Variable in class org.agrona.collections.ObjectHashSet
 
shuffleDown(int) - Method in class org.agrona.collections.Int2ObjectCache
 
shuffleDown(int) - Method in class org.agrona.collections.Long2ObjectCache
 
shuffleUp(int, int) - Method in class org.agrona.collections.Int2ObjectCache
 
shuffleUp(int, int) - Method in class org.agrona.collections.Long2ObjectCache
 
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 on the latch associated with this barrier.
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.
signalAll() - Method in class org.agrona.concurrent.ShutdownSignalBarrier
Programmatically signal all awaiting threads.
signalAndClearAll() - Static method in class org.agrona.concurrent.ShutdownSignalBarrier
 
signalReady(int) - Method in class org.agrona.MarkFile
Perform an ordered put of the version field.
signalTailIntent(AtomicBuffer, long) - Method in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
size - Variable in class org.agrona.collections.BiInt2ObjectMap
 
size - Variable in class org.agrona.collections.Int2IntCounterMap
 
size - Variable in class org.agrona.collections.Int2IntHashMap
 
size - Variable in class org.agrona.collections.Int2ObjectCache
 
size - Variable in class org.agrona.collections.Int2ObjectHashMap
 
size - Variable in class org.agrona.collections.IntArrayList
 
size - Variable in class org.agrona.collections.IntLruCache
 
size - Variable in class org.agrona.collections.Long2LongCounterMap
 
size - Variable in class org.agrona.collections.Long2LongHashMap
 
size - Variable in class org.agrona.collections.Long2ObjectCache
 
size - Variable in class org.agrona.collections.Long2ObjectHashMap
 
size - Variable in class org.agrona.collections.LongArrayList
 
size - Variable in class org.agrona.collections.LongLruCache
 
size - Variable in class org.agrona.collections.Object2IntCounterMap
 
size - Variable in class org.agrona.collections.Object2IntHashMap
 
size - Variable in class org.agrona.collections.Object2LongCounterMap
 
size - Variable in class org.agrona.collections.Object2LongHashMap
 
size - Variable in class org.agrona.collections.Object2ObjectHashMap
 
size - Variable in class org.agrona.collections.ObjectHashSet
 
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.IntArrayQueue
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.LongArrayQueue
size() - Method in class org.agrona.collections.LongHashSet
size() - Method in class org.agrona.collections.Object2IntCounterMap
The current size of the map which at not at Object2IntCounterMap.initialValue().
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.Object2LongCounterMap
The current size of the map which at not at Object2LongCounterMap.initialValue().
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
The number of items currently in the container.
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.ExpandableRingBuffer
Size of the ring buffer currently populated in bytes.
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
sizeOfArrayValues - Variable in class org.agrona.collections.IntHashSet
 
sizeOfArrayValues - Variable in class org.agrona.collections.LongHashSet
 
skip(long) - Method in class org.agrona.io.DirectBufferInputStream
skipBytes(int) - Method in class org.agrona.io.DirectBufferDataInput
sleep(long) - Static method in class org.agrona.MarkFile
Put thread to sleep for the given duration and restore interrupted status if thread is interrupted while sleeping.
SleepingIdleStrategy - Class in org.agrona.concurrent
When idle this strategy is to sleep for a specified period in nanoseconds.
SleepingIdleStrategy() - Constructor for class org.agrona.concurrent.SleepingIdleStrategy
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() - Constructor for class org.agrona.concurrent.SleepingMillisIdleStrategy
SleepingMillisIdleStrategy(long) - Constructor for class org.agrona.concurrent.SleepingMillisIdleStrategy
Constructed a new strategy that will sleep for a given period when idle.
sleepPeriodMs - Variable in class org.agrona.concurrent.SleepingMillisIdleStrategy
 
sleepPeriodNs - Variable in class org.agrona.concurrent.SleepingIdleStrategy
 
SnowflakeIdGenerator - Class in org.agrona.concurrent
Generate unique identifiers based on the Twitter Snowflake algorithm.
SnowflakeIdGenerator(int, int, long, long, EpochClock) - Constructor for class org.agrona.concurrent.SnowflakeIdGenerator
Construct a new Snowflake id generator for a given node with a provided offset and EpochClock.
SnowflakeIdGenerator(long) - Constructor for class org.agrona.concurrent.SnowflakeIdGenerator
Construct a new Snowflake id generator for a given node with a 0 offset from 1 Jan 1970 UTC and use SystemEpochClock.INSTANCE with SnowflakeIdGenerator.NODE_ID_BITS_DEFAULT node ID bits and SnowflakeIdGenerator.SEQUENCE_BITS_DEFAULT sequence bits.
sourceCode - Variable in class org.agrona.generation.CharSequenceJavaFileObject
 
sourceFileByName - Variable in class org.agrona.generation.StringWriterOutputManager
 
SpecialisationGenerator - Class in org.agrona.generation
Specialise classes written for primitive type int for other primitive types by substitution.
SpecialisationGenerator() - Constructor for class org.agrona.generation.SpecialisationGenerator
 
SpecialisationGenerator.Substitution - Class in org.agrona.generation
Substitution to be performed on each code line.
specialise(List<SpecialisationGenerator.Substitution>, String, String, String, String) - Static method in class org.agrona.generation.SpecialisationGenerator
Specialise a class replacing int types based on SpecialisationGenerator.Substitutions.
SPINNING - Static variable in class org.agrona.concurrent.BackoffIdleStrategyData
Denotes a spinning state.
spins - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Number of spins.
SRC_DIR - Static variable in class org.agrona.generation.SpecialisationGenerator
 
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.
startTime - Variable in class org.agrona.DeadlineTimerWheel
 
startTime() - Method in class org.agrona.DeadlineTimerWheel
The start time tick for the wheel from which it advances.
state - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Current state.
status - Variable in class org.agrona.concurrent.DynamicCompositeAgent
 
status() - Method in class org.agrona.concurrent.DynamicCompositeAgent
Get the DynamicCompositeAgent.Status for the Agent.
Status() - Constructor for enum class org.agrona.concurrent.DynamicCompositeAgent.Status
 
statusIndicator - Variable in class org.agrona.concurrent.ControllableIdleStrategy
 
StatusIndicator - Class in org.agrona.concurrent.status
Extends a StatusIndicatorReader with the ability to set the value so other readers can take action.
StatusIndicator() - Constructor for class org.agrona.concurrent.status.StatusIndicator
 
StatusIndicatorReader - Class in org.agrona.concurrent.status
Reads the value of a counter to indicate current status and what abstraction should be taken.
StatusIndicatorReader() - Constructor for class org.agrona.concurrent.status.StatusIndicatorReader
 
stopCounter - Variable in class org.agrona.collections.Int2IntHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.Int2ObjectHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.IntHashSet.IntIterator
 
stopCounter - Variable in class org.agrona.collections.Long2LongHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.Long2ObjectHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.LongHashSet.LongIterator
 
stopCounter - Variable in class org.agrona.collections.Object2IntHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.Object2LongHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.Object2ObjectHashMap.AbstractIterator
 
stopCounter - Variable in class org.agrona.collections.ObjectHashSet.ObjectIterator
 
STR_HEADER_LEN - Static variable in interface org.agrona.DirectBuffer
Length of the header on strings to denote the length of the string in bytes.
STRICT_ALIGNMENT_CHECKS - Static variable in interface org.agrona.concurrent.AtomicBuffer
Should alignment checks for atomic operations be done or not.
STRICT_ALIGNMENT_CHECKS_PROP_NAME - Static variable in interface org.agrona.concurrent.AtomicBuffer
Name of the system property that specify if the alignment checks for atomic operations are strict.
Strings - Class in org.agrona
Utility functions for using Strings.
Strings() - Constructor for class org.agrona.Strings
 
StringWriterOutputManager - Class in org.agrona.generation
An OutputManager which can store source files as StringWriter buy source file name.
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.SpecialisationGenerator.Substitution
Perform code substitutions.
Substitution(String, String, String) - Constructor for class org.agrona.generation.SpecialisationGenerator.Substitution
 
SUBSTITUTIONS - Static variable in class org.agrona.generation.SpecialisationGenerator
 
SUFFIX - Static variable in class org.agrona.generation.SpecialisationGenerator
 
sum(List<V>, ToIntFunction<V>) - Static method in class org.agrona.collections.CollectionUtil
Garbage free sum function.
SUN_PID_PROP_NAME - Static variable in class org.agrona.SystemUtil
 
swapTail(ManyToOneConcurrentLinkedQueuePadding1.Node<E>) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
 
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 - Variable in class org.agrona.collections.IntArrayQueue
 
tail - Variable in class org.agrona.collections.LongArrayQueue
 
tail - Variable in class org.agrona.concurrent.AbstractConcurrentArrayQueueProducer
Tail index.
tail - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueueTail
Tail of the queue.
tail - Variable in class org.agrona.ExpandableRingBuffer
 
tail() - Method in class org.agrona.ExpandableRingBuffer
Tail position in the buffer at which new bytes are appended.
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
Offset of the tail field.
TAIL_OFFSET - Static variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1
Offset of the tail field.
TAIL_POSITION_OFFSET - Static variable in class org.agrona.concurrent.ringbuffer.RingBufferDescriptor
Offset within the trailer for where the tail value is stored.
tailCounterIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
tailCounterIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
tailIntentCounterIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
tailIntentCountIndex - Variable in class org.agrona.concurrent.broadcast.BroadcastTransmitter
 
tailPositionIndex - Variable in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
tailPositionIndex - Variable in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
TEMP_DIR_NAME - Static variable in class org.agrona.generation.CompilerUtil
Temporary directory for files.
test(int, int) - Method in interface org.agrona.collections.IntIntPredicate
Evaluates this predicate on the given arguments.
test(int, T) - Method in interface org.agrona.collections.IntObjPredicate
Evaluates this predicate on the given arguments.
test(long, long) - Method in interface org.agrona.collections.LongLongPredicate
Evaluates this predicate on the given arguments.
test(long, T) - Method in interface org.agrona.collections.LongObjPredicate
Evaluates this predicate on the given arguments.
test(T, int) - Method in interface org.agrona.collections.ObjIntPredicate
Evaluates this predicate on the given arguments.
test(T, long) - Method in interface org.agrona.collections.ObjLongPredicate
Evaluates this predicate on the given arguments.
thread - Variable in class org.agrona.concurrent.AgentRunner
 
thread() - Method in class org.agrona.concurrent.AgentRunner
Get the thread which is running that Agent.
THREAD - Static variable in class org.agrona.concurrent.HighResolutionTimer
 
threadDump() - Static method in class org.agrona.SystemUtil
Get a formatted dump of all threads with associated state and stack traces.
threadDump(StringBuilder) - Static method in class org.agrona.SystemUtil
Write a formatted dump of all threads with associated state and stack traces to a provided StringBuilder.
ThreadHints - Class in org.agrona.hints
This class captures possible hints that may be used by some runtimes to improve code performance.
ThreadHints() - Constructor for class org.agrona.hints.ThreadHints
 
throwable - Variable in class org.agrona.concurrent.errors.DistinctErrorLog.DistinctObservation
 
throwParseIntError(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
throwParseIntError(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
 
throwParseIntOverflowError(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
throwParseIntOverflowError(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
 
throwParseLongError(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
throwParseLongError(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
 
throwParseLongOverflowError(int, int) - Method in class org.agrona.AbstractMutableDirectBuffer
 
throwParseLongOverflowError(CharSequence, int, int) - Static method in class org.agrona.AsciiEncoding
 
tickAllocation - Variable in class org.agrona.DeadlineTimerWheel
 
tickForTimerId(long) - Static method in class org.agrona.DeadlineTimerWheel
 
tickMask - Variable in class org.agrona.DeadlineTimerWheel
 
tickResolution - Variable in class org.agrona.DeadlineTimerWheel
 
tickResolution() - Method in class org.agrona.DeadlineTimerWheel
Resolution of a tick of the wheel in DeadlineTimerWheel.timeUnit()s.
ticksPerWheel - Variable in class org.agrona.DeadlineTimerWheel
 
ticksPerWheel() - Method in class org.agrona.DeadlineTimerWheel
The number of ticks, or spokes, per wheel.
time() - Method in class org.agrona.concurrent.CachedEpochClock
Time in milliseconds since 1 Jan 1970 UTC.
time() - Method in interface org.agrona.concurrent.EpochClock
Time in milliseconds since 1 Jan 1970 UTC.
time() - Method in class org.agrona.concurrent.SystemEpochClock
Time in milliseconds since 1 Jan 1970 UTC.
timeFields - Variable in class org.agrona.concurrent.OffsetEpochNanoClock
 
TimeFields(long, long, boolean) - Constructor for class org.agrona.concurrent.OffsetEpochNanoClock.TimeFields
 
timeMs - Variable in class org.agrona.concurrent.CachedEpochClockValue
Time in milliseconds.
timeNs - Variable in class org.agrona.concurrent.CachedNanoClockValue
Time in nanoseconds.
timeOfLastStateChange() - Method in interface org.agrona.ManagedResource
Get the time of the last state change.
timeOfLastStateChange(long) - Method in interface org.agrona.ManagedResource
Set the time of the last state change.
timerCount - Variable in class org.agrona.DeadlineTimerWheel
 
timerCount() - Method in class org.agrona.DeadlineTimerWheel
Number of active timers.
timerIdForSlot(int, int) - Static method in class org.agrona.DeadlineTimerWheel
 
TIMESTAMP_SEQUENCE_UPDATER - Static variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorValue
 
timestampFieldOffset - Variable in class org.agrona.MarkFile
 
timestampOffsetMs - Variable in class org.agrona.concurrent.SnowflakeIdGenerator
 
timestampOffsetMs() - Method in class org.agrona.concurrent.SnowflakeIdGenerator
Offset in milliseconds from Epoch of 1 Jan 1970 UTC which is subtracted to give 69 years of ids.
timestampOrdered(long) - Method in class org.agrona.MarkFile
Set timestamp field using an ordered put.
timestampSequence - Variable in class org.agrona.concurrent.AbstractSnowflakeIdGeneratorValue
 
timestampVolatile() - Method in class org.agrona.MarkFile
Perform volatile read of the timestamp field.
timestampWeak() - Method in class org.agrona.MarkFile
Perform weak/plain read of the timestamp field.
timeUnit - Variable in class org.agrona.DeadlineTimerWheel
 
timeUnit() - Method in class org.agrona.DeadlineTimerWheel
Time unit for the time ticks.
tmpDirName() - Static method in class org.agrona.IoUtil
Return the system property for java.io.tmpdir ensuring a File.separator is at the end.
tmpDirName() - Static method in class org.agrona.SystemUtil
The system property for java.io.tmpdir and ensuring a File.separator is at the end.
toArray() - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
toArray() - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
toArray() - Method in class org.agrona.collections.IntHashSet
toArray() - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
toArray() - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
toArray() - Method in class org.agrona.collections.LongHashSet
toArray() - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
toArray() - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
toArray() - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
toArray() - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
toArray() - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
toArray(T[]) - Method in class org.agrona.collections.Int2IntHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.Int2ObjectHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.IntHashSet
toArray(T[]) - Method in class org.agrona.collections.Long2LongHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.Long2ObjectHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.LongHashSet
toArray(T[]) - Method in class org.agrona.collections.Object2IntHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.Object2LongHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.collections.Object2ObjectHashMap.EntrySet
toArray(T[]) - Method in class org.agrona.concurrent.AbstractConcurrentArrayQueue
toArray(T[]) - Method in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueue
toHex(byte[]) - Static method in class org.agrona.BitUtil
Generate a string that is the hex representation of a given byte array.
toHex(byte[], int, int) - 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.
toHexByteArray(CharSequence, 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.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Int2IntHashMap
toString() - Method in class org.agrona.collections.Int2ObjectCache
toString() - Method in class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Int2ObjectHashMap
toString() - Method in class org.agrona.collections.IntArrayList
toString() - Method in class org.agrona.collections.IntArrayQueue
toString() - Method in class org.agrona.collections.IntHashSet
toString() - Method in class org.agrona.collections.Long2LongCounterMap
toString() - Method in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Long2LongHashMap
toString() - Method in class org.agrona.collections.Long2ObjectCache
toString() - Method in class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Long2ObjectHashMap
toString() - Method in class org.agrona.collections.LongArrayList
toString() - Method in class org.agrona.collections.LongArrayQueue
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.Object2IntCounterMap
toString() - Method in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Object2IntHashMap
toString() - Method in class org.agrona.collections.Object2LongCounterMap
toString() - Method in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
toString() - Method in class org.agrona.collections.Object2LongHashMap
toString() - Method in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
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.status.AtomicCounter
toString() - Method in class org.agrona.concurrent.status.AtomicLongPosition
toString() - Method in class org.agrona.concurrent.status.ConcurrentCountersManager
toString() - Method in class org.agrona.concurrent.status.CountersManager
toString() - Method in class org.agrona.concurrent.status.UnsafeBufferPosition
toString() - Method in class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
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
toString(int) - Static method in class org.agrona.SemanticVersion
Generate a String representation of the semantic version in the format major.minor.patch.
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
Default constructor.
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.
tryClaim(int, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Try to claim a space in the underlying ring-buffer into which a message can be written with zero copy semantics.
tryClaim(int, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Try to claim a space in the underlying ring-buffer into which a message can be written with zero copy semantics.
tryClaim(int, int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Try to claim a space in the underlying ring-buffer into which a message can be written with zero copy semantics.
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
Constant indicating an invalid/unknown array index.
unlock() - Method in class org.agrona.concurrent.NoOpLock
The lock has never been taken so no effect.
unmap(ByteBuffer) - Static method in class org.agrona.IoUtil
Unmap a ByteBuffer without waiting for the next GC cycle if its memory mapped.
unmap(MappedByteBuffer) - Static method in class org.agrona.IoUtil
Unmap a MappedByteBuffer without waiting for the next GC cycle.
unmapNullValue(Object) - Method in class org.agrona.collections.BiInt2NullableObjectMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.BiInt2ObjectMap
Interceptor for unmasking null values.
unmapNullValue(Object) - Method in class org.agrona.collections.Int2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Int2ObjectHashMap
Interceptor for unmasking null values.
unmapNullValue(Object) - Method in class org.agrona.collections.Long2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Long2ObjectHashMap
Longerceptor for unmasking null values.
unmapNullValue(Object) - Method in class org.agrona.collections.Object2NullableObjectHashMap
 
unmapNullValue(Object) - Method in class org.agrona.collections.Object2ObjectHashMap
Handle incoming non-null value and optionally replace it with the null value counterpart.
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
Constructs an unmodifiable view over collection.
UnmodifiableCollectionView.ReusableIterator - Class in org.agrona.collections
A stateful reusable iterator.
UNSAFE - Static variable in class org.agrona.UnsafeAccess
Reference to the Unsafe instance.
UnsafeAccess - Class in org.agrona
Obtain access 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(long, int) - Constructor for class org.agrona.concurrent.UnsafeBuffer
Attach a view to an off-heap memory region by address.
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
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
StatusIndicator which wraps an AtomicBuffer with a given counter id.
UnsafeBufferStatusIndicator(AtomicBuffer, int) - Constructor for class org.agrona.concurrent.status.UnsafeBufferStatusIndicator
Map a status indicator over a buffer.
UNUSED_BITS - Static variable in class org.agrona.concurrent.SnowflakeIdGenerator
High order 2's compliment bit which is unused.
update(long) - Method in class org.agrona.concurrent.CachedEpochClock
Update the value of the timestamp in with release ordered semantics.
update(long) - Method in class org.agrona.concurrent.CachedNanoClock
Update the value of the timestamp with release memory ordered semantics.
updateKey(Consumer<MutableDirectBuffer>) - Method in class org.agrona.concurrent.status.AtomicCounter
Update the key for a counter constructed with a CountersManager.
updateKey(DirectBuffer, int, int) - Method in class org.agrona.concurrent.status.AtomicCounter
Update the key for a counter constructed with a CountersManager.
updateLabel(String) - Method in class org.agrona.concurrent.status.AtomicCounter
Update the label for the counter constructed with a CountersManager.

V

v - Variable in class org.agrona.collections.Int2IntHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Int2ObjectHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Long2LongHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Long2ObjectHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Object2IntHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Object2LongHashMap.EntryIterator.MapEntry
 
v - Variable in class org.agrona.collections.Object2ObjectHashMap.EntryIterator.MapEntry
 
validate() - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
Validate that the current received record is still valid and has not been overwritten.
validate(long, AtomicBuffer, int) - Method in class org.agrona.concurrent.broadcast.BroadcastReceiver
 
validateCounterId(int) - Method in class org.agrona.concurrent.status.CountersReader
Validate if counter Id is valid.
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.
validateOffsets(int, int) - Static method in class org.agrona.MarkFile
 
validatePositivePowerOfTwo(int) - Static method in class org.agrona.collections.CollectionUtil
Validate that a number is a power of two.
valOrNull(int) - Method in class org.agrona.collections.Int2IntHashMap
 
valOrNull(long) - Method in class org.agrona.collections.Long2LongHashMap
 
value - Variable in class org.agrona.collections.MutableBoolean
For convenient access.
value - Variable in class org.agrona.collections.MutableInteger
The value.
value - Variable in class org.agrona.collections.MutableLong
The value.
value - Variable in class org.agrona.concurrent.ManyToOneConcurrentLinkedQueuePadding1.Node
 
value - Variable in class org.agrona.concurrent.status.AtomicLongPosition
 
valueCollection - Variable in class org.agrona.collections.Int2ObjectCache
 
valueCollection - Variable in class org.agrona.collections.Int2ObjectHashMap
 
valueCollection - Variable in class org.agrona.collections.Long2ObjectCache
 
valueCollection - Variable in class org.agrona.collections.Long2ObjectHashMap
 
valueCollection - Variable in class org.agrona.collections.Object2IntHashMap
 
valueCollection - Variable in class org.agrona.collections.Object2LongHashMap
 
valueCollection - Variable in class org.agrona.collections.Object2ObjectHashMap
 
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 - Variable in class org.agrona.collections.Int2IntHashMap.ValueCollection
 
valueIterator - Variable in class org.agrona.collections.Int2ObjectHashMap.ValueCollection
 
valueIterator - Variable in class org.agrona.collections.Long2LongHashMap.ValueCollection
 
valueIterator - Variable in class org.agrona.collections.Long2ObjectHashMap.ValueCollection
 
valueIterator - Variable in class org.agrona.collections.Object2IntHashMap.ValueCollection
 
valueIterator - Variable in class org.agrona.collections.Object2LongHashMap.ValueCollection
 
valueIterator - Variable in 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 class org.agrona.concurrent.ControlledMessageHandler.Action
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.agrona.concurrent.DynamicCompositeAgent.Status
Returns the enum constant of this class with the specified name.
valueOf(String) - Static method in enum class org.agrona.PropertyAction
Returns the enum constant of this class with the specified name.
valueOrNull(int) - Method in class org.agrona.collections.Object2IntHashMap
 
valueOrNull(long) - Method in class org.agrona.collections.Object2LongHashMap
 
values - Variable in class org.agrona.collections.BiInt2ObjectMap
 
values - Variable in class org.agrona.collections.Int2IntHashMap
 
values - Variable in class org.agrona.collections.Int2ObjectCache
 
values - Variable in class org.agrona.collections.Int2ObjectHashMap
 
values - Variable in class org.agrona.collections.IntHashSet
 
values - Variable in class org.agrona.collections.IntLruCache
 
values - Variable in class org.agrona.collections.Long2LongHashMap
 
values - Variable in class org.agrona.collections.Long2ObjectCache
 
values - Variable in class org.agrona.collections.Long2ObjectHashMap
 
values - Variable in class org.agrona.collections.LongHashSet
 
values - Variable in class org.agrona.collections.LongLruCache
 
values - Variable in class org.agrona.collections.Object2IntCounterMap
 
values - Variable in class org.agrona.collections.Object2IntHashMap
 
values - Variable in class org.agrona.collections.Object2LongCounterMap
 
values - Variable in class org.agrona.collections.Object2LongHashMap
 
values - Variable in class org.agrona.collections.ObjectHashSet
 
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 class org.agrona.concurrent.ControlledMessageHandler.Action
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.agrona.concurrent.DynamicCompositeAgent.Status
Returns an array containing the constants of this enum class, in the order they are declared.
values() - Static method in enum class org.agrona.PropertyAction
Returns an array containing the constants of this enum class, in the order they are declared.
valuesBuffer - Variable in class org.agrona.concurrent.status.CountersReader
Values buffer.
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, other ordering issues and the JVM crashes.
verifyAlignment() - Method in class org.agrona.concurrent.UnsafeBuffer
Verify that the underlying buffer is correctly aligned to prevent word tearing, other ordering issues and the JVM crashes.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.CharVerifier
Verify alignment of the char types.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.DoubleVerifier
Verify alignment of the double types.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.FloatVerifier
Verify alignment of the float types.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.IntVerifier
Verify alignment of the int types.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.LongVerifier
Verify alignment of the long types.
verifyAlignment(int, DirectBuffer) - Static method in class org.agrona.agent.BufferAlignmentInterceptor.ShortVerifier
Verify alignment of the short types.
verifyClaimedSpaceNotReleased(AtomicBuffer, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
 
verifyClaimedSpaceNotReleased(AtomicBuffer, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
 
verifyNull(Object, String) - Static method in class org.agrona.Verify
Verify that a reference is null.
versionFieldOffset - Variable in class org.agrona.MarkFile
 
versionVolatile() - Method in class org.agrona.MarkFile
Perform volatile read of the version field.
versionWeak() - Method in class org.agrona.MarkFile
Perform weak/plain read of the version field.
viewer - Variable in class org.agrona.collections.UnmodifiableCollectionView
 

W

waitForFileMapping(Consumer<String>, File, long, EpochClock) - Static method in class org.agrona.MarkFile
Await the creation of the MarkFile.
wheel - Variable in class org.agrona.DeadlineTimerWheel
 
withOutput(String, ResourceConsumer<Writer>) - Method in interface org.agrona.generation.OutputManager
Create named output and call ResourceConsumer.accept(Object).
workLoop(IdleStrategy, Agent) - Method in class org.agrona.concurrent.AgentRunner
 
wrap(byte[]) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[]) - Method in interface org.agrona.DirectBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[]) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[]) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[], int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
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(byte[], int, int) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to a byte[] for providing direct access.
wrap(byte[], int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to a byte[] for providing direct access.
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, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to an off-heap memory region by address.
wrap(long, int) - Method in interface org.agrona.DirectBuffer
Attach a view to an off-heap memory region by address.
wrap(long, int) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to an off-heap memory region by address.
wrap(long, int) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to an off-heap memory region by address.
wrap(ByteBuffer) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
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) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
wrap(ByteBuffer) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to a ByteBuffer for providing direct access, the ByteBuffer can be heap based or direct.
wrap(ByteBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to a ByteBuffer for providing direct access.
wrap(ByteBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Attach a view to a ByteBuffer for providing direct access.
wrap(ByteBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to a ByteBuffer for providing direct access.
wrap(ByteBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to a ByteBuffer for providing direct access.
wrap(Map<String, CharSequence>) - Static method in class org.agrona.generation.CompilerUtil
 
wrap(DirectBuffer) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to an existing DirectBuffer
wrap(DirectBuffer) - Method in interface org.agrona.DirectBuffer
Attach a view to an existing DirectBuffer
wrap(DirectBuffer) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to an existing DirectBuffer
wrap(DirectBuffer) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to an existing DirectBuffer
wrap(DirectBuffer) - Method in class org.agrona.io.DirectBufferDataInput
Wrap given DirectBuffer.
wrap(DirectBuffer) - Method in class org.agrona.io.DirectBufferInputStream
Wrap given DirectBuffer.
wrap(DirectBuffer, int) - Method in interface org.agrona.sbe.CompositeDecoderFlyweight
Wrap a buffer for decoding at a given offset.
wrap(DirectBuffer, int, int) - Method in class org.agrona.AsciiSequenceView
Wrap a range of an existing buffer containing an ASCII sequence.
wrap(DirectBuffer, int, int) - Method in class org.agrona.concurrent.UnsafeBuffer
Attach a view to a DirectBuffer for providing direct access.
wrap(DirectBuffer, int, int) - Method in interface org.agrona.DirectBuffer
Attach a view to a DirectBuffer for providing direct access.
wrap(DirectBuffer, int, int) - Method in class org.agrona.ExpandableArrayBuffer
Attach a view to a DirectBuffer for providing direct access.
wrap(DirectBuffer, int, int) - Method in class org.agrona.ExpandableDirectByteBuffer
Attach a view to a DirectBuffer for providing direct access.
wrap(DirectBuffer, int, int) - Method in class org.agrona.io.DirectBufferDataInput
Wrap given DirectBuffer.
wrap(DirectBuffer, int, int) - Method in class org.agrona.io.DirectBufferInputStream
Wrap given DirectBuffer.
wrap(DirectBuffer, int, int, int) - Method in interface org.agrona.sbe.MessageDecoderFlyweight
Wrap a buffer containing an encoded message for decoding.
wrap(MutableDirectBuffer) - Method in class org.agrona.io.DirectBufferOutputStream
Wrap the buffer.
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(MutableDirectBuffer, int) - Method in interface org.agrona.sbe.EncoderFlyweight
Wrap a buffer for encoding at a given offset.
wrap(MutableDirectBuffer, int, int) - Method in class org.agrona.io.DirectBufferOutputStream
Wrap the buffer at an offset.
wrapAdjustment - Variable in class org.agrona.concurrent.UnsafeBuffer
 
wrapAdjustment() - Method in class org.agrona.concurrent.UnsafeBuffer
Get the adjustment in indices between an index in this buffer and the wrapped object.
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
Get the adjustment in indices between an index in this buffer and the wrapped object.
wrapAdjustment() - Method in class org.agrona.ExpandableDirectByteBuffer
Get the adjustment in indices between an index in this buffer and the wrapped object.
write(byte[]) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte[] to the buffer.
write(byte[], int, int) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte[] to the buffer.
write(byte[], int, int) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Write a byte[] to the buffer.
write(int) - Method in class org.agrona.io.DirectBufferOutputStream
Write a byte to buffer.
write(int) - Method in class org.agrona.io.ExpandableDirectBufferOutputStream
Write a byte to buffer.
write(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.ringbuffer.ManyToOneRingBuffer
Non-blocking write of a message to an underlying ring-buffer.
write(int, DirectBuffer, int, int) - Method in class org.agrona.concurrent.ringbuffer.OneToOneRingBuffer
Non-blocking write of a message to an underlying ring-buffer.
write(int, DirectBuffer, int, int) - Method in interface org.agrona.concurrent.ringbuffer.RingBuffer
Non-blocking write of a message to an underlying ring-buffer.
writeMessage(DirectBuffer, int, int) - Method in class org.agrona.ExpandableRingBuffer
 

Y

YIELD - Static variable in class org.agrona.concurrent.ControllableIdleStrategy
YIELDING - Static variable in class org.agrona.concurrent.BackoffIdleStrategyData
Denotes a yielding state.
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
 
yields - Variable in class org.agrona.concurrent.BackoffIdleStrategyData
Number of yields.

Z

ZERO - Static variable in class org.agrona.AsciiEncoding
Byte value of zero character ('0').
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 
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form