A B C D E F G H I L M N O P R S T U V W Y 
All Classes All Packages

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(Sequence) - Method in class com.lmax.disruptor.SequenceGroup
Add a Sequence into this aggregate.
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.
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(EventHandlerIdentity...) - 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 EventHandlers that get called in sequence for each event.
AggregateEventHandler(EventHandler<T>...) - Constructor for class com.lmax.disruptor.AggregateEventHandler
Construct an aggregate collection of EventHandlers to be called in sequence.
alert() - Method in interface com.lmax.disruptor.SequenceBarrier
Alert the EventProcessors of a status change and stay in this status until cleared.
AlertException - Exception in com.lmax.disruptor
Used to alert EventProcessors waiting at a SequenceBarrier of status changes.
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.
asSequenceBarrier() - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
Create a dependency barrier for the processors in this group.
attemptRewindGetNextSequence(RewindableException, long) - Method in interface com.lmax.disruptor.RewindHandler
 
awaitNanos(Object, long) - Static method in class com.lmax.disruptor.util.Util
 

B

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 an EventHandler.
BatchEventProcessorBuilder - Class in com.lmax.disruptor
 
BatchEventProcessorBuilder() - Constructor for class com.lmax.disruptor.BatchEventProcessorBuilder
 
BatchRewindStrategy - Interface in com.lmax.disruptor
Strategy for handling a rewindableException when processing an event.
BlockingWaitStrategy - Class in com.lmax.disruptor
Blocking strategy that uses a lock and condition variable for EventProcessors waiting on a barrier.
BlockingWaitStrategy() - Constructor for class com.lmax.disruptor.BlockingWaitStrategy
 
build(DataProvider<T>, SequenceBarrier, EventHandler<? super T>) - Method in class com.lmax.disruptor.BatchEventProcessorBuilder
Construct a EventProcessor that will automatically track the progress by updating its sequence when the EventHandler.onEvent(Object, long, boolean) method returns.
build(DataProvider<T>, SequenceBarrier, RewindableEventHandler<? super T>, BatchRewindStrategy) - Method in class com.lmax.disruptor.BatchEventProcessorBuilder
Construct a EventProcessor that will automatically track the progress by updating its sequence when the EventHandler.onEvent(Object, long, boolean) method returns.
BusySpinWaitStrategy - Class in com.lmax.disruptor
Busy Spin strategy that uses a busy spin loop for EventProcessors waiting on a barrier.
BusySpinWaitStrategy() - Constructor for class com.lmax.disruptor.BusySpinWaitStrategy
 

C

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 interface com.lmax.disruptor.SequenceBarrier
Check if an alert has been raised and throw an AlertException if it has.
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 interface com.lmax.disruptor.SequenceBarrier
Clear the current alert status.
com.lmax.disruptor - module com.lmax.disruptor
 
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
A DSL-style API for setting up the disruptor pattern around a ring buffer.
com.lmax.disruptor.util - package com.lmax.disruptor.util
Utility classes
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.
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.
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.
Cursored - Interface in com.lmax.disruptor
Implementors of this interface must provide a single long value that represents their current cursor value.

D

DaemonThreadFactory - Enum in com.lmax.disruptor.util
Access to a ThreadFactory instance.
DataProvider<T> - Interface in com.lmax.disruptor
Typically used to decouple classes from RingBuffer to allow easier testing
defaultHandler() - Static method in class com.lmax.disruptor.ExceptionHandlers
Get a reference to the default ExceptionHandler instance.
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, 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.

E

EventFactory<T> - Interface in com.lmax.disruptor
Called by the RingBuffer to pre-populate all the events to fill the RingBuffer.
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 EventProcessors used as part of the Disruptor.
EventHandlerIdentity - Interface in com.lmax.disruptor
 
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
Creates an event poller.
EventPoller.Handler<T> - Interface in com.lmax.disruptor
A callback used to process events
EventPoller.PollState - Enum in com.lmax.disruptor
Indicates the result of a call to EventPoller.poll(Handler)
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:
EventSequencer<T> - Interface in com.lmax.disruptor
Pulls together the low-level data access and sequencing operations of RingBuffer
EventSink<E> - Interface in com.lmax.disruptor
Write interface for RingBuffer.
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,​B,​C> - Interface in com.lmax.disruptor
Implementations translate another data representations into events claimed from the RingBuffer
EventTranslatorTwoArg<T,​A,​B> - Interface in com.lmax.disruptor
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
EventuallyGiveUpBatchRewindStrategy - Class in com.lmax.disruptor
Strategy for handling a rewindableException that will eventually delegate the exception to the ExceptionHandler after a specified number of attempts have been made.
EventuallyGiveUpBatchRewindStrategy(long) - Constructor for class com.lmax.disruptor.EventuallyGiveUpBatchRewindStrategy
 
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.
ExceptionHandlerSetting<T> - Class in com.lmax.disruptor.dsl
A support class used as part of setting an exception handler for a specific event handler.
ExceptionHandlerWrapper<T> - Class in com.lmax.disruptor.dsl
A mutable exception handler wrapper
ExceptionHandlerWrapper() - Constructor for class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
 

F

FatalExceptionHandler - Class in com.lmax.disruptor
Convenience implementation of an exception handler that uses the standard JDK logging of System.Logger to log the exception as System.Logger.Level.ERROR and re-throw it wrapped in a RuntimeException
FatalExceptionHandler() - Constructor for class com.lmax.disruptor.FatalExceptionHandler
 
fillInStackTrace() - Method in exception com.lmax.disruptor.AlertException
Overridden so the stack trace is not filled in for this exception for performance reasons.
fillInStackTrace() - Method in exception com.lmax.disruptor.InsufficientCapacityException
 
fillInStackTrace() - Method in exception 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 - com.lmax.disruptor.EventPoller.PollState
The poller is waiting for gated sequences to advance before events become available
get() - Method in class com.lmax.disruptor.FixedSequenceGroup
Get the minimum sequence value for the group.
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.
getAndAdd(long) - Method in class com.lmax.disruptor.Sequence
Perform an atomic getAndAdd operation on the sequence.
getBarrierFor(EventHandlerIdentity) - 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.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.
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
 
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 Sequences.
getMinimumSequence(Sequence[], long) - Static method in class com.lmax.disruptor.util.Util
Get the minimum sequence from an array of Sequences.
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
Get the Sequence being used by this event poller
getSequence() - Method in interface com.lmax.disruptor.EventProcessor
Get a reference to the Sequence being used by this EventProcessor.
getSequence() - Method in class com.lmax.disruptor.NoOpEventProcessor
 
getSequencesFor(EventProcessor...) - Static method in class com.lmax.disruptor.util.Util
Get an array of Sequences for the passed EventProcessors.
getSequenceValueFor(EventHandlerIdentity) - Method in class com.lmax.disruptor.dsl.Disruptor
Gets the sequence value for the specified event handlers.

H

halt() - Method in class com.lmax.disruptor.BatchEventProcessor
 
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 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
 
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.dsl.ExceptionHandlerWrapper
 
handleEventException(Throwable, long, T) - Method in interface com.lmax.disruptor.ExceptionHandler
Strategy for handling uncaught exceptions when processing an event.
handleEventsWith(BatchRewindStrategy, RewindableEventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
Set up event handlers to handle events from the ring buffer.
handleEventsWith(BatchRewindStrategy, RewindableEventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
Set up batch handlers to handle events from the ring buffer.
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.
handleExceptionsFor(EventHandlerIdentity) - 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.dsl.ExceptionHandlerWrapper
 
handleOnShutdownException(Throwable) - Method in interface com.lmax.disruptor.ExceptionHandler
Callback to notify of an exception during EventHandlerBase.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.dsl.ExceptionHandlerWrapper
 
handleOnStartException(Throwable) - Method in interface com.lmax.disruptor.ExceptionHandler
Callback to notify of an exception during EventHandlerBase.onStart()
handleOnStartException(Throwable) - Method in class com.lmax.disruptor.FatalExceptionHandler
 
handleOnStartException(Throwable) - Method in class com.lmax.disruptor.IgnoreExceptionHandler
 
handleRewindException(RewindableException, int) - Method in interface com.lmax.disruptor.BatchRewindStrategy
When a RewindableException is thrown, this will be called.
handleRewindException(RewindableException, int) - Method in class com.lmax.disruptor.EventuallyGiveUpBatchRewindStrategy
 
handleRewindException(RewindableException, int) - Method in class com.lmax.disruptor.NanosecondPauseBatchRewindStrategy
 
handleRewindException(RewindableException, int) - Method in class com.lmax.disruptor.SimpleBatchRewindStrategy
 
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
 
hasStarted() - Method in class com.lmax.disruptor.dsl.Disruptor
Checks if disruptor has been started

I

IDLE - com.lmax.disruptor.EventPoller.PollState
No events need to be processed
IgnoreExceptionHandler - Class in com.lmax.disruptor
Convenience implementation of an exception handler that uses the standard JDK logging of System.Logger to log the exception as System.Logger.Level.INFO
IgnoreExceptionHandler() - 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.
INITIAL_CURSOR_VALUE - Static variable in class com.lmax.disruptor.RingBuffer
The initial cursor value
INITIAL_CURSOR_VALUE - Static variable in interface com.lmax.disruptor.Sequencer
Set to -1 as sequence starting point
INSTANCE - com.lmax.disruptor.util.DaemonThreadFactory
The singleton instance
INSTANCE - Static variable in exception com.lmax.disruptor.AlertException
Pre-allocated exception to avoid garbage generation.
INSTANCE - Static variable in exception com.lmax.disruptor.InsufficientCapacityException
The efficiency saving singleton instance
INSTANCE - Static variable in exception com.lmax.disruptor.TimeoutException
The efficiency saving singleton instance
InsufficientCapacityException - Exception 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.
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 class com.lmax.disruptor.RingBuffer
Determines if the event for a given sequence is currently available.
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
 
isRunning() - Method in class com.lmax.disruptor.BatchEventProcessor
 
isRunning() - Method in interface com.lmax.disruptor.EventProcessor
 
isRunning() - Method in class com.lmax.disruptor.NoOpEventProcessor
 

L

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
 
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.

M

MULTI - 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 Sequences.
MultiProducerSequencer(int, WaitStrategy) - Constructor for class com.lmax.disruptor.MultiProducerSequencer
Construct a Sequencer with the selected wait strategy and buffer size.

N

NanosecondPauseBatchRewindStrategy - Class in com.lmax.disruptor
Strategy for handling a rewindableException that will pause for a specified amount of nanos.
NanosecondPauseBatchRewindStrategy(long) - Constructor for class com.lmax.disruptor.NanosecondPauseBatchRewindStrategy
Strategy for handling a rewindableException that will pause for a specified amount of nanos.
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
Implementations should instantiate an event object, with all memory already allocated where possible.
newInstance(DataProvider<T>, Sequencer, Sequence, Sequence, Sequence...) - Static method in class com.lmax.disruptor.EventPoller
Creates an event poller.
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
Creates an event poller from this 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
 
NoOpEventProcessor - Class in com.lmax.disruptor
No operation version of a EventProcessor that simply tracks a Sequence.
NoOpEventProcessor(RingBuffer<?>) - Constructor for class com.lmax.disruptor.NoOpEventProcessor
Construct a EventProcessor that simply tracks a Sequence object.

O

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
Called for each event to consume it
onEvent(T, long, boolean) - Method in interface com.lmax.disruptor.RewindableEventHandler
Called when a publisher has published an event to the RingBuffer.
onShutdown() - Method in class com.lmax.disruptor.AggregateEventHandler
 
onSpinWait() - Static method in class com.lmax.disruptor.util.ThreadHints
Deprecated.
Use Thread.onSpinWait() directly. This method previously existed to accommodate Java versions which do not have Thread.onSpinWait().
onStart() - Method in class com.lmax.disruptor.AggregateEventHandler
 

P

PhasedBackoffWaitStrategy - Class in com.lmax.disruptor
Phased wait strategy for waiting EventProcessors 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
Polls for events using the given handler.
PROCESSING - com.lmax.disruptor.EventPoller.PollState
The poller processed one or more events
ProducerType - Enum in com.lmax.disruptor.dsl
Defines producer types to support creation of RingBuffer with correct sequencer and publisher.
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

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.
REWIND - com.lmax.disruptor.RewindAction
Rewind and replay the whole batch from he beginning
RewindableEventHandler<T> - Interface in com.lmax.disruptor
Callback interface to be implemented for processing events as they become available in the RingBuffer with support for throwing a RewindableException when an even cannot be processed currently but may succeed on retry.
RewindableException - Class in com.lmax.disruptor
A special exception that can be thrown while using the BatchEventProcessor.
RewindableException(Throwable) - Constructor for class com.lmax.disruptor.RewindableException
 
RewindAction - Enum in com.lmax.disruptor
The result returned from the BatchRewindStrategy that decides whether to rewind or throw the exception
RewindHandler - Interface in com.lmax.disruptor
 
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 EventProcessors.
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
 

S

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.
SequenceBarrier - Interface in com.lmax.disruptor
Coordination barrier for tracking the cursor for publishers and sequence of dependent EventProcessors for processing a data structure
Sequenced - Interface in com.lmax.disruptor
Operations related to the sequencing of items in a RingBuffer.
SequenceGroup - Class in com.lmax.disruptor
A Sequence group that can dynamically have Sequences added and removed while being thread safe.
SequenceGroup() - Constructor for class com.lmax.disruptor.SequenceGroup
Default Constructor
Sequencer - Interface in com.lmax.disruptor
Coordinates claiming sequences for access to a data structure while tracking dependent Sequences
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 Sequences in the group to a given value.
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.
setExceptionHandler(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.BatchEventProcessor
Set a new ExceptionHandler for handling exceptions propagated out of the BatchEventProcessor.
setMaxBatchSize(int) - Method in class com.lmax.disruptor.BatchEventProcessorBuilder
Set the maximum number of events that will be processed in a batch before updating the sequence.
setSequenceCallback(Sequence) - Method in interface com.lmax.disruptor.EventHandler
Used by the BatchEventProcessor to set a callback allowing the EventHandler to notify when it has finished consuming an event if this happens after the EventHandler.onEvent(Object, long, boolean) call.
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 EventProcessors that the cursor has advanced.
signalAllWhenBlocking() - Method in class com.lmax.disruptor.YieldingWaitStrategy
 
SimpleBatchRewindStrategy - Class in com.lmax.disruptor
Batch rewind strategy that always rewinds
SimpleBatchRewindStrategy() - Constructor for class com.lmax.disruptor.SimpleBatchRewindStrategy
 
SINGLE - 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 Sequences.
SingleProducerSequencer(int, WaitStrategy) - Constructor for class com.lmax.disruptor.SingleProducerSequencer
Construct a Sequencer with the selected wait strategy and buffer size.
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 the EventProcessors are waiting on a barrier.
SleepingWaitStrategy() - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
Provides a sleeping wait strategy with the default retry and sleep settings
SleepingWaitStrategy(int) - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
 
SleepingWaitStrategy(int, long) - Constructor for class com.lmax.disruptor.SleepingWaitStrategy
 
start() - Method in class com.lmax.disruptor.dsl.Disruptor
Starts the event processors and returns the fully configured ring buffer.
switchTo(ExceptionHandler<? super T>) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
Switch to a different exception handler

T

then(BatchRewindStrategy, RewindableEventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
Set up batch handlers to consume events from the ring buffer.
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.
ThreadHints - Class in com.lmax.disruptor.util
Deprecated.
Use Thread.onSpinWait() directly. This class previously existed to accommodate Java versions which do not have Thread.onSpinWait().
THROW - com.lmax.disruptor.RewindAction
rethrows the exception, delegating it to the configured ExceptionHandler
TimeoutBlockingWaitStrategy - Class in com.lmax.disruptor
Blocking strategy that uses a lock and condition variable for EventProcessors waiting on a barrier.
TimeoutBlockingWaitStrategy(long, TimeUnit) - Constructor for class com.lmax.disruptor.TimeoutBlockingWaitStrategy
 
TimeoutException - Exception in com.lmax.disruptor
Wait strategies may throw this Exception to inform callers that a message has not been detected within a specific time window.
toString() - Method in class com.lmax.disruptor.AbstractSequencer
 
toString() - Method in class com.lmax.disruptor.BlockingWaitStrategy
 
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.MultiProducerSequencer
 
toString() - Method in class com.lmax.disruptor.RingBuffer
 
toString() - Method in class com.lmax.disruptor.Sequence
 
toString() - Method in class com.lmax.disruptor.SingleProducerSequencer
 
toString() - Method in class com.lmax.disruptor.TimeoutBlockingWaitStrategy
 
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

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

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.RewindAction
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.RewindAction
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 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 - Interface in com.lmax.disruptor
Strategy employed for making EventProcessors wait on a cursor Sequence.
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
withLock(long, long, TimeUnit) - Static method in class com.lmax.disruptor.PhasedBackoffWaitStrategy
withSleep(long, long, TimeUnit) - Static method in class com.lmax.disruptor.PhasedBackoffWaitStrategy

Y

YieldingWaitStrategy - Class in com.lmax.disruptor
Yielding strategy that uses a Thread.yield() for EventProcessors waiting on a barrier after an initially spinning.
YieldingWaitStrategy() - Constructor for class com.lmax.disruptor.YieldingWaitStrategy
 
A B C D E F G H I L M N O P R S T U V W Y 
All Classes All Packages