Index
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
A
- AbstractSequencer - Class in com.lmax.disruptor
-
Base class for the various sequencer types (single/multi).
- AbstractSequencer(int, WaitStrategy) - Constructor for class com.lmax.disruptor.AbstractSequencer
-
Create with the specified buffer size and wait strategy.
- add(EventProcessor) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- add(EventProcessor, EventHandler<? super T>, SequenceBarrier) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- add(Sequence) - Method in class com.lmax.disruptor.SequenceGroup
-
Add a
Sequence
into this aggregate. - add(WorkerPool<T>, SequenceBarrier) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- addAndGet(long) - Method in class com.lmax.disruptor.FixedSequenceGroup
-
Not supported.
- addAndGet(long) - Method in class com.lmax.disruptor.Sequence
-
Atomically add the supplied value.
- addGatingSequences(Sequence...) - Method in class com.lmax.disruptor.AbstractSequencer
- addGatingSequences(Sequence...) - Method in class com.lmax.disruptor.RingBuffer
-
Add the specified gating sequences to this instance of the Disruptor.
- addGatingSequences(Sequence...) - Method in interface com.lmax.disruptor.Sequencer
-
Add the specified gating sequences to this instance of the Disruptor.
- addSequences(T, AtomicReferenceFieldUpdater<T, Sequence[]>, Cursored, Sequence...) - Static method in class com.lmax.disruptor.SequenceGroups
- addWhileRunning(Cursored, Sequence) - Method in class com.lmax.disruptor.SequenceGroup
-
Adds a sequence to the sequence group after threads have started to publish to the Disruptor.
- after(EventHandler<T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Create a group of event handlers to be used as a dependency.
- after(EventProcessor...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Create a group of event processors to be used as a dependency.
- AggregateEventHandler<T> - Class in com.lmax.disruptor
-
An aggregate collection of
EventHandler
s that get called in sequence for each event. - AggregateEventHandler(EventHandler<T>...) - Constructor for class com.lmax.disruptor.AggregateEventHandler
-
Construct an aggregate collection of
EventHandler
s to be called in sequence. - alert() - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- alert() - Method in interface com.lmax.disruptor.SequenceBarrier
-
Alert the
EventProcessor
s of a status change and stay in this status until cleared. - alerted - Variable in class com.lmax.disruptor.ProcessingSequenceBarrier
- AlertException - Exception Class in com.lmax.disruptor
-
Used to alert
EventProcessor
s waiting at aSequenceBarrier
of status changes. - AlertException() - Constructor for exception class com.lmax.disruptor.AlertException
-
Private constructor so only a single instance exists.
- and(EventHandlerGroup<T>) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Create a new event handler group that combines the consumers in this group with otherHandlerGroup.
- and(EventProcessor...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Create a new event handler group that combines the handlers in this group with processors.
- applyWaitMethod(SequenceBarrier, int) - Method in class com.lmax.disruptor.SleepingWaitStrategy
- applyWaitMethod(SequenceBarrier, int) - Method in class com.lmax.disruptor.YieldingWaitStrategy
- asSequenceBarrier() - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Create a dependency barrier for the processors in this group.
- availableBuffer - Variable in class com.lmax.disruptor.MultiProducerSequencer
B
- barrier - Variable in class com.lmax.disruptor.dsl.EventProcessorInfo
- BASE - Static variable in class com.lmax.disruptor.MultiProducerSequencer
- BasicExecutor - Class in com.lmax.disruptor.dsl
- BasicExecutor(ThreadFactory) - Constructor for class com.lmax.disruptor.dsl.BasicExecutor
- BatchEventProcessor<T> - Class in com.lmax.disruptor
-
Convenience class for handling the batching semantics of consuming entries from a
RingBuffer
and delegating the available events to anEventHandler
. - BatchEventProcessor(DataProvider<T>, SequenceBarrier, EventHandler<? super T>) - Constructor for class com.lmax.disruptor.BatchEventProcessor
-
Construct a
EventProcessor
that will automatically track the progress by updating its sequence when theEventHandler.onEvent(Object, long, boolean)
method returns. - batchOverRuns(A[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- batchStartAware - Variable in class com.lmax.disruptor.BatchEventProcessor
- BatchStartAware - Interface in com.lmax.disruptor
- BlockingWaitStrategy - Class in com.lmax.disruptor
-
Blocking strategy that uses a lock and condition variable for
EventProcessor
s waiting on a barrier. - BlockingWaitStrategy() - Constructor for class com.lmax.disruptor.BlockingWaitStrategy
- BUFFER_PAD - Static variable in class com.lmax.disruptor.RingBufferFields
- bufferSize - Variable in class com.lmax.disruptor.AbstractSequencer
- bufferSize - Variable in class com.lmax.disruptor.RingBufferFields
- BusySpinWaitStrategy - Class in com.lmax.disruptor
-
Busy Spin strategy that uses a busy spin loop for
EventProcessor
s waiting on a barrier. - BusySpinWaitStrategy() - Constructor for class com.lmax.disruptor.BusySpinWaitStrategy
C
- cachedValue - Variable in class com.lmax.disruptor.SingleProducerSequencerFields
- calculateAvailabilityFlag(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- calculateIndex(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- ceilingNextPowerOfTwo(int) - Static method in class com.lmax.disruptor.util.Util
-
Calculate the next power of 2, greater than or equal to x.
- checkAlert() - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- checkAlert() - Method in interface com.lmax.disruptor.SequenceBarrier
-
Check if an alert has been raised and throw an
AlertException
if it has. - checkBatchSizing(int, int) - Method in class com.lmax.disruptor.RingBuffer
- checkBounds(int, int, Object[][]) - Method in class com.lmax.disruptor.RingBuffer
- checkBounds(A[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- checkBounds(A[], B[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- checkBounds(A[], B[], C[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- checkBounds(EventTranslator<E>[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- checkNotStarted() - Method in class com.lmax.disruptor.dsl.Disruptor
- checkOnlyStartedOnce() - Method in class com.lmax.disruptor.dsl.Disruptor
- claim(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- claim(long) - Method in interface com.lmax.disruptor.Sequencer
-
Claim a specific sequence.
- claim(long) - Method in class com.lmax.disruptor.SingleProducerSequencer
- claimAndGetPreallocated(long) - Method in class com.lmax.disruptor.RingBuffer
-
Sets the cursor to a specific sequence and returns the preallocated entry that is stored there.
- clearAlert() - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- clearAlert() - Method in interface com.lmax.disruptor.SequenceBarrier
-
Clear the current alert status.
- Code Example - Search tag in package com.lmax.disruptor
- Section
- com.lmax.disruptor - package com.lmax.disruptor
-
The Disruptor is a concurrent programming framework for exchanging and coordinating work as a continuous series of events.
- com.lmax.disruptor.dsl - package com.lmax.disruptor.dsl
- com.lmax.disruptor.util - package com.lmax.disruptor.util
- compareAndSet(long, long) - Method in class com.lmax.disruptor.FixedSequenceGroup
-
Not supported.
- compareAndSet(long, long) - Method in class com.lmax.disruptor.Sequence
-
Perform a compare and set operation on the sequence.
- ConsumerInfo - Interface in com.lmax.disruptor.dsl
- consumerInfos - Variable in class com.lmax.disruptor.dsl.ConsumerRepository
- consumerRepository - Variable in class com.lmax.disruptor.dsl.Disruptor
- consumerRepository - Variable in class com.lmax.disruptor.dsl.EventHandlerGroup
- consumerRepository - Variable in class com.lmax.disruptor.dsl.ExceptionHandlerSetting
- ConsumerRepository<T> - Class in com.lmax.disruptor.dsl
-
Provides a repository mechanism to associate
EventHandler
s withEventProcessor
s - ConsumerRepository() - Constructor for class com.lmax.disruptor.dsl.ConsumerRepository
- countMatching(T[], T) - Static method in class com.lmax.disruptor.SequenceGroups
- create(ProducerType, EventFactory<E>, int, WaitStrategy) - Static method in class com.lmax.disruptor.RingBuffer
-
Create a new Ring Buffer with the specified producer type (SINGLE or MULTI)
- createEventProcessor(RingBuffer<T>, Sequence[]) - Method in interface com.lmax.disruptor.dsl.EventProcessorFactory
-
Create a new event processor that gates on
barrierSequences
. - createEventProcessors(Sequence[], EventProcessorFactory<T>[]) - Method in class com.lmax.disruptor.dsl.Disruptor
- createEventProcessors(Sequence[], EventHandler<? super T>[]) - Method in class com.lmax.disruptor.dsl.Disruptor
- createMultiProducer(EventFactory<E>, int) - Static method in class com.lmax.disruptor.RingBuffer
-
Create a new multiple producer RingBuffer using the default wait strategy
BlockingWaitStrategy
. - createMultiProducer(EventFactory<E>, int, WaitStrategy) - Static method in class com.lmax.disruptor.RingBuffer
-
Create a new multiple producer RingBuffer with the specified wait strategy.
- createSingleProducer(EventFactory<E>, int) - Static method in class com.lmax.disruptor.RingBuffer
-
Create a new single producer RingBuffer using the default wait strategy
BlockingWaitStrategy
. - createSingleProducer(EventFactory<E>, int, WaitStrategy) - Static method in class com.lmax.disruptor.RingBuffer
-
Create a new single producer RingBuffer with the specified wait strategy.
- createWorkerPool(Sequence[], WorkHandler<? super T>[]) - Method in class com.lmax.disruptor.dsl.Disruptor
- cursor - Variable in class com.lmax.disruptor.AbstractSequencer
- Cursored - Interface in com.lmax.disruptor
-
Implementors of this interface must provide a single long value that represents their current cursor value.
- cursorSequence - Variable in class com.lmax.disruptor.ProcessingSequenceBarrier
D
- DaemonThreadFactory - Enum in com.lmax.disruptor.util
-
Access to a ThreadFactory instance.
- DaemonThreadFactory() - Constructor for enum com.lmax.disruptor.util.DaemonThreadFactory
- dataProvider - Variable in class com.lmax.disruptor.BatchEventProcessor
- dataProvider - Variable in class com.lmax.disruptor.EventPoller
- DataProvider<T> - Interface in com.lmax.disruptor
- DEFAULT_RETRIES - Static variable in class com.lmax.disruptor.SleepingWaitStrategy
- DEFAULT_SLEEP - Static variable in class com.lmax.disruptor.SleepingWaitStrategy
- DefaultExceptionHandlerHolder() - Constructor for class com.lmax.disruptor.ExceptionHandlers.DefaultExceptionHandlerHolder
- defaultHandler() - Static method in class com.lmax.disruptor.ExceptionHandlers
-
Get a reference to the default
ExceptionHandler
instance. - delegate - Variable in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- dependentSequence - Variable in class com.lmax.disruptor.ProcessingSequenceBarrier
- disruptor - Variable in class com.lmax.disruptor.dsl.EventHandlerGroup
- Disruptor<T> - Class in com.lmax.disruptor.dsl
-
A DSL-style API for setting up the disruptor pattern around a ring buffer (aka the Builder pattern).
- Disruptor(EventFactory<T>, int, Executor) - Constructor for class com.lmax.disruptor.dsl.Disruptor
-
Deprecated.
- Disruptor(EventFactory<T>, int, Executor, ProducerType, WaitStrategy) - Constructor for class com.lmax.disruptor.dsl.Disruptor
-
Deprecated.Use a
ThreadFactory
instead of anExecutor
as a the ThreadFactory is able to report errors when it is unable to construct a thread to run a producer. - Disruptor(EventFactory<T>, int, ThreadFactory) - Constructor for class com.lmax.disruptor.dsl.Disruptor
-
Create a new Disruptor.
- Disruptor(EventFactory<T>, int, ThreadFactory, ProducerType, WaitStrategy) - Constructor for class com.lmax.disruptor.dsl.Disruptor
-
Create a new Disruptor.
- Disruptor(RingBuffer<T>, Executor) - Constructor for class com.lmax.disruptor.dsl.Disruptor
-
Private constructor helper
- drainAndHalt() - Method in class com.lmax.disruptor.WorkerPool
-
Wait for the
RingBuffer
to drain of published events then halt the workers. - dumpThreadInfo() - Method in class com.lmax.disruptor.dsl.BasicExecutor
E
- earlyExit() - Method in class com.lmax.disruptor.BatchEventProcessor
- elementAt(long) - Method in class com.lmax.disruptor.RingBufferFields
- endOfChain - Variable in class com.lmax.disruptor.dsl.EventProcessorInfo
- endOfChain - Variable in class com.lmax.disruptor.dsl.WorkerPoolInfo
- entries - Variable in class com.lmax.disruptor.RingBufferFields
- EventFactory<T> - Interface in com.lmax.disruptor
-
Called by the
RingBuffer
to pre-populate all the events to fill the RingBuffer. - eventHandler - Variable in class com.lmax.disruptor.BatchEventProcessor
- eventHandler - Variable in class com.lmax.disruptor.dsl.ExceptionHandlerSetting
- EventHandler<T> - Interface in com.lmax.disruptor
-
Callback interface to be implemented for processing events as they become available in the
RingBuffer
- EventHandlerGroup<T> - Class in com.lmax.disruptor.dsl
-
A group of
EventProcessor
s used as part of theDisruptor
. - EventHandlerGroup(Disruptor<T>, ConsumerRepository<T>, Sequence[]) - Constructor for class com.lmax.disruptor.dsl.EventHandlerGroup
- eventHandlers - Variable in class com.lmax.disruptor.AggregateEventHandler
- EventPoller<T> - Class in com.lmax.disruptor
-
Experimental poll-based interface for the Disruptor.
- EventPoller(DataProvider<T>, Sequencer, Sequence, Sequence) - Constructor for class com.lmax.disruptor.EventPoller
- EventPoller.Handler<T> - Interface in com.lmax.disruptor
- EventPoller.PollState - Enum in com.lmax.disruptor
- eventprocessor - Variable in class com.lmax.disruptor.dsl.EventProcessorInfo
- EventProcessor - Interface in com.lmax.disruptor
-
An EventProcessor needs to be an implementation of a runnable that will poll for events from the
RingBuffer
using the appropriate wait strategy. - EventProcessorFactory<T> - Interface in com.lmax.disruptor.dsl
-
A factory interface to make it possible to include custom event processors in a chain:
- EventProcessorInfo<T> - Class in com.lmax.disruptor.dsl
-
Wrapper class to tie together a particular event processing stage
- EventProcessorInfo(EventProcessor, EventHandler<? super T>, SequenceBarrier) - Constructor for class com.lmax.disruptor.dsl.EventProcessorInfo
- eventProcessorInfoByEventHandler - Variable in class com.lmax.disruptor.dsl.ConsumerRepository
- eventProcessorInfoBySequence - Variable in class com.lmax.disruptor.dsl.ConsumerRepository
- EventReleaseAware - Interface in com.lmax.disruptor
- eventReleaser - Variable in class com.lmax.disruptor.WorkProcessor
- EventReleaser - Interface in com.lmax.disruptor
- EventSequencer<T> - Interface in com.lmax.disruptor
- EventSink<E> - Interface in com.lmax.disruptor
- EventTranslator<T> - Interface in com.lmax.disruptor
-
Implementations translate (write) data representations into events claimed from the
RingBuffer
. - EventTranslatorOneArg<T,
A> - Interface in com.lmax.disruptor -
Implementations translate another data representations into events claimed from the
RingBuffer
- EventTranslatorThreeArg<T,
A, - Interface in com.lmax.disruptorB, C> -
Implementations translate another data representations into events claimed from the
RingBuffer
- EventTranslatorTwoArg<T,
A, - Interface in com.lmax.disruptorB> -
Implementations translate another data representations into events claimed from the
RingBuffer
- EventTranslatorVararg<T> - Interface in com.lmax.disruptor
-
Implementations translate another data representations into events claimed from the
RingBuffer
- exceptionHandler - Variable in class com.lmax.disruptor.BatchEventProcessor
- exceptionHandler - Variable in class com.lmax.disruptor.dsl.Disruptor
- exceptionHandler - Variable in class com.lmax.disruptor.WorkProcessor
- ExceptionHandler<T> - Interface in com.lmax.disruptor
-
Callback handler for uncaught exceptions in the event processing cycle of the
BatchEventProcessor
- ExceptionHandlers - Class in com.lmax.disruptor
-
Provides static methods for accessing a default
ExceptionHandler
object. - ExceptionHandlers() - Constructor for class com.lmax.disruptor.ExceptionHandlers
- ExceptionHandlers.DefaultExceptionHandlerHolder - Class in com.lmax.disruptor
- ExceptionHandlerSetting<T> - Class in com.lmax.disruptor.dsl
-
A support class used as part of setting an exception handler for a specific event handler.
- ExceptionHandlerSetting(EventHandler<T>, ConsumerRepository<T>) - Constructor for class com.lmax.disruptor.dsl.ExceptionHandlerSetting
- ExceptionHandlerWrapper<T> - Class in com.lmax.disruptor.dsl
- ExceptionHandlerWrapper() - Constructor for class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- execute(Runnable) - Method in class com.lmax.disruptor.dsl.BasicExecutor
- executor - Variable in class com.lmax.disruptor.dsl.Disruptor
F
- factory - Variable in class com.lmax.disruptor.dsl.BasicExecutor
- fallbackStrategy - Variable in class com.lmax.disruptor.PhasedBackoffWaitStrategy
- FatalExceptionHandler - Class in com.lmax.disruptor
-
Convenience implementation of an exception handler that using standard JDK logging to log the exception as
Level
.SEVERE and re-throw it wrapped in aRuntimeException
- FatalExceptionHandler() - Constructor for class com.lmax.disruptor.FatalExceptionHandler
- FatalExceptionHandler(Logger) - Constructor for class com.lmax.disruptor.FatalExceptionHandler
- fill(EventFactory<E>) - Method in class com.lmax.disruptor.RingBufferFields
- fillInStackTrace() - Method in exception class com.lmax.disruptor.AlertException
-
Overridden so the stack trace is not filled in for this exception for performance reasons.
- fillInStackTrace() - Method in exception class com.lmax.disruptor.InsufficientCapacityException
- fillInStackTrace() - Method in exception class com.lmax.disruptor.TimeoutException
- FixedSequenceGroup - Class in com.lmax.disruptor
-
Hides a group of Sequences behind a single Sequence
- FixedSequenceGroup(Sequence[]) - Constructor for class com.lmax.disruptor.FixedSequenceGroup
-
Constructor
G
- GATING - Enum constant in enum com.lmax.disruptor.EventPoller.PollState
- gatingSequence - Variable in class com.lmax.disruptor.EventPoller
- gatingSequenceCache - Variable in class com.lmax.disruptor.MultiProducerSequencer
- gatingSequences - Variable in class com.lmax.disruptor.AbstractSequencer
- get() - Method in class com.lmax.disruptor.FixedSequenceGroup
-
Get the minimum sequence value for the group.
- get() - Method in class com.lmax.disruptor.NoOpEventProcessor.SequencerFollowingSequence
- get() - Method in class com.lmax.disruptor.Sequence
-
Perform a volatile read of this sequence's value.
- get() - Method in class com.lmax.disruptor.SequenceGroup
-
Get the minimum sequence value for the group.
- get(long) - Method in interface com.lmax.disruptor.DataProvider
- get(long) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Get the event for a given sequence in the RingBuffer.
- get(long) - Method in class com.lmax.disruptor.RingBuffer
-
Get the event for a given sequence in the RingBuffer.
- getBarrier() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- getBarrier() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- getBarrier() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- getBarrierFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getBarrierFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Get the
SequenceBarrier
used by a specific handler. - getBufferSize() - Method in class com.lmax.disruptor.AbstractSequencer
- getBufferSize() - Method in class com.lmax.disruptor.dsl.Disruptor
-
The capacity of the data structure to hold entries.
- getBufferSize() - Method in class com.lmax.disruptor.RingBuffer
-
The size of the buffer.
- getBufferSize() - Method in interface com.lmax.disruptor.Sequenced
-
The capacity of the data structure to hold entries.
- getCursor() - Method in class com.lmax.disruptor.AbstractSequencer
- getCursor() - Method in interface com.lmax.disruptor.Cursored
-
Get the current cursor value.
- getCursor() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Get the value of the cursor indicating the published sequence.
- getCursor() - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- getCursor() - Method in class com.lmax.disruptor.RingBuffer
-
Get the current cursor value for the ring buffer.
- getCursor() - Method in interface com.lmax.disruptor.SequenceBarrier
-
Get the current cursor value that can be read.
- getEventProcessor() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- getEventProcessorFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getEventProcessorInfo(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getEventProcessorInfo(Sequence) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getExceptionHandler() - Method in class com.lmax.disruptor.BatchEventProcessor
- getExceptionHandler() - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- getHandler() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- getHighestPublishedSequence(long, long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- getHighestPublishedSequence(long, long) - Method in interface com.lmax.disruptor.Sequencer
-
Get the highest sequence number that can be safely read from the ring buffer.
- getHighestPublishedSequence(long, long) - Method in class com.lmax.disruptor.SingleProducerSequencer
- getLastSequenceInChain(boolean) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getMinimumGatingSequence() - Method in class com.lmax.disruptor.RingBuffer
-
Get the minimum sequence value from all of the gating sequences added to this ringBuffer.
- getMinimumSequence() - Method in class com.lmax.disruptor.AbstractSequencer
- getMinimumSequence() - Method in interface com.lmax.disruptor.Sequencer
-
Get the minimum sequence value from all of the gating sequences added to this ringBuffer.
- getMinimumSequence(Sequence[]) - Static method in class com.lmax.disruptor.util.Util
-
Get the minimum sequence from an array of
Sequence
s. - getMinimumSequence(Sequence[], long) - Static method in class com.lmax.disruptor.util.Util
-
Get the minimum sequence from an array of
Sequence
s. - getRingBuffer() - Method in class com.lmax.disruptor.dsl.Disruptor
-
The
RingBuffer
used by this Disruptor. - getSequence() - Method in class com.lmax.disruptor.BatchEventProcessor
- getSequence() - Method in class com.lmax.disruptor.EventPoller
- getSequence() - Method in interface com.lmax.disruptor.EventProcessor
-
Get a reference to the
Sequence
being used by thisEventProcessor
. - getSequence() - Method in class com.lmax.disruptor.NoOpEventProcessor
- getSequence() - Method in class com.lmax.disruptor.WorkProcessor
- getSequenceFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- getSequences() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- getSequences() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- getSequences() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- getSequencesFor(EventProcessor...) - Static method in class com.lmax.disruptor.util.Util
-
Get an array of
Sequence
s for the passedEventProcessor
s - getSequenceValueFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Gets the sequence value for the specified event handlers.
- getUnsafe() - Static method in class com.lmax.disruptor.util.Util
-
Get a handle on the Unsafe instance, used for accessing low-level concurrency and memory constructs.
- getWorkerSequences() - Method in class com.lmax.disruptor.WorkerPool
-
Get an array of
Sequence
s representing the progress of the workers.
H
- halt() - Method in class com.lmax.disruptor.BatchEventProcessor
- halt() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- halt() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Calls
EventProcessor.halt()
on all of the event processors created via this disruptor. - halt() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- halt() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- halt() - Method in interface com.lmax.disruptor.EventProcessor
-
Signal that this EventProcessor should stop when it has finished consuming at the next clean break.
- halt() - Method in class com.lmax.disruptor.NoOpEventProcessor
- halt() - Method in class com.lmax.disruptor.WorkerPool
-
Halt all workers immediately at the end of their current cycle.
- halt() - Method in class com.lmax.disruptor.WorkProcessor
- HALTED - Static variable in class com.lmax.disruptor.BatchEventProcessor
- handleEventException(Throwable, long, Object) - Method in class com.lmax.disruptor.FatalExceptionHandler
- handleEventException(Throwable, long, Object) - Method in class com.lmax.disruptor.IgnoreExceptionHandler
- handleEventException(Throwable, long, T) - Method in class com.lmax.disruptor.BatchEventProcessor
-
Delegate to
ExceptionHandler.handleEventException(Throwable, long, Object)
on the delegate or the defaultExceptionHandler
if one has not been configured. - handleEventException(Throwable, long, T) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- handleEventException(Throwable, long, T) - Method in interface com.lmax.disruptor.ExceptionHandler
-
Strategy for handling uncaught exceptions when processing an event.
- handleEventsWith(EventProcessorFactory<T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up custom event processors to handle events from the ring buffer.
- handleEventsWith(EventProcessorFactory<T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up custom event processors to handle events from the ring buffer.
- handleEventsWith(EventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up event handlers to handle events from the ring buffer.
- handleEventsWith(EventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up batch handlers to handle events from the ring buffer.
- handleEventsWith(EventProcessor...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up custom event processors to handle events from the ring buffer.
- handleEventsWithWorkerPool(WorkHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up a worker pool to handle events from the ring buffer.
- handleEventsWithWorkerPool(WorkHandler<T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up a
WorkerPool
to distribute an event to one of a pool of work handler threads. - handleExceptionsFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Override the default exception handler for a specific handler.
- handleExceptionsWith(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Deprecated.This method only applies to future event handlers. Use setDefaultExceptionHandler instead which applies to existing and new event handlers.
- handleOnShutdownException(Throwable) - Method in class com.lmax.disruptor.BatchEventProcessor
-
Delegate to
ExceptionHandler.handleOnShutdownException(Throwable)
on the delegate or the defaultExceptionHandler
if one has not been configured. - handleOnShutdownException(Throwable) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- handleOnShutdownException(Throwable) - Method in interface com.lmax.disruptor.ExceptionHandler
-
Callback to notify of an exception during
LifecycleAware.onShutdown()
- handleOnShutdownException(Throwable) - Method in class com.lmax.disruptor.FatalExceptionHandler
- handleOnShutdownException(Throwable) - Method in class com.lmax.disruptor.IgnoreExceptionHandler
- handleOnStartException(Throwable) - Method in class com.lmax.disruptor.BatchEventProcessor
-
Delegate to
ExceptionHandler.handleOnStartException(Throwable)
on the delegate or the defaultExceptionHandler
if one has not been configured. - handleOnStartException(Throwable) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
- handleOnStartException(Throwable) - Method in interface com.lmax.disruptor.ExceptionHandler
-
Callback to notify of an exception during
LifecycleAware.onStart()
- handleOnStartException(Throwable) - Method in class com.lmax.disruptor.FatalExceptionHandler
- handleOnStartException(Throwable) - Method in class com.lmax.disruptor.IgnoreExceptionHandler
- handler - Variable in class com.lmax.disruptor.dsl.EventProcessorInfo
- HANDLER - Static variable in class com.lmax.disruptor.ExceptionHandlers.DefaultExceptionHandlerHolder
- hasAvailableCapacity(int) - Method in class com.lmax.disruptor.MultiProducerSequencer
- hasAvailableCapacity(int) - Method in class com.lmax.disruptor.RingBuffer
-
Given specified requiredCapacity determines if that amount of space is available.
- hasAvailableCapacity(int) - Method in interface com.lmax.disruptor.Sequenced
-
Has the buffer got capacity to allocate another sequence.
- hasAvailableCapacity(int) - Method in class com.lmax.disruptor.SingleProducerSequencer
- hasAvailableCapacity(int, boolean) - Method in class com.lmax.disruptor.SingleProducerSequencer
- hasAvailableCapacity(Sequence[], int, long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- hasBacklog() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Confirms if all messages have been consumed by all event processors
I
- IDLE - Enum constant in enum com.lmax.disruptor.EventPoller.PollState
- IDLE - Static variable in class com.lmax.disruptor.BatchEventProcessor
- IgnoreExceptionHandler - Class in com.lmax.disruptor
-
Convenience implementation of an exception handler that using standard JDK logging to log the exception as
Level
.INFO - IgnoreExceptionHandler() - Constructor for class com.lmax.disruptor.IgnoreExceptionHandler
- IgnoreExceptionHandler(Logger) - Constructor for class com.lmax.disruptor.IgnoreExceptionHandler
- incrementAndGet() - Method in class com.lmax.disruptor.FixedSequenceGroup
-
Not supported.
- incrementAndGet() - Method in class com.lmax.disruptor.Sequence
-
Atomically increment the sequence by one.
- indexMask - Variable in class com.lmax.disruptor.MultiProducerSequencer
- indexMask - Variable in class com.lmax.disruptor.RingBufferFields
- indexShift - Variable in class com.lmax.disruptor.MultiProducerSequencer
- INITIAL_CURSOR_VALUE - Static variable in class com.lmax.disruptor.RingBuffer
- INITIAL_CURSOR_VALUE - Static variable in interface com.lmax.disruptor.Sequencer
-
Set to -1 as sequence starting point
- INITIAL_VALUE - Static variable in class com.lmax.disruptor.Sequence
- initialiseAvailableBuffer() - Method in class com.lmax.disruptor.MultiProducerSequencer
- INSTANCE - Enum constant in enum com.lmax.disruptor.util.DaemonThreadFactory
- INSTANCE - Static variable in exception class com.lmax.disruptor.AlertException
-
Pre-allocated exception to avoid garbage generation
- INSTANCE - Static variable in exception class com.lmax.disruptor.InsufficientCapacityException
- INSTANCE - Static variable in exception class com.lmax.disruptor.TimeoutException
- InsufficientCapacityException - Exception Class in com.lmax.disruptor
-
Exception thrown when it is not possible to insert a value into the ring buffer without it wrapping the consuming sequences.
- InsufficientCapacityException() - Constructor for exception class com.lmax.disruptor.InsufficientCapacityException
- isAlerted() - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- isAlerted() - Method in interface com.lmax.disruptor.SequenceBarrier
-
The current alert status for the barrier.
- isAvailable(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- isAvailable(long) - Method in interface com.lmax.disruptor.Sequencer
-
Confirms if a sequence is published and the event is available for use; non-blocking.
- isAvailable(long) - Method in class com.lmax.disruptor.SingleProducerSequencer
- isEndOfChain() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- isEndOfChain() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- isEndOfChain() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- isPublished(long) - Method in class com.lmax.disruptor.RingBuffer
-
Deprecated.Please don't use this method. It probably won't do what you think that it does.
- isRunning() - Method in class com.lmax.disruptor.BatchEventProcessor
- isRunning() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- isRunning() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- isRunning() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- isRunning() - Method in interface com.lmax.disruptor.EventProcessor
- isRunning() - Method in class com.lmax.disruptor.NoOpEventProcessor
- isRunning() - Method in class com.lmax.disruptor.WorkerPool
- isRunning() - Method in class com.lmax.disruptor.WorkProcessor
- iterator() - Method in class com.lmax.disruptor.dsl.ConsumerRepository
L
- LhsPadding - Class in com.lmax.disruptor
- LhsPadding() - Constructor for class com.lmax.disruptor.LhsPadding
- LifecycleAware - Interface in com.lmax.disruptor
-
Implement this interface in your
EventHandler
to be notified when a thread for theBatchEventProcessor
starts and shuts down. - LiteBlockingWaitStrategy - Class in com.lmax.disruptor
-
Variation of the
BlockingWaitStrategy
that attempts to elide conditional wake-ups when the lock is uncontended. - LiteBlockingWaitStrategy() - Constructor for class com.lmax.disruptor.LiteBlockingWaitStrategy
- LiteTimeoutBlockingWaitStrategy - Class in com.lmax.disruptor
-
Variation of the
TimeoutBlockingWaitStrategy
that attempts to elide conditional wake-ups when the lock is uncontended. - LiteTimeoutBlockingWaitStrategy(long, TimeUnit) - Constructor for class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- lock - Variable in class com.lmax.disruptor.BlockingWaitStrategy
- lock - Variable in class com.lmax.disruptor.LiteBlockingWaitStrategy
- lock - Variable in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- lock - Variable in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- log2(int) - Static method in class com.lmax.disruptor.util.Util
-
Calculate the log base 2 of the supplied integer, essentially reports the location of the highest bit.
- logger - Variable in class com.lmax.disruptor.FatalExceptionHandler
- logger - Variable in class com.lmax.disruptor.IgnoreExceptionHandler
- LOGGER - Static variable in class com.lmax.disruptor.FatalExceptionHandler
- LOGGER - Static variable in class com.lmax.disruptor.IgnoreExceptionHandler
M
- markAsUsedInBarrier() - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- markAsUsedInBarrier() - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- markAsUsedInBarrier() - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- MULTI - Enum constant in enum com.lmax.disruptor.dsl.ProducerType
-
Create a RingBuffer supporting multiple event publishers to the one RingBuffer
- MultiProducerSequencer - Class in com.lmax.disruptor
-
Coordinator for claiming sequences for access to a data structure while tracking dependent
Sequence
s. - MultiProducerSequencer(int, WaitStrategy) - Constructor for class com.lmax.disruptor.MultiProducerSequencer
-
Construct a Sequencer with the selected wait strategy and buffer size.
N
- newBarrier(Sequence...) - Method in class com.lmax.disruptor.AbstractSequencer
- newBarrier(Sequence...) - Method in class com.lmax.disruptor.RingBuffer
-
Create a new SequenceBarrier to be used by an EventProcessor to track which messages are available to be read from the ring buffer given a list of sequences to track.
- newBarrier(Sequence...) - Method in interface com.lmax.disruptor.Sequencer
-
Create a new SequenceBarrier to be used by an EventProcessor to track which messages are available to be read from the ring buffer given a list of sequences to track.
- newInstance() - Method in interface com.lmax.disruptor.EventFactory
- newInstance(DataProvider<T>, Sequencer, Sequence, Sequence, Sequence...) - Static method in class com.lmax.disruptor.EventPoller
- newPoller(DataProvider<T>, Sequence...) - Method in class com.lmax.disruptor.AbstractSequencer
-
Creates an event poller for this sequence that will use the supplied data provider and gating sequences.
- newPoller(DataProvider<T>, Sequence...) - Method in interface com.lmax.disruptor.Sequencer
- newPoller(Sequence...) - Method in class com.lmax.disruptor.RingBuffer
-
Creates an event poller for this ring buffer gated on the supplied sequences.
- newThread(Runnable) - Method in enum com.lmax.disruptor.util.DaemonThreadFactory
- next() - Method in class com.lmax.disruptor.MultiProducerSequencer
- next() - Method in class com.lmax.disruptor.RingBuffer
-
Increment and return the next sequence for the ring buffer.
- next() - Method in interface com.lmax.disruptor.Sequenced
-
Claim the next event in sequence for publishing.
- next() - Method in class com.lmax.disruptor.SingleProducerSequencer
- next(int) - Method in class com.lmax.disruptor.MultiProducerSequencer
- next(int) - Method in class com.lmax.disruptor.RingBuffer
-
The same functionality as
RingBuffer.next()
, but allows the caller to claim the next n sequences. - next(int) - Method in interface com.lmax.disruptor.Sequenced
-
Claim the next n events in sequence for publishing.
- next(int) - Method in class com.lmax.disruptor.SingleProducerSequencer
- nextValue - Variable in class com.lmax.disruptor.SingleProducerSequencerFields
-
Set to -1 as sequence starting point
- NoOpEventProcessor - Class in com.lmax.disruptor
-
No operation version of a
EventProcessor
that simply tracks aSequence
. - NoOpEventProcessor(RingBuffer<?>) - Constructor for class com.lmax.disruptor.NoOpEventProcessor
-
Construct a
EventProcessor
that simply tracks aSequence
object. - NoOpEventProcessor.SequencerFollowingSequence - Class in com.lmax.disruptor
-
Sequence that follows (by wrapping) another sequence
- notifyShutdown() - Method in class com.lmax.disruptor.BatchEventProcessor
-
Notifies the EventHandler immediately prior to this processor shutting down
- notifyShutdown() - Method in class com.lmax.disruptor.WorkProcessor
- notifyStart() - Method in class com.lmax.disruptor.BatchEventProcessor
-
Notifies the EventHandler when this processor is starting up
- notifyStart() - Method in class com.lmax.disruptor.WorkProcessor
- notifyTimeout(long) - Method in class com.lmax.disruptor.BatchEventProcessor
- notifyTimeout(long) - Method in class com.lmax.disruptor.WorkProcessor
O
- ON_SPIN_WAIT_METHOD_HANDLE - Static variable in class com.lmax.disruptor.util.ThreadHints
- onBatchStart(long) - Method in interface com.lmax.disruptor.BatchStartAware
- onEvent(T) - Method in interface com.lmax.disruptor.WorkHandler
-
Callback to indicate a unit of work needs to be processed.
- onEvent(T, long, boolean) - Method in class com.lmax.disruptor.AggregateEventHandler
- onEvent(T, long, boolean) - Method in interface com.lmax.disruptor.EventHandler
-
Called when a publisher has published an event to the
RingBuffer
. - onEvent(T, long, boolean) - Method in interface com.lmax.disruptor.EventPoller.Handler
- onShutdown() - Method in class com.lmax.disruptor.AggregateEventHandler
- onShutdown() - Method in interface com.lmax.disruptor.LifecycleAware
-
Called once just before the thread is shutdown.
- onSpinWait() - Static method in class com.lmax.disruptor.util.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 class com.lmax.disruptor.AggregateEventHandler
- onStart() - Method in interface com.lmax.disruptor.LifecycleAware
-
Called once on thread start before first event is available.
- onTimeout(long) - Method in interface com.lmax.disruptor.TimeoutHandler
P
- p1 - Variable in class com.lmax.disruptor.LhsPadding
- p1 - Variable in class com.lmax.disruptor.RingBuffer
- p1 - Variable in class com.lmax.disruptor.RingBufferPad
- p1 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p1 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p10 - Variable in class com.lmax.disruptor.RhsPadding
- p11 - Variable in class com.lmax.disruptor.RhsPadding
- p12 - Variable in class com.lmax.disruptor.RhsPadding
- p13 - Variable in class com.lmax.disruptor.RhsPadding
- p14 - Variable in class com.lmax.disruptor.RhsPadding
- p15 - Variable in class com.lmax.disruptor.RhsPadding
- p2 - Variable in class com.lmax.disruptor.LhsPadding
- p2 - Variable in class com.lmax.disruptor.RingBuffer
- p2 - Variable in class com.lmax.disruptor.RingBufferPad
- p2 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p2 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p3 - Variable in class com.lmax.disruptor.LhsPadding
- p3 - Variable in class com.lmax.disruptor.RingBuffer
- p3 - Variable in class com.lmax.disruptor.RingBufferPad
- p3 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p3 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p4 - Variable in class com.lmax.disruptor.LhsPadding
- p4 - Variable in class com.lmax.disruptor.RingBuffer
- p4 - Variable in class com.lmax.disruptor.RingBufferPad
- p4 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p4 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p5 - Variable in class com.lmax.disruptor.LhsPadding
- p5 - Variable in class com.lmax.disruptor.RingBuffer
- p5 - Variable in class com.lmax.disruptor.RingBufferPad
- p5 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p5 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p6 - Variable in class com.lmax.disruptor.LhsPadding
- p6 - Variable in class com.lmax.disruptor.RingBuffer
- p6 - Variable in class com.lmax.disruptor.RingBufferPad
- p6 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p6 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p7 - Variable in class com.lmax.disruptor.LhsPadding
- p7 - Variable in class com.lmax.disruptor.RingBuffer
- p7 - Variable in class com.lmax.disruptor.RingBufferPad
- p7 - Variable in class com.lmax.disruptor.SingleProducerSequencer
- p7 - Variable in class com.lmax.disruptor.SingleProducerSequencerPad
- p9 - Variable in class com.lmax.disruptor.RhsPadding
- PhasedBackoffWaitStrategy - Class in com.lmax.disruptor
-
Phased wait strategy for waiting
EventProcessor
s on a barrier. - PhasedBackoffWaitStrategy(long, long, TimeUnit, WaitStrategy) - Constructor for class com.lmax.disruptor.PhasedBackoffWaitStrategy
- poll(EventPoller.Handler<T>) - Method in class com.lmax.disruptor.EventPoller
- PollState() - Constructor for enum com.lmax.disruptor.EventPoller.PollState
- processEvents() - Method in class com.lmax.disruptor.BatchEventProcessor
- PROCESSING - Enum constant in enum com.lmax.disruptor.EventPoller.PollState
- ProcessingSequenceBarrier - Class in com.lmax.disruptor
-
SequenceBarrier
handed out for gatingEventProcessor
s on a cursor sequence and optional dependentEventProcessor
(s), using the given WaitStrategy. - ProcessingSequenceBarrier(Sequencer, WaitStrategy, Sequence, Sequence[]) - Constructor for class com.lmax.disruptor.ProcessingSequenceBarrier
- processorNotifyCondition - Variable in class com.lmax.disruptor.BlockingWaitStrategy
- processorNotifyCondition - Variable in class com.lmax.disruptor.LiteBlockingWaitStrategy
- processorNotifyCondition - Variable in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- processorNotifyCondition - Variable in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- ProducerType - Enum in com.lmax.disruptor.dsl
-
Defines producer types to support creation of RingBuffer with correct sequencer and publisher.
- ProducerType() - Constructor for enum com.lmax.disruptor.dsl.ProducerType
- publish(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- publish(long) - Method in class com.lmax.disruptor.RingBuffer
-
Publish the specified sequence.
- publish(long) - Method in interface com.lmax.disruptor.Sequenced
-
Publishes a sequence.
- publish(long) - Method in class com.lmax.disruptor.SingleProducerSequencer
- publish(long, long) - Method in class com.lmax.disruptor.MultiProducerSequencer
- publish(long, long) - Method in class com.lmax.disruptor.RingBuffer
-
Publish the specified sequences.
- publish(long, long) - Method in interface com.lmax.disruptor.Sequenced
-
Batch publish sequences.
- publish(long, long) - Method in class com.lmax.disruptor.SingleProducerSequencer
- publishEvent(EventTranslator<E>) - Method in interface com.lmax.disruptor.EventSink
-
Publishes an event to the ring buffer.
- publishEvent(EventTranslator<E>) - Method in class com.lmax.disruptor.RingBuffer
- publishEvent(EventTranslator<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslatorOneArg<E, A>, A) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- publishEvent(EventTranslatorOneArg<E, A>, A) - Method in class com.lmax.disruptor.RingBuffer
- publishEvent(EventTranslatorOneArg<T, A>, A) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments
- publishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in class com.lmax.disruptor.RingBuffer
- publishEvent(EventTranslatorThreeArg<T, A, B, C>, A, B, C) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments.
- publishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in class com.lmax.disruptor.RingBuffer
- publishEvent(EventTranslatorTwoArg<T, A, B>, A, B) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslatorVararg<E>, Object...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments
- publishEvent(EventTranslatorVararg<E>, Object...) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslator<E>[]) - Method in interface com.lmax.disruptor.EventSink
-
Publishes multiple events to the ring buffer.
- publishEvents(EventTranslator<E>[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslator<E>[], int, int) - Method in interface com.lmax.disruptor.EventSink
-
Publishes multiple events to the ring buffer.
- publishEvents(EventTranslator<E>[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument per event.
- publishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument per event.
- publishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorOneArg<T, A>, A[]) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish a batch of events to the ring buffer.
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- publishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- publishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- publishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
- publishEvents(EventTranslatorVararg<E>, Object[]...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- publishEvents(EventTranslatorVararg<E>, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
R
- REF_ARRAY_BASE - Static variable in class com.lmax.disruptor.RingBufferFields
- REF_ELEMENT_SHIFT - Static variable in class com.lmax.disruptor.RingBufferFields
- release() - Method in interface com.lmax.disruptor.EventReleaser
- remainingCapacity() - Method in class com.lmax.disruptor.MultiProducerSequencer
- remainingCapacity() - Method in class com.lmax.disruptor.RingBuffer
-
Get the remaining capacity for this ringBuffer.
- remainingCapacity() - Method in interface com.lmax.disruptor.Sequenced
-
Get the remaining capacity for this sequencer.
- remainingCapacity() - Method in class com.lmax.disruptor.SingleProducerSequencer
- remove(Sequence) - Method in class com.lmax.disruptor.SequenceGroup
-
Remove the first occurrence of the
Sequence
from this aggregate. - removeGatingSequence(Sequence) - Method in class com.lmax.disruptor.AbstractSequencer
- removeGatingSequence(Sequence) - Method in class com.lmax.disruptor.RingBuffer
-
Remove the specified sequence from this ringBuffer.
- removeGatingSequence(Sequence) - Method in interface com.lmax.disruptor.Sequencer
-
Remove the specified sequence from this sequencer.
- removeSequence(T, AtomicReferenceFieldUpdater<T, Sequence[]>, Sequence) - Static method in class com.lmax.disruptor.SequenceGroups
- resetTo(long) - Method in class com.lmax.disruptor.RingBuffer
-
Deprecated.
- retries - Variable in class com.lmax.disruptor.SleepingWaitStrategy
- RhsPadding - Class in com.lmax.disruptor
- RhsPadding() - Constructor for class com.lmax.disruptor.RhsPadding
- ringBuffer - Variable in class com.lmax.disruptor.dsl.Disruptor
- ringBuffer - Variable in class com.lmax.disruptor.WorkerPool
- ringBuffer - Variable in class com.lmax.disruptor.WorkProcessor
- RingBuffer<E> - Class in com.lmax.disruptor
-
Ring based store of reusable entries containing the data representing an event being exchanged between event producer and
EventProcessor
s. - RingBuffer(EventFactory<E>, Sequencer) - Constructor for class com.lmax.disruptor.RingBuffer
-
Construct a RingBuffer with the full option set.
- RingBufferFields<E> - Class in com.lmax.disruptor
- RingBufferFields(EventFactory<E>, Sequencer) - Constructor for class com.lmax.disruptor.RingBufferFields
- RingBufferPad - Class in com.lmax.disruptor
- RingBufferPad() - Constructor for class com.lmax.disruptor.RingBufferPad
- run() - Method in class com.lmax.disruptor.BatchEventProcessor
-
It is ok to have another thread rerun this method after a halt().
- run() - Method in class com.lmax.disruptor.NoOpEventProcessor
- run() - Method in class com.lmax.disruptor.WorkProcessor
-
It is ok to have another thread re-run this method after a halt().
- running - Variable in class com.lmax.disruptor.BatchEventProcessor
- running - Variable in class com.lmax.disruptor.NoOpEventProcessor
- running - Variable in class com.lmax.disruptor.WorkProcessor
- RUNNING - Static variable in class com.lmax.disruptor.BatchEventProcessor
S
- SCALE - Static variable in class com.lmax.disruptor.MultiProducerSequencer
- sequence - Variable in class com.lmax.disruptor.BatchEventProcessor
- sequence - Variable in class com.lmax.disruptor.EventPoller
- sequence - Variable in class com.lmax.disruptor.NoOpEventProcessor
- sequence - Variable in class com.lmax.disruptor.WorkProcessor
- Sequence - Class in com.lmax.disruptor
-
Concurrent sequence class used for tracking the progress of the ring buffer and event processors.
- Sequence() - Constructor for class com.lmax.disruptor.Sequence
-
Create a sequence initialised to -1.
- Sequence(long) - Constructor for class com.lmax.disruptor.Sequence
-
Create a sequence with a specified initial value.
- SEQUENCE_UPDATER - Static variable in class com.lmax.disruptor.AbstractSequencer
- SEQUENCE_UPDATER - Static variable in class com.lmax.disruptor.SequenceGroup
- sequenceBarrier - Variable in class com.lmax.disruptor.BatchEventProcessor
- sequenceBarrier - Variable in class com.lmax.disruptor.dsl.WorkerPoolInfo
- sequenceBarrier - Variable in class com.lmax.disruptor.WorkProcessor
- SequenceBarrier - Interface in com.lmax.disruptor
-
Coordination barrier for tracking the cursor for publishers and sequence of dependent
EventProcessor
s for processing a data structure - Sequenced - Interface in com.lmax.disruptor
- SequenceGroup - Class in com.lmax.disruptor
- SequenceGroup() - Constructor for class com.lmax.disruptor.SequenceGroup
-
Default Constructor
- SequenceGroups - Class in com.lmax.disruptor
-
Provides static methods for managing a
SequenceGroup
object. - SequenceGroups() - Constructor for class com.lmax.disruptor.SequenceGroups
- sequencer - Variable in class com.lmax.disruptor.EventPoller
- sequencer - Variable in class com.lmax.disruptor.NoOpEventProcessor.SequencerFollowingSequence
- sequencer - Variable in class com.lmax.disruptor.ProcessingSequenceBarrier
- sequencer - Variable in class com.lmax.disruptor.RingBufferFields
- Sequencer - Interface in com.lmax.disruptor
-
Coordinates claiming sequences for access to a data structure while tracking dependent
Sequence
s - SequenceReportingEventHandler<T> - Interface in com.lmax.disruptor
-
Used by the
BatchEventProcessor
to set a callback allowing theEventHandler
to notify when it has finished consuming an event if this happens after theEventHandler.onEvent(Object, long, boolean)
call. - SequencerFollowingSequence(RingBuffer<?>) - Constructor for class com.lmax.disruptor.NoOpEventProcessor.SequencerFollowingSequence
- sequences - Variable in class com.lmax.disruptor.dsl.EventHandlerGroup
- sequences - Variable in class com.lmax.disruptor.FixedSequenceGroup
- sequences - Variable in class com.lmax.disruptor.SequenceGroup
- set(long) - Method in class com.lmax.disruptor.FixedSequenceGroup
-
Not supported.
- set(long) - Method in class com.lmax.disruptor.Sequence
-
Perform an ordered write of this sequence.
- set(long) - Method in class com.lmax.disruptor.SequenceGroup
-
Set all
Sequence
s in the group to a given value. - setAvailable(long) - Method in class com.lmax.disruptor.MultiProducerSequencer
-
The below methods work on the availableBuffer flag.
- setAvailableBufferValue(int, int) - Method in class com.lmax.disruptor.MultiProducerSequencer
- setDefaultExceptionHandler(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Specify an exception handler to be used for event handlers and worker pools created by this Disruptor.
- setEventReleaser(EventReleaser) - Method in interface com.lmax.disruptor.EventReleaseAware
- setExceptionHandler(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.BatchEventProcessor
-
Set a new
ExceptionHandler
for handling exceptions propagated out of theBatchEventProcessor
- setSequenceCallback(Sequence) - Method in interface com.lmax.disruptor.SequenceReportingEventHandler
-
Call by the
BatchEventProcessor
to setup the callback. - setVolatile(long) - Method in class com.lmax.disruptor.Sequence
-
Performs a volatile write of this sequence.
- shutdown() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Waits until all events currently in the disruptor have been processed by all event processors and then halts the processors.
- shutdown(long, TimeUnit) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Waits until all events currently in the disruptor have been processed by all event processors and then halts the processors.
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.BlockingWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.BusySpinWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.LiteBlockingWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.SleepingWaitStrategy
- signalAllWhenBlocking() - Method in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- signalAllWhenBlocking() - Method in interface com.lmax.disruptor.WaitStrategy
-
Implementations should signal the waiting
EventProcessor
s that the cursor has advanced. - signalAllWhenBlocking() - Method in class com.lmax.disruptor.YieldingWaitStrategy
- signalNeeded - Variable in class com.lmax.disruptor.LiteBlockingWaitStrategy
- signalNeeded - Variable in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- SINGLE - Enum constant in enum com.lmax.disruptor.dsl.ProducerType
-
Create a RingBuffer with a single event publisher to the RingBuffer
- SingleProducerSequencer - Class in com.lmax.disruptor
-
Coordinator for claiming sequences for access to a data structure while tracking dependent
Sequence
s. - SingleProducerSequencer(int, WaitStrategy) - Constructor for class com.lmax.disruptor.SingleProducerSequencer
-
Construct a Sequencer with the selected wait strategy and buffer size.
- SingleProducerSequencerFields - Class in com.lmax.disruptor
- SingleProducerSequencerFields(int, WaitStrategy) - Constructor for class com.lmax.disruptor.SingleProducerSequencerFields
- SingleProducerSequencerPad - Class in com.lmax.disruptor
- SingleProducerSequencerPad(int, WaitStrategy) - Constructor for class com.lmax.disruptor.SingleProducerSequencerPad
- size() - Method in class com.lmax.disruptor.SequenceGroup
-
Get the size of the group.
- SleepingWaitStrategy - Class in com.lmax.disruptor
-
Sleeping strategy that initially spins, then uses a Thread.yield(), and eventually sleep (
LockSupport.parkNanos(n)
) for the minimum number of nanos the OS and JVM will allow while theEventProcessor
s are waiting on a barrier. - SleepingWaitStrategy() - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
- SleepingWaitStrategy(int) - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
- SleepingWaitStrategy(int, long) - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
- sleepTimeNs - Variable in class com.lmax.disruptor.SleepingWaitStrategy
- SPIN_TRIES - Static variable in class com.lmax.disruptor.PhasedBackoffWaitStrategy
- SPIN_TRIES - Static variable in class com.lmax.disruptor.YieldingWaitStrategy
- spinTimeoutNanos - Variable in class com.lmax.disruptor.PhasedBackoffWaitStrategy
- start() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Starts the event processors and returns the fully configured ring buffer.
- start(Executor) - Method in interface com.lmax.disruptor.dsl.ConsumerInfo
- start(Executor) - Method in class com.lmax.disruptor.dsl.EventProcessorInfo
- start(Executor) - Method in class com.lmax.disruptor.dsl.WorkerPoolInfo
- start(Executor) - Method in class com.lmax.disruptor.WorkerPool
-
Start the worker pool processing events in sequence.
- started - Variable in class com.lmax.disruptor.dsl.Disruptor
- started - Variable in class com.lmax.disruptor.WorkerPool
- switchTo(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
T
- THE_UNSAFE - Static variable in class com.lmax.disruptor.util.Util
- then(EventProcessorFactory<T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up custom event processors to handle events from the ring buffer.
- then(EventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up batch handlers to consume events from the ring buffer.
- thenHandleEventsWithWorkerPool(WorkHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up a worker pool to handle events from the ring buffer.
- ThreadHints - Class in com.lmax.disruptor.util
-
This class captures possible hints that may be used by some runtimes to improve code performance.
- ThreadHints() - Constructor for class com.lmax.disruptor.util.ThreadHints
- threads - Variable in class com.lmax.disruptor.dsl.BasicExecutor
- TimeoutBlockingWaitStrategy - Class in com.lmax.disruptor
- TimeoutBlockingWaitStrategy(long, TimeUnit) - Constructor for class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- TimeoutException - Exception Class in com.lmax.disruptor
- TimeoutException() - Constructor for exception class com.lmax.disruptor.TimeoutException
- timeoutHandler - Variable in class com.lmax.disruptor.BatchEventProcessor
- timeoutHandler - Variable in class com.lmax.disruptor.WorkProcessor
- TimeoutHandler - Interface in com.lmax.disruptor
- timeoutInNanos - Variable in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- timeoutInNanos - Variable in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- toString() - Method in class com.lmax.disruptor.AbstractSequencer
- toString() - Method in class com.lmax.disruptor.BlockingWaitStrategy
- toString() - Method in class com.lmax.disruptor.dsl.BasicExecutor
- toString() - Method in class com.lmax.disruptor.dsl.Disruptor
- toString() - Method in class com.lmax.disruptor.FixedSequenceGroup
- toString() - Method in class com.lmax.disruptor.LiteBlockingWaitStrategy
- toString() - Method in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- toString() - Method in class com.lmax.disruptor.RingBuffer
- toString() - Method in class com.lmax.disruptor.Sequence
- toString() - Method in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- translateAndPublish(EventTranslator<E>, long) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublish(EventTranslatorOneArg<E, A>, long, A) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublish(EventTranslatorThreeArg<E, A, B, C>, long, A, B, C) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublish(EventTranslatorTwoArg<E, A, B>, long, A, B) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublish(EventTranslatorVararg<E>, long, Object...) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublishBatch(EventTranslator<E>[], int, int, long) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublishBatch(EventTranslatorOneArg<E, A>, A[], int, int, long) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublishBatch(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[], int, int, long) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublishBatch(EventTranslatorTwoArg<E, A, B>, A[], B[], int, int, long) - Method in class com.lmax.disruptor.RingBuffer
- translateAndPublishBatch(EventTranslatorVararg<E>, int, int, long, Object[][]) - Method in class com.lmax.disruptor.RingBuffer
- translateTo(T, long) - Method in interface com.lmax.disruptor.EventTranslator
-
Translate a data representation into fields set in given event
- translateTo(T, long, A) - Method in interface com.lmax.disruptor.EventTranslatorOneArg
-
Translate a data representation into fields set in given event
- translateTo(T, long, A, B) - Method in interface com.lmax.disruptor.EventTranslatorTwoArg
-
Translate a data representation into fields set in given event
- translateTo(T, long, A, B, C) - Method in interface com.lmax.disruptor.EventTranslatorThreeArg
-
Translate a data representation into fields set in given event
- translateTo(T, long, Object...) - Method in interface com.lmax.disruptor.EventTranslatorVararg
-
Translate a data representation into fields set in given event
- tryNext() - Method in class com.lmax.disruptor.MultiProducerSequencer
- tryNext() - Method in class com.lmax.disruptor.RingBuffer
-
Increment and return the next sequence for the ring buffer.
- tryNext() - Method in interface com.lmax.disruptor.Sequenced
-
Attempt to claim the next event in sequence for publishing.
- tryNext() - Method in class com.lmax.disruptor.SingleProducerSequencer
- tryNext(int) - Method in class com.lmax.disruptor.MultiProducerSequencer
- tryNext(int) - Method in class com.lmax.disruptor.RingBuffer
-
The same functionality as
RingBuffer.tryNext()
, but allows the caller to attempt to claim the next n sequences. - tryNext(int) - Method in interface com.lmax.disruptor.Sequenced
-
Attempt to claim the next n events in sequence for publishing.
- tryNext(int) - Method in class com.lmax.disruptor.SingleProducerSequencer
- tryPublishEvent(EventTranslator<E>) - Method in interface com.lmax.disruptor.EventSink
-
Attempts to publish an event to the ring buffer.
- tryPublishEvent(EventTranslator<E>) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvent(EventTranslatorOneArg<E, A>, A) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- tryPublishEvent(EventTranslatorOneArg<E, A>, A) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments
- tryPublishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments.
- tryPublishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvent(EventTranslatorVararg<E>, Object...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments
- tryPublishEvent(EventTranslatorVararg<E>, Object...) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslator<E>[]) - Method in interface com.lmax.disruptor.EventSink
-
Attempts to publish multiple events to the ring buffer.
- tryPublishEvents(EventTranslator<E>[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslator<E>[], int, int) - Method in interface com.lmax.disruptor.EventSink
-
Attempts to publish multiple events to the ring buffer.
- tryPublishEvents(EventTranslator<E>[], int, int) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- tryPublishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- tryPublishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- tryPublishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
- tryPublishEvents(EventTranslatorVararg<E>, Object[]...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- tryPublishEvents(EventTranslatorVararg<E>, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
U
- unMarkEventProcessorsAsEndOfChain(Sequence...) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
- UNSAFE - Static variable in class com.lmax.disruptor.MultiProducerSequencer
- UNSAFE - Static variable in class com.lmax.disruptor.RingBufferFields
- UNSAFE - Static variable in class com.lmax.disruptor.Sequence
- updateGatingSequencesForNextInChain(Sequence[], Sequence[]) - Method in class com.lmax.disruptor.dsl.Disruptor
- Util - Class in com.lmax.disruptor.util
-
Set of common functions used by the Disruptor
- Util() - Constructor for class com.lmax.disruptor.util.Util
V
- value - Variable in class com.lmax.disruptor.Value
- Value - Class in com.lmax.disruptor
- Value() - Constructor for class com.lmax.disruptor.Value
- VALUE_OFFSET - Static variable in class com.lmax.disruptor.Sequence
- valueOf(String) - Static method in enum com.lmax.disruptor.dsl.ProducerType
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.lmax.disruptor.EventPoller.PollState
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum com.lmax.disruptor.util.DaemonThreadFactory
-
Returns the enum constant of this type with the specified name.
- values() - Static method in enum com.lmax.disruptor.dsl.ProducerType
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.lmax.disruptor.EventPoller.PollState
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum com.lmax.disruptor.util.DaemonThreadFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
W
- waitFor(long) - Method in class com.lmax.disruptor.ProcessingSequenceBarrier
- waitFor(long) - Method in interface com.lmax.disruptor.SequenceBarrier
-
Wait for the given sequence to be available for consumption.
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.BlockingWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.BusySpinWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.LiteBlockingWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.LiteTimeoutBlockingWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.SleepingWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in interface com.lmax.disruptor.WaitStrategy
-
Wait for the given sequence to be available.
- waitFor(long, Sequence, Sequence, SequenceBarrier) - Method in class com.lmax.disruptor.YieldingWaitStrategy
- waitStrategy - Variable in class com.lmax.disruptor.AbstractSequencer
- waitStrategy - Variable in class com.lmax.disruptor.ProcessingSequenceBarrier
- WaitStrategy - Interface in com.lmax.disruptor
-
Strategy employed for making
EventProcessor
s wait on a cursorSequence
. - with(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerSetting
-
Specify the
ExceptionHandler
to use with the event handler. - withLiteLock(long, long, TimeUnit) - Static method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
-
Construct
PhasedBackoffWaitStrategy
with fallback toLiteBlockingWaitStrategy
- withLock(long, long, TimeUnit) - Static method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
-
Construct
PhasedBackoffWaitStrategy
with fallback toBlockingWaitStrategy
- withSleep(long, long, TimeUnit) - Static method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
-
Construct
PhasedBackoffWaitStrategy
with fallback toSleepingWaitStrategy
- workerPool - Variable in class com.lmax.disruptor.dsl.WorkerPoolInfo
- WorkerPool<T> - Class in com.lmax.disruptor
-
WorkerPool contains a pool of
WorkProcessor
s that will consume sequences so jobs can be farmed out across a pool of workers. - WorkerPool(EventFactory<T>, ExceptionHandler<? super T>, WorkHandler<? super T>...) - Constructor for class com.lmax.disruptor.WorkerPool
-
Construct a work pool with an internal
RingBuffer
for convenience. - WorkerPool(RingBuffer<T>, SequenceBarrier, ExceptionHandler<? super T>, WorkHandler<? super T>...) - Constructor for class com.lmax.disruptor.WorkerPool
-
Create a worker pool to enable an array of
WorkHandler
s to consume published sequences. - WorkerPoolInfo<T> - Class in com.lmax.disruptor.dsl
- WorkerPoolInfo(WorkerPool<T>, SequenceBarrier) - Constructor for class com.lmax.disruptor.dsl.WorkerPoolInfo
- workHandler - Variable in class com.lmax.disruptor.WorkProcessor
- WorkHandler<T> - Interface in com.lmax.disruptor
-
Callback interface to be implemented for processing units of work as they become available in the
RingBuffer
. - WorkProcessor<T> - Class in com.lmax.disruptor
-
A
WorkProcessor
wraps a singleWorkHandler
, effectively consuming the sequence and ensuring appropriate barriers. - WorkProcessor(RingBuffer<T>, SequenceBarrier, WorkHandler<? super T>, ExceptionHandler<? super T>, Sequence) - Constructor for class com.lmax.disruptor.WorkProcessor
-
Construct a
WorkProcessor
. - workProcessors - Variable in class com.lmax.disruptor.WorkerPool
- workSequence - Variable in class com.lmax.disruptor.WorkerPool
- workSequence - Variable in class com.lmax.disruptor.WorkProcessor
Y
- YieldingWaitStrategy - Class in com.lmax.disruptor
-
Yielding strategy that uses a Thread.yield() for
EventProcessor
s waiting on a barrier after an initially spinning. - YieldingWaitStrategy() - Constructor for class com.lmax.disruptor.YieldingWaitStrategy
- yieldTimeoutNanos - Variable in class com.lmax.disruptor.PhasedBackoffWaitStrategy
All Classes and Interfaces|All Packages|Constant Field Values|Serialized Form
ThreadFactory
instead of anExecutor
as a the ThreadFactory is able to report errors when it is unable to construct a thread to run a producer.