- 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, EventHandler<? super T>, SequenceBarrier) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
-
- add(EventProcessor) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
-
- add(WorkerPool<T>, SequenceBarrier) - Method in class com.lmax.disruptor.dsl.ConsumerRepository
-
- add(Sequence) - Method in class com.lmax.disruptor.SequenceGroup
-
- 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.
- addObservation(long) - Method in class com.lmax.disruptor.collections.Histogram
-
Add an observation to the histogram and increment the counter for the interval it matches.
- addObservations(Histogram) - Method in class com.lmax.disruptor.collections.Histogram
-
Add observations from another Histogram into this one.
- 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 in com.lmax.disruptor
-
- AlertException() - Constructor for exception 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
-
- 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(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() - 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(long) - Method in class com.lmax.disruptor.RingBuffer
-
Get the event for a given sequence in the RingBuffer.
- 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.
- getAddressFromDirectByteBuffer(ByteBuffer) - Static method in class com.lmax.disruptor.util.Util
-
Gets the address value for the memory that backs a direct byte buffer.
- 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
-
- 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.
- getCount() - Method in class com.lmax.disruptor.collections.Histogram
-
Count total number of recorded observations.
- getCountAt(int) - Method in class com.lmax.disruptor.collections.Histogram
-
Get the count of observations at a given index.
- 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
-
- getFourNinesUpperBound() - Method in class com.lmax.disruptor.collections.Histogram
-
Calculate the upper bound within which 99.99% of observations fall.
- 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
-
- getMax() - Method in class com.lmax.disruptor.collections.Histogram
-
Get the maximum observed value.
- getMean() - Method in class com.lmax.disruptor.collections.Histogram
-
Calculate the mean of all recorded observations.
- getMin() - Method in class com.lmax.disruptor.collections.Histogram
-
Get the minimum observed value.
- 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
-
- getSequence() - Method in class com.lmax.disruptor.BatchEventProcessor
-
- getSequence() - Method in class com.lmax.disruptor.EventPoller
-
- getSequence() - Method in interface com.lmax.disruptor.EventProcessor
-
- 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
-
- getSequenceValueFor(EventHandler<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Gets the sequence value for the specified event handlers.
- getSize() - Method in class com.lmax.disruptor.collections.Histogram
-
Size of the list of interval bars (ie: count of interval bars).
- getTwoNinesUpperBound() - Method in class com.lmax.disruptor.collections.Histogram
-
Calculate the upper bound within which 99% of observations fall.
- 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.
- getUpperBoundAt(int) - Method in class com.lmax.disruptor.collections.Histogram
-
Get the upper bound of an interval for an index.
- getUpperBoundForFactor(double) - Method in class com.lmax.disruptor.collections.Histogram
-
Get the interval upper bound for a given factor of the observation population.
- getWorkerSequences() - Method in class com.lmax.disruptor.WorkerPool
-
Get an array of
Sequence
s representing the progress of the workers.
- 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
-
- 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
-
- 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.
- handleEventException(Throwable, long, Object) - Method in class com.lmax.disruptor.FatalExceptionHandler
-
- handleEventException(Throwable, long, Object) - Method in class com.lmax.disruptor.IgnoreExceptionHandler
-
- handleEventsWith(EventHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up event 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(EventProcessor...) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Set up custom event processors 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(EventProcessorFactory<T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up custom event processors 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.
- handleEventsWithWorkerPool(WorkHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up a worker pool to handle events from the ring buffer.
- 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
-
- handleOnShutdownException(Throwable) - Method in class com.lmax.disruptor.dsl.ExceptionHandlerWrapper
-
- handleOnShutdownException(Throwable) - Method in interface com.lmax.disruptor.ExceptionHandler
-
- 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
-
- 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
-
- hasAvailableCapacity(int) - Method in class com.lmax.disruptor.MultiProducerSequencer
-
- hasAvailableCapacity(Sequence[], int, long) - 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
-
- hasBacklog() - Method in class com.lmax.disruptor.dsl.Disruptor
-
Confirms if all messages have been consumed by all event processors
- Histogram - Class in com.lmax.disruptor.collections
-
Histogram for tracking the frequency of observations of values below interval upper bounds.
- Histogram(long[]) - Constructor for class com.lmax.disruptor.collections.Histogram
-
Create a new Histogram with a provided list of interval bounds.
- 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
-
- 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
-
- ProcessingSequenceBarrier - Class in com.lmax.disruptor
-
- 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, long) - Method in class com.lmax.disruptor.MultiProducerSequencer
-
- publish(long) - Method in class com.lmax.disruptor.RingBuffer
-
Publish the specified sequence.
- publish(long, long) - Method in class com.lmax.disruptor.RingBuffer
-
Publish the specified sequences.
- publish(long) - Method in interface com.lmax.disruptor.Sequenced
-
Publishes a sequence.
- publish(long, long) - Method in interface com.lmax.disruptor.Sequenced
-
Batch publish sequences.
- publish(long) - Method in class com.lmax.disruptor.SingleProducerSequencer
-
- publish(long, long) - Method in class com.lmax.disruptor.SingleProducerSequencer
-
- publishEvent(EventTranslator<T>) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslatorOneArg<T, A>, A) - Method in class com.lmax.disruptor.dsl.Disruptor
-
Publish an event to the ring buffer.
- publishEvent(EventTranslator<E>) - Method in interface com.lmax.disruptor.EventSink
-
Publishes an event to the ring buffer.
- publishEvent(EventTranslatorOneArg<E, A>, A) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- publishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments.
- publishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments
- publishEvent(EventTranslatorVararg<E>, Object...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments
- publishEvent(EventTranslator<E>) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvent(EventTranslatorOneArg<E, A>, A) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvent(EventTranslatorVararg<E>, Object...) - 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(EventTranslator<E>[]) - Method in interface com.lmax.disruptor.EventSink
-
Publishes multiple events to the ring buffer.
- publishEvents(EventTranslator<E>[], int, int) - Method in interface com.lmax.disruptor.EventSink
-
Publishes multiple events to the ring buffer.
- publishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument per event.
- publishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument per event.
- 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>, int, int, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- 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>, int, int, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- publishEvents(EventTranslatorVararg<E>, 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 interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- publishEvents(EventTranslator<E>[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslator<E>[], int, int) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorVararg<E>, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
-
- publishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
-
- THE_UNSAFE - Static variable in class com.lmax.disruptor.util.Util
-
- then(EventHandler<? 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.
- thenHandleEventsWithWorkerPool(WorkHandler<? super T>...) - Method in class com.lmax.disruptor.dsl.EventHandlerGroup
-
Set up a worker pool to handle events from the ring buffer.
- 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 in com.lmax.disruptor
-
- TimeoutException() - Constructor for exception com.lmax.disruptor.TimeoutException
-
- timeoutHandler - Variable in class com.lmax.disruptor.BatchEventProcessor
-
- TimeoutHandler - Interface in com.lmax.disruptor
-
- timeoutHandler - Variable in class com.lmax.disruptor.WorkProcessor
-
- 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.collections.Histogram
-
- 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
-
- trackRange(long) - Method in class com.lmax.disruptor.collections.Histogram
-
Track minimum and maximum observations
- 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(EventTranslatorTwoArg<E, A, B>, long, A, B) - 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(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(EventTranslatorTwoArg<E, A, B>, A[], B[], 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(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, C) - Method in interface com.lmax.disruptor.EventTranslatorThreeArg
-
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, 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(int) - 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(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() - Method in interface com.lmax.disruptor.Sequenced
-
Attempt to claim the next event in sequence for publishing.
- tryNext(int) - Method in interface com.lmax.disruptor.Sequenced
-
Attempt to claim the next n events in sequence for publishing.
- tryNext() - Method in class com.lmax.disruptor.SingleProducerSequencer
-
- 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(EventTranslatorOneArg<E, A>, A) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- tryPublishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments.
- tryPublishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments
- tryPublishEvent(EventTranslatorVararg<E>, Object...) - Method in interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments
- tryPublishEvent(EventTranslator<E>) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvent(EventTranslatorOneArg<E, A>, A) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvent(EventTranslatorTwoArg<E, A, B>, A, B) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvent(EventTranslatorThreeArg<E, A, B, C>, A, B, C) - Method in class com.lmax.disruptor.RingBuffer
-
- 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>[], int, int) - Method in interface com.lmax.disruptor.EventSink
-
Attempts to publish multiple events to the ring buffer.
- tryPublishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- tryPublishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows one user supplied argument.
- 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>, int, int, A[], B[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows two user supplied arguments per event.
- 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>, int, int, A[], B[], C[]) - Method in interface com.lmax.disruptor.EventSink
-
Allows three user supplied arguments per event.
- tryPublishEvents(EventTranslatorVararg<E>, 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 interface com.lmax.disruptor.EventSink
-
Allows a variable number of user supplied arguments per event.
- tryPublishEvents(EventTranslator<E>[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslator<E>[], int, int) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorOneArg<E, A>, A[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorOneArg<E, A>, int, int, A[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorTwoArg<E, A, B>, int, int, A[], B[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorThreeArg<E, A, B, C>, int, int, A[], B[], C[]) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorVararg<E>, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
-
- tryPublishEvents(EventTranslatorVararg<E>, int, int, Object[]...) - Method in class com.lmax.disruptor.RingBuffer
-