- AbstractLifecycleDispatcher - Class in reactor.core.dispatch
-
A Dispatcher
that has a lifecycle.
- AbstractLifecycleDispatcher() - Constructor for class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- AbstractLifecycleDispatcher.Task - Class in reactor.core.dispatch
-
- accept(IN) - Method in class reactor.core.processor.ReactorProcessor
-
- accept(LEFT, RIGHT) - Method in interface reactor.fn.BiConsumer
-
- accept(T) - Method in interface reactor.fn.Consumer
-
Execute the logic of the action, accepting the given parameter.
- accept(T) - Method in class reactor.fn.support.Tap
-
- add(E) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- addAll(Collection<? extends E>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- addCachedDispatchers(String, DispatcherSupplier) - Method in class reactor.Environment
-
Adds the dispatcherFactory
to the environment, storing it using the given name
.
- addCause(Throwable, Throwable) - Static method in class reactor.core.support.Exceptions
-
Adds a Throwable
to a causality-chain of Throwables, as an additional cause (if it does not
already appear in the chain among the causes).
- addDelimiterIfAny(Buffer) - Method in class reactor.io.codec.Codec
-
Add a trailing delimiter if defined
- addValueAsLastCause(Throwable, Object) - Static method in class reactor.core.support.Exceptions
-
Adds the given item as the final cause of the given Throwable
, wrapped in OnNextValue
(which extends RuntimeException
).
- AgileWaitingStrategy - Class in reactor.core.dispatch.wait
-
A pair of slow and fast wait strategies to dynamically adapt to a given application load
- AgileWaitingStrategy() - Constructor for class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- AgileWaitingStrategy(WaitStrategy, WaitStrategy) - Constructor for class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- alive() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- alive() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- alive() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- alive() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- alive() - Method in class reactor.core.processor.ExecutorPoweredProcessor
-
- alive() - Static method in class reactor.Environment
-
Read if the context environment has been set
- alive() - Method in interface reactor.fn.Resource
-
Determine whether this Resource
can be used.
- allocateRecursiveTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- allocateRecursiveTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- allocateRecursiveTask() - Method in class reactor.core.dispatch.SingleThreadDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.MpscDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.SingleThreadDispatcher
-
- allocateTask() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- always() - Static method in class reactor.fn.Predicates
-
Deprecated.
Returns a Predicate which always evaluates to true.
- and(Predicate<? super T>...) - Static method in class reactor.fn.Predicates
-
Deprecated.
Returns a Predicate which evaluates to true only if all the provided predicates evaluate to
true.
- append(String) - Method in class reactor.io.buffer.Buffer
-
Append the given String to this Buffer.
- append(short) - Method in class reactor.io.buffer.Buffer
-
Append the given short
to this Buffer.
- append(int) - Method in class reactor.io.buffer.Buffer
-
Append the given int
to this Buffer.
- append(long) - Method in class reactor.io.buffer.Buffer
-
Append the given long
to this Buffer.
- append(char) - Method in class reactor.io.buffer.Buffer
-
Append the given char
to this Buffer.
- append(ByteBuffer...) - Method in class reactor.io.buffer.Buffer
-
Append the given ByteBuffer
to this Buffer.
- append(Buffer...) - Method in class reactor.io.buffer.Buffer
-
Append the given
Buffer
to this Buffer.
- append(byte) - Method in class reactor.io.buffer.Buffer
-
Append the given byte
to this Buffer.
- append(byte[]) - Method in class reactor.io.buffer.Buffer
-
Append the given byte[]
to this Buffer.
- append(byte[], int, int) - Method in class reactor.io.buffer.Buffer
-
Append the given byte[]
to this Buffer, starting at the given index and continuing for the
given
length.
- apply(LEFT, RIGHT) - Method in interface reactor.fn.BiFunction
-
- apply(T) - Method in interface reactor.fn.Function
-
Execute the logic of the action, accepting the given parameter.
- apply(byte[]) - Method in class reactor.io.codec.ByteArrayCodec
-
- apply(OUT) - Method in class reactor.io.codec.compress.CompressionCodec
-
- apply(OUT) - Method in class reactor.io.codec.DelimitedCodec
-
- apply(Frame) - Method in class reactor.io.codec.FrameCodec
-
- apply(T) - Method in class reactor.io.codec.JavaSerializationCodec
-
- apply(OUT) - Method in class reactor.io.codec.json.JsonCodec
-
- apply(OUT) - Method in class reactor.io.codec.LengthFieldCodec
-
- apply(SRC) - Method in class reactor.io.codec.PassThroughCodec
-
- apply(OUT) - Method in class reactor.io.codec.SerializationCodec
-
- apply(String) - Method in class reactor.io.codec.StringCodec
-
- apply(String) - Method in class reactor.io.codec.StringCodec.StringEncoder
-
- approxCurrentTimeMillis() - Static method in class reactor.fn.timer.TimeUtils
-
- asBytes() - Method in class reactor.io.buffer.Buffer
-
Return the contents of this buffer copied into a byte[]
.
- Assert - Class in reactor.core.support
-
Assertion utility class that assists in validating arguments.
- Assert() - Constructor for class reactor.core.support.Assert
-
- assign(Environment) - Static method in class reactor.Environment
-
Assign an environment to the context in order to make it available statically in the application from the current
classloader.
- assignErrorJournal() - Method in class reactor.Environment
-
Assign a default error
Consumer
to listen for any call to
this#routeError(Throwable)
.
- assignErrorJournal(Consumer<? super Throwable>) - Method in class reactor.Environment
-
Assign the error
Consumer
to listen for any call to
this#routeError(Throwable)
.
- asString() - Method in class reactor.io.buffer.Buffer
-
Convert the contents of this buffer into a String using a UTF-8 CharsetDecoder
.
- autoCancel - Variable in class reactor.core.processor.ReactorProcessor
-
- awaitAndShutdown() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.MpscDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- awaitAndShutdown() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- awaitAndShutdown() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
- awaitAndShutdown() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- awaitAndShutdown() - Method in class reactor.core.processor.ExecutorPoweredProcessor
-
- awaitAndShutdown(long, TimeUnit) - Method in class reactor.core.processor.ExecutorPoweredProcessor
-
- awaitAndShutdown() - Method in interface reactor.fn.Resource
-
- awaitAndShutdown(long, TimeUnit) - Method in interface reactor.fn.Resource
-
- awaitTermination(long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- backlog - Variable in class reactor.core.dispatch.SingleThreadDispatcher
-
- backlogSize() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- backlogSize() - Method in class reactor.core.dispatch.SingleThreadDispatcher
-
- backlogSize() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- backlogSize() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- backlogSize() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- backlogSize() - Method in interface reactor.core.Dispatcher
-
Request the capacity for the underlying shared state structure.
- barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Intercept a source Publisher
onNext signal to eventually transform, forward or filter the data by calling
or not
the right operand Subscriber
.
- barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>, BiConsumer<Throwable, Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Intercept a source Publisher
onNext signal to eventually transform, forward or filter the data by calling
or not
the right operand Subscriber
.
- barrier(Publisher<I>, BiConsumer<I, Subscriber<? super O>>, BiConsumer<Throwable, Subscriber<? super O>>, Consumer<Subscriber<? super O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Intercept a source Publisher
onNext signal to eventually transform, forward or filter the data by calling
or not
the right operand Subscriber
.
- basePath(String) - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- beforeAccept(SRC) - Method in class reactor.io.codec.PassThroughCodec
-
Override to intercept the source object before it is passed into the next
Consumer
or
returned to the caller if a
Consumer
is not set.
- beforeApply(SRC) - Method in class reactor.io.codec.PassThroughCodec
-
Override to intercept the source object before it is returned for output.
- BiConsumer<LEFT,RIGHT> - Interface in reactor.fn
-
Implementations of this class perform work on the given parameters pair.
- BiFunction<LEFT,RIGHT,R> - Interface in reactor.fn
-
Implementations of this class perform work on the given parameters pair and return a result of an optionally different
type.
- Buffer - Class in reactor.io.buffer
-
A Buffer is a general-purpose IO utility class that wraps a ByteBuffer
.
- Buffer() - Constructor for class reactor.io.buffer.Buffer
-
Create an empty Buffer that is dynamic.
- Buffer(int, boolean) - Constructor for class reactor.io.buffer.Buffer
-
Create an Buffer that has an internal ByteBuffer
allocated to the given size and optional make
this buffer fixed-length.
- Buffer(Buffer) - Constructor for class reactor.io.buffer.Buffer
-
Copy constructor that creates a shallow copy of the given Buffer by calling ByteBuffer.duplicate()
on the underlying ByteBuffer
.
- Buffer(ByteBuffer) - Constructor for class reactor.io.buffer.Buffer
-
Create a Buffer using the given ByteBuffer
as the inital source.
- Buffer.View - Class in reactor.io.buffer
-
A View represents a segment of a buffer.
- BufferCodec<IN,OUT> - Class in reactor.io.codec
-
Implementations of a BufferCodec are codec manipulating Buffer sources
- BufferCodec() - Constructor for class reactor.io.codec.BufferCodec
-
Create a new Codec set with a \0 delimiter to finish any Buffer encoded value or scan for delimited decoded
Buffers.
- BufferCodec(Byte) - Constructor for class reactor.io.codec.BufferCodec
-
A delimiter can be used to trail any decoded buffer or to finalize encoding from any incoming value
- BusySpinWait() - Constructor for class reactor.fn.timer.HashWheelTimer.BusySpinWait
-
- BYTE_ARRAY_CODEC - Static variable in class reactor.io.codec.StandardCodecs
-
- ByteArrayCodec - Class in reactor.io.codec
-
A simple
Codec
implementation that turns a
Buffer
into a
byte[]
and
visa-versa.
- ByteArrayCodec() - Constructor for class reactor.io.codec.ByteArrayCodec
-
- byteBuffer() - Method in class reactor.io.buffer.Buffer
-
Return the underlying ByteBuffer
.
- cachedDispatcher() - Static method in class reactor.Environment
-
Obtain a cached dispatcher out of this#PROCESSORS
maximum pooled.
- cachedDispatchers(String) - Static method in class reactor.Environment
-
Obtain a dispatcher supplier into the context environment.
- cachedDispatchers() - Static method in class reactor.Environment
-
Obtain the default dispatcher supplier from the context environment.
- cachedDispatchers(String, DispatcherSupplier) - Static method in class reactor.Environment
-
Register a dispatcher supplier into the context environment.
- calm() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- calm() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- calm() - Method in interface reactor.core.dispatch.wait.WaitingMood
-
Turn the mood into eco CPU demand mode to save resources from the underlying component.
- calm() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- cancel() - Method in class reactor.core.reactivestreams.SerializedSubscriber
-
- cancel() - Method in class reactor.core.reactivestreams.SubscriberBarrier
-
- cancel() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
-
- cancel() - Method in interface reactor.fn.Pausable
-
Cancel this Pausable.
- cancel() - Method in class reactor.fn.timer.HashWheelTimer
-
Cancel current Timer
- cancel() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Cancel the registration
- cancel() - Method in interface reactor.fn.timer.Timer
-
Cancel this timer by interrupting the task thread.
- cancelAfterUse() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- CancelException - Exception in reactor.core.processor
-
An exception signal from downstream subscribers consuming data when their state is denying any additional event.
- capacity() - Method in class reactor.io.buffer.Buffer
-
Provides the current capacity of the internal ByteBuffer
.
- chain(Consumer<T>...) - Static method in class reactor.fn.Functions
-
Deprecated.
- checkResolution(long, long) - Static method in class reactor.fn.timer.TimeUtils
-
- ChronicleQueuePersistor<T> - Class in reactor.io.queue
-
- ChronicleQueuePersistor(String) - Constructor for class reactor.io.queue.ChronicleQueuePersistor
-
- ChronicleQueuePersistor(String, Codec<Buffer, T, T>, boolean, boolean, ChronicleQueueBuilder) - Constructor for class reactor.io.queue.ChronicleQueuePersistor
-
- clear() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- clear() - Method in class reactor.io.buffer.Buffer
-
Clear the internal ByteBuffer
by setting the Buffer.position(int)
to 0 and the limit to the
current capacity.
- clearMaybe() - Method in class reactor.core.queue.internal.MpscLinkedQueueNode
-
Sets the element this node contains to null
so that the node can be used as a tombstone.
- clearOnStart(boolean) - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- close() - Method in class reactor.Environment
-
- close() - Method in class reactor.io.buffer.Buffer
-
- close() - Method in class reactor.io.IO.FileContext
-
- close() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
Close the underlying chronicles.
- close() - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- close() - Method in class reactor.io.queue.PersistentQueue
-
- close() - Method in interface reactor.io.queue.QueuePersistor
-
Release any internal resources used by the persistence mechanism.
- Codec<SRC,IN,OUT> - Class in reactor.io.codec
-
Implementations of a Codec are responsible for decoding a
SRC
into an
instance of
IN
and passing that to the given
Consumer
.
- Codec() - Constructor for class reactor.io.codec.Codec
-
Create a new Codec set with a \0 delimiter to finish any Buffer encoded value or scan for delimited decoded
Buffers.
- Codec(Byte) - Constructor for class reactor.io.codec.Codec
-
A delimiter can be used to trail any decoded buffer or to finalize encoding from any incoming value
- codec() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- codec(Codec<Buffer, T, T>) - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- collect(List<Supplier<T>>) - Static method in class reactor.fn.Suppliers
-
Deprecated.
Create a
Supplier
that aggregates the given list of suppliers by calling each one, in
turn, until the supplier returns
null
.
- compact() - Method in class reactor.io.buffer.Buffer
-
Compact the underlying ByteBuffer
.
- compareTo(Object) - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- compareTo(Buffer) - Method in class reactor.io.buffer.Buffer
-
- CompletableBlockingQueue<T> - Class in reactor.core.queue
-
A LinkedQueue that supports a terminal state.
- CompletableBlockingQueue(int) - Constructor for class reactor.core.queue.CompletableBlockingQueue
-
- CompletableLinkedQueue<T> - Class in reactor.core.queue
-
A LinkedQueue that supports a terminal state.
- CompletableLinkedQueue() - Constructor for class reactor.core.queue.CompletableLinkedQueue
-
- CompletableQueue<T> - Interface in reactor.core.queue
-
Deprecated.
- complete() - Method in class reactor.core.queue.CompletableBlockingQueue
-
- complete() - Method in class reactor.core.queue.CompletableLinkedQueue
-
- complete() - Method in interface reactor.core.queue.CompletableQueue
-
Deprecated.
Mark this queue as complete
- complete() - Method in class reactor.io.queue.PersistentQueue
-
- CompressionCodec<IN,OUT> - Class in reactor.io.codec.compress
-
- CompressionCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.CompressionCodec
-
- ConfigurationReader - Interface in reactor.core.config
-
A ConfigurationReader
is used to read Reactor configuration.
- Consumer<T> - Interface in reactor.fn
-
Implementations accept a given value and perform work on the argument.
- consumer(Runnable) - Static method in class reactor.fn.Functions
-
Deprecated.
Wrap the given
Runnable
and compose a new
Consumer
.
- contains(Object) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- containsAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- context - Variable in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- context - Variable in class reactor.core.reactivestreams.SubscriberWithContext
-
- context() - Method in class reactor.core.reactivestreams.SubscriberWithContext
-
The stateful context C
- context - Variable in class reactor.core.reactivestreams.SubscriptionWithContext
-
- context() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
-
The stateful context C
- copy() - Method in class reactor.io.buffer.Buffer
-
Create a new Buffer
by copying the underlying ByteBuffer
into a newly-allocated Buffer
.
- create() - Static method in class reactor.core.processor.RingBufferProcessor
-
- create(boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
- create(ExecutorService) - Static method in class reactor.core.processor.RingBufferProcessor
-
- create(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
- create(String, int) - Static method in class reactor.core.processor.RingBufferProcessor
-
- create(String, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using the blockingWait Strategy, passed backlog size,
and auto-cancel settings.
- create(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy
and will auto-cancel.
- create(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy
and the auto-cancel argument.
- create(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and will auto-cancel.
- create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and auto-cancel settings.
- create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and will auto-cancel.
- create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and auto-cancel settings.
- create() - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- create(boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- create(ExecutorService) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- create(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- create(String, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- create(String, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and the passed auto-cancel setting.
- create(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- create(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- create(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- create(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel settings.
- create(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size and blockingWait Strategy settings
but will auto-cancel.
- create(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, wait strategy
and auto-cancel settings.
- create(String) - Static method in class reactor.core.processor.util.SingleUseExecutor
-
- create() - Static method in class reactor.core.queue.internal.MpscLinkedQueue
-
Create a new Queue
which is safe to use for multiple producers (different threads) and a single
consumer (one thread!).
- create(BiConsumer<Long, SubscriberWithContext<T, Void>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Create a
Publisher
reacting on requests with the passed
BiConsumer
- create(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Create a
Publisher
reacting on requests with the passed
BiConsumer
The argument
contextFactory
is executed once by new subscriber to generate a context shared by every
request calls.
- create(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>, Consumer<C>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Create a
Publisher
reacting on requests with the passed
BiConsumer
.
- create(Subscriber<? super T>) - Static method in class reactor.core.reactivestreams.SerializedSubscriber
-
- create(Consumer<Subscription>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
-
Create a
Subscriber
reacting onSubscribe with the passed
Consumer
- create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
-
Create a Subscriber
reacting onSubscribe and onNext, eventually sharing a context.
- create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>, BiConsumer<Throwable, C>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
-
Create a Subscriber
reacting onNext, onError.
- create(Function<Subscription, C>, BiConsumer<T, SubscriptionWithContext<C>>, BiConsumer<Throwable, C>, Consumer<C>) - Static method in class reactor.core.reactivestreams.SubscriberFactory
-
Create a
Subscriber
reacting onNext, onSubscribe, onError, onComplete with the passed
BiConsumer
.
- create(Subscriber<? super T>, C) - Static method in class reactor.core.reactivestreams.SubscriberWithContext
-
Attach a given arbitrary context (stateful information) to a Subscriber
, all Subscriber methods
will delegate properly.
- create(Subscription, C) - Static method in class reactor.core.reactivestreams.SubscriptionWithContext
-
Attach a given arbitrary context (stateful information) to a Subscription
, all Subscription methods
will delegate properly.
- create(Throwable) - Static method in exception reactor.core.support.ReactorFatalException
-
- create() - Static method in class reactor.core.support.UUIDUtils
-
Create a new time-based UUID.
- createDispatcherFactory(String, int, int, Consumer<Throwable>, ProducerType, WaitStrategy) - Static method in class reactor.Environment
-
Create a RingBuffer pool that will clone up to generated dispatcher and return a different one
on a round robin fashion each time
Supplier.get()
is called.
- createInputStream(InputStream) - Method in class reactor.io.codec.compress.CompressionCodec
-
- createInputStream(InputStream) - Method in class reactor.io.codec.compress.GzipCodec
-
- createInputStream(InputStream) - Method in class reactor.io.codec.compress.SnappyCodec
-
- createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.CompressionCodec
-
- createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.GzipCodec
-
- createOutputStream(OutputStream) - Method in class reactor.io.codec.compress.SnappyCodec
-
- createView() - Method in class reactor.io.buffer.Buffer
-
- createView(int, int) - Method in class reactor.io.buffer.Buffer
-
Create a
Buffer.View
of the given range of this Buffer.
- current() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- get() - Static method in exception reactor.core.processor.CancelException
-
- get() - Static method in exception reactor.core.processor.InsufficientCapacityException
-
- get() - Static method in class reactor.Environment
-
Read the context environment.
- get() - Method in interface reactor.fn.Supplier
-
Get an object.
- get() - Method in class reactor.fn.support.Tap
-
Get the value of this Tap
, which is the current value of the event stream this
tap is consuming.
- get(int) - Method in class reactor.fn.tuple.Tuple
-
Get the object at the given index.
- get(int) - Method in class reactor.fn.tuple.Tuple1
-
- get(int) - Method in class reactor.fn.tuple.Tuple2
-
- get(int) - Method in class reactor.fn.tuple.Tuple3
-
- get(int) - Method in class reactor.fn.tuple.Tuple4
-
- get(int) - Method in class reactor.fn.tuple.Tuple5
-
- get(int) - Method in class reactor.fn.tuple.Tuple6
-
- get(int) - Method in class reactor.fn.tuple.Tuple7
-
- get(int) - Method in class reactor.fn.tuple.Tuple8
-
- get(int) - Method in class reactor.fn.tuple.TupleN
-
- get() - Method in class reactor.io.buffer.Buffer.View
-
- get(Long) - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- get(Long) - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- get(Long) - Method in interface reactor.io.queue.QueuePersistor
-
Return the item with the given id.
- get() - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- getAdditionalProperties() - Method in class reactor.core.config.ReactorConfiguration
-
Additional configuration properties.
- getAvailableCapacity() - Method in class reactor.core.processor.ReactorProcessor
-
- getAvailableCapacity() - Method in class reactor.core.processor.RingBufferProcessor
-
- getAvailableCapacity() - Method in class reactor.core.processor.RingBufferWorkProcessor
-
- getBacklog() - Method in class reactor.core.config.DispatcherConfiguration
-
Returns the configured backlog, or null
if the backlog was not configured
- getCachedDispatcher() - Method in class reactor.Environment
-
Returns a default cached dispatcher for this environment.
- getCachedDispatchers() - Method in class reactor.Environment
-
Returns the default dispatcher group for this environment.
- getCachedDispatchers(String) - Method in class reactor.Environment
-
Returns the dispatcher factory with the given name
.
- getCapacity() - Method in class reactor.core.processor.ReactorProcessor
-
- getCapacity() - Method in class reactor.core.processor.RingBufferProcessor
-
- getCapacity() - Method in class reactor.core.processor.RingBufferWorkProcessor
-
- getCapacity() - Method in class reactor.core.reactivestreams.SerializedSubscriber
-
- getCapacity() - Method in class reactor.core.reactivestreams.SubscriberBarrier
-
- getCapacity() - Method in interface reactor.core.support.NonBlocking
-
Return defined element capacity, used to drive new Subscription
request needs.
- getContext() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- getData() - Method in class reactor.io.codec.Frame
-
- getDefaultDispatcher() - Method in class reactor.Environment
-
Returns the default dispatcher for this environment.
- getDefaultDispatcherName() - Method in class reactor.core.config.ReactorConfiguration
-
Returns the name of the default dispatcher.
- getDispatcher(String) - Method in class reactor.Environment
-
Returns the dispatcher with the given name
.
- getDispatcherConfigurations() - Method in class reactor.core.config.ReactorConfiguration
-
- getEnd() - Method in class reactor.io.buffer.Buffer.View
-
Get the end of this range.
- getEngine() - Method in class reactor.io.codec.SerializationCodec
-
- getFinalCause(Throwable) - Static method in class reactor.core.support.Exceptions
-
Get the Throwable
at the end of the causality-chain for a particular Throwable
- getFinalValueCause(Throwable) - Static method in class reactor.core.support.Exceptions
-
Try to find the last value at the end of the causality-chain for a particular
Throwable
If the final cause wasn't of type
Exceptions.ValueCause
,
return null;
- getIntProperty(String, int) - Method in class reactor.Environment
-
Gets the property with the given key
, converting it to an integer.
- getLongProperty(String, long) - Method in class reactor.Environment
-
Gets the property with the given key
, converting it to a long.
- getName() - Method in class reactor.core.config.DispatcherConfiguration
-
Returns the name of the Dispatcher.
- getOffset() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- getPrefix() - Method in class reactor.io.codec.Frame
-
- getProperty(String, String) - Method in class reactor.Environment
-
Gets the property with the given key
.
- getResolution() - Method in class reactor.fn.timer.HashWheelTimer
-
- getResolution() - Method in interface reactor.fn.timer.Timer
-
Get the resolution of this tTimer.
- getSize() - Method in class reactor.core.config.DispatcherConfiguration
-
Returns the configured size, or null
if the size was not configured
- getStart() - Method in class reactor.io.buffer.Buffer.View
-
Get the start of this range.
- getT1() - Method in class reactor.fn.tuple.Tuple1
-
Type-safe way to get the first object of this
Tuple
.
- getT1() - Method in class reactor.fn.tuple.TupleN
-
- getT2() - Method in class reactor.fn.tuple.Tuple2
-
Type-safe way to get the second object of this
Tuple
.
- getT2() - Method in class reactor.fn.tuple.TupleN
-
- getT3() - Method in class reactor.fn.tuple.Tuple3
-
Type-safe way to get the third object of this
Tuple
.
- getT3() - Method in class reactor.fn.tuple.TupleN
-
- getT4() - Method in class reactor.fn.tuple.Tuple4
-
Type-safe way to get the fourth object of this
Tuple
.
- getT4() - Method in class reactor.fn.tuple.TupleN
-
- getT5() - Method in class reactor.fn.tuple.Tuple5
-
Type-safe way to get the fifth object of this
Tuple
.
- getT5() - Method in class reactor.fn.tuple.TupleN
-
- getT6() - Method in class reactor.fn.tuple.Tuple6
-
Type-safe way to get the sixth object of this
Tuple
.
- getT6() - Method in class reactor.fn.tuple.TupleN
-
- getT7() - Method in class reactor.fn.tuple.Tuple7
-
Type-safe way to get the seventh object of this
Tuple
.
- getT7() - Method in class reactor.fn.tuple.TupleN
-
- getT8() - Method in class reactor.fn.tuple.Tuple8
-
Type-safe way to get the eighth object of this
Tuple
.
- getT8() - Method in class reactor.fn.tuple.TupleN
-
- getTailRecursionPileSize() - Method in class reactor.core.dispatch.SingleThreadDispatcher
-
- getTimer() - Method in class reactor.Environment
-
- getTimer() - Static method in class reactor.fn.timer.TimeUtils
-
- getType() - Method in class reactor.core.config.DispatcherConfiguration
-
Returns the type of the Dispatcher.
- getValue() - Method in exception reactor.core.support.Exceptions.ValueCause
-
Retrieve the item that the component was trying to emit at the time this exception occurred.
- GzipCodec<IN,OUT> - Class in reactor.io.codec.compress
-
- GzipCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.GzipCodec
-
- inContext() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
Dispatchers can be traced through a contextClassLoader
to let producers adapting their dispatching
strategy
- inContext() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- inContext() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- inContext() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- inContext() - Method in interface reactor.core.Dispatcher
-
A dispatcher context can be bound to the thread(s) it runs on.
- incrementSubscribers() - Method in class reactor.core.processor.ReactorProcessor
-
- indexBlockSize(int) - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- indexOf(byte) - Method in class reactor.io.buffer.Buffer
-
Search the buffer and find the position of the first occurrence of the given byte
.
- indexOf(byte, int, int) - Method in class reactor.io.buffer.Buffer
-
Search the buffer and find the position of the first occurrence of the given byte
staring at the start
position and searching until (and including) the end position.
- initialize() - Static method in class reactor.Environment
-
Create and assign a context environment bound to the current classloader.
- initialize(Consumer<Throwable>) - Static method in class reactor.Environment
-
Create and assign a context environment bound to the current classloader.
- initializeIfEmpty() - Static method in class reactor.Environment
-
Create and assign a context environment bound to the current classloader only if it not already set.
- InMemoryQueuePersistor<T> - Class in reactor.io.queue
-
- InMemoryQueuePersistor() - Constructor for class reactor.io.queue.InMemoryQueuePersistor
-
- inputStream() - Method in class reactor.io.buffer.Buffer
-
Create an InputStream
capable of reading the bytes from the internal ByteBuffer
.
- INSTANCE - Static variable in class reactor.core.dispatch.SynchronousDispatcher
-
- INSTANCE - Static variable in class reactor.core.dispatch.TailRecurseDispatcher
-
- INSTANCE - Static variable in exception reactor.core.processor.CancelException
-
- INSTANCE - Static variable in exception reactor.core.reactivestreams.PublisherFactory.PrematureCompleteException
-
- INSTANCE - Static variable in exception reactor.core.support.ReactorFatalException
-
- instance() - Static method in exception reactor.core.support.ReactorFatalException
-
- InsufficientCapacityException - Exception in reactor.core.processor
-
Exception thrown when the it is not possible to dispatch a signal a
Dispatcher
.
- intercept(Publisher<? extends I>, Function<Subscriber<? super O>, SubscriberBarrier<I, O>>) - Static method in class reactor.core.reactivestreams.PublisherFactory
-
Create a
Publisher
intercepting all source signals with a
SubscriberBarrier
per Subscriber
provided by the given barrierProvider.
- invokeAll(Collection<? extends Callable<T>>) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- invokeAny(Collection<? extends Callable<T>>) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- invokeCallbackOrReturn(Consumer<IN>, IN) - Static method in class reactor.io.codec.Codec
-
- IO - Class in reactor.io
-
A factory for Reactive basic IO operations such as File read/write, Byte read and Codec decoding.
- IO.FileContext - Class in reactor.io
-
A read access to the source file
- isAssignable(Class<?>, Class<?>, String) - Static method in class reactor.core.support.Assert
-
Assert that superType.isAssignableFrom(subType)
is true
.
- isCancelAfterUse() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- isCancelled() - Method in class reactor.core.reactivestreams.SubscriberWithContext
-
- isCancelled() - Method in class reactor.core.reactivestreams.SubscriptionWithContext
-
- isCancelled() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Check whether the current Registration is cancelled
- isComplete() - Method in class reactor.core.queue.CompletableBlockingQueue
-
- isComplete() - Method in class reactor.core.queue.CompletableLinkedQueue
-
- isComplete() - Method in interface reactor.core.queue.CompletableQueue
-
Deprecated.
Get the number of items persisted right now.
- isComplete() - Method in class reactor.io.queue.PersistentQueue
-
- isDelimitingBuffer() - Method in class reactor.io.buffer.Buffer
-
Is this instance a delimiting Buffer
- isDynamic() - Method in class reactor.io.buffer.Buffer
-
Whether this Buffer is fixed-length or not.
- isEmpty() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- isInstanceOf(Class<?>, Object, String) - Static method in class reactor.core.support.Assert
-
Assert that the provided object is an instance of the provided class.
- isNull(Object, String) - Static method in class reactor.core.support.Assert
-
Assert that an object is null
.
- isOpen() - Method in class reactor.io.buffer.Buffer
-
- isOpen() - Method in class reactor.io.IO.FileContext
-
- isPaused() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Check whether the current Registration is paused
- isReactivePull(Dispatcher, long) - Method in class reactor.core.processor.ReactorProcessor
-
- isReactivePull(Dispatcher, long) - Method in class reactor.core.reactivestreams.SerializedSubscriber
-
- isReactivePull(Dispatcher, long) - Method in class reactor.core.reactivestreams.SubscriberBarrier
-
- isReactivePull(Dispatcher, long) - Method in interface reactor.core.support.NonBlocking
-
- isShutdown() - Method in class reactor.core.processor.util.SingleUseExecutor
-
- isTerminated() - Method in class reactor.core.processor.util.SingleUseExecutor
-
- isTrue(boolean, String) - Static method in class reactor.core.support.Assert
-
Assert a boolean expression, throwing IllegalArgumentException
if the test result is false
.
- isTrue(boolean) - Static method in class reactor.core.support.Assert
-
Assert a boolean expression, throwing IllegalArgumentException
if the test result is false
.
- iterator() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- iterator() - Method in class reactor.Environment
-
- iterator() - Method in class reactor.fn.tuple.Tuple
-
- iterator() - Method in class reactor.fn.tuple.Tuple1
-
- iterator() - Method in class reactor.fn.tuple.Tuple2
-
- iterator() - Method in class reactor.fn.tuple.Tuple3
-
- iterator() - Method in class reactor.fn.tuple.Tuple4
-
- iterator() - Method in class reactor.fn.tuple.Tuple5
-
- iterator() - Method in class reactor.fn.tuple.Tuple6
-
- iterator() - Method in class reactor.fn.tuple.Tuple7
-
- iterator() - Method in class reactor.fn.tuple.Tuple8
-
- iterator() - Method in class reactor.fn.tuple.TupleN
-
- iterator() - Method in class reactor.io.buffer.Buffer
-
- iterator() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- iterator() - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- iterator() - Method in class reactor.io.queue.PersistentQueue
-
- NamedDaemonThreadFactory - Class in reactor.core.support
-
A thread factory that creates named daemon threads.
- NamedDaemonThreadFactory(String) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
-
Creates a new thread factory that will name its threads <prefix>-<n>, where
<prefix> is the given prefix
and <n> is the count of threads
created thus far by this class.
- NamedDaemonThreadFactory(String, ClassLoader) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
-
Creates a new thread factory that will name its threads <prefix>-<n>, where
<prefix> is the given prefix
and <n> is the count of threads
created thus far by this class.
- NamedDaemonThreadFactory(String, ClassLoader, Thread.UncaughtExceptionHandler, boolean) - Constructor for class reactor.core.support.NamedDaemonThreadFactory
-
- negate(Predicate<? super T>) - Static method in class reactor.fn.Predicates
-
Deprecated.
Returns a Predicate which negates the given Predicate.
- nervous() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- nervous() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- nervous() - Method in interface reactor.core.dispatch.wait.WaitingMood
-
Turn the mood into aggressive CPU demand mode to effectively give an an additional resources boost to the underlying
component.
- nervous() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- never() - Static method in class reactor.fn.Predicates
-
Deprecated.
Returns a Predicate which always evaluates to false.
- newAtomicReferenceFieldUpdater(Class<U>, String) - Static method in class reactor.core.internal.PlatformDependent
-
- newCachedDispatchers(int) - Static method in class reactor.Environment
-
- newCachedDispatchers(int, String) - Static method in class reactor.Environment
-
- newDispatcher() - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(int) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(String, int) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(int, int) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(String, int, int) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(int, int, DispatcherType) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcher(String, int, int, DispatcherType) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcherLike(String) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newDispatcherLike(String, String) - Static method in class reactor.Environment
-
Register a dispatcher into the context environment.
- newFanOutCachedDispatchers(int, String) - Static method in class reactor.Environment
-
- newThread(Runnable) - Method in class reactor.core.support.NamedDaemonThreadFactory
-
- NonBlocking - Interface in reactor.core.support
-
A dispatcher aware component
- notEmpty(Object[], String) - Static method in class reactor.core.support.Assert
-
Assert that an array has elements; that is, it must not be null
and must have at least one element.
- notNull(Object, String) - Static method in class reactor.core.support.Assert
-
Assert that an object is not null
.
- notNull(Object) - Static method in class reactor.core.support.Assert
-
Assert that an object is not null
.
- pairFrom(Function<Tuple2<LEFT, RIGHT>, V>) - Static method in class reactor.fn.Functions
-
Deprecated.
Wrap a given
Function
that applies transformation to a Tuple2 into a PairFunction.
- ParkWaitStrategy - Class in reactor.core.dispatch.wait
-
- ParkWaitStrategy() - Constructor for class reactor.core.dispatch.wait.ParkWaitStrategy
-
- ParkWaitStrategy(long) - Constructor for class reactor.core.dispatch.wait.ParkWaitStrategy
-
- parseInt(Buffer, int, int) - Static method in class reactor.io.buffer.Buffer
-
Very efficient method for parsing an Integer
from the given Buffer range.
- parseInt(Buffer) - Static method in class reactor.io.buffer.Buffer
-
Very efficient method for parsing an Integer
from the given Buffer.
- parseLong(Buffer, int, int) - Static method in class reactor.io.buffer.Buffer
-
Very efficient method for parsing a Long
from the given Buffer range.
- parseLong(Buffer) - Static method in class reactor.io.buffer.Buffer
-
Very efficient method for parsing a Long
from the given Buffer.
- PASS_THROUGH_CODEC - Static variable in class reactor.io.codec.StandardCodecs
-
- PassThroughCodec<SRC> - Class in reactor.io.codec
-
A simple Codec
that uses the source object as both input and output.
- PassThroughCodec() - Constructor for class reactor.io.codec.PassThroughCodec
-
- Pausable - Interface in reactor.fn
-
- pause() - Method in interface reactor.fn.Pausable
-
Pause this Pausable.
- pause() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Pause the current Regisration
- peek() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- peek() - Method in class reactor.io.queue.PersistentQueue
-
- PENDING_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriptionWithContext
-
- PersistentQueue<T> - Class in reactor.io.queue
-
A PersistentQueue is a
Queue
implementation that delegates the actual storage of the
elements in the queue to a
QueuePersistor
.
- PersistentQueue(QueuePersistor<T>) - Constructor for class reactor.io.queue.PersistentQueue
-
- PersistentQueueSpec<T> - Class in reactor.io.queue.spec
-
- PersistentQueueSpec() - Constructor for class reactor.io.queue.spec.PersistentQueueSpec
-
- PlatformDependent - Class in reactor.core.internal
-
Borrowed from Netty project which itself borrows from JCTools and various other projects.
- PlatformDependent() - Constructor for class reactor.core.internal.PlatformDependent
-
- poll() - Method in class reactor.core.queue.CompletableBlockingQueue
-
- poll(long, TimeUnit) - Method in class reactor.core.queue.CompletableBlockingQueue
-
- poll() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- poll() - Method in class reactor.io.queue.PersistentQueue
-
- poolSize() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- position() - Method in class reactor.io.buffer.Buffer
-
Provides the current position in the internal ByteBuffer
.
- position(int) - Method in class reactor.io.buffer.Buffer
-
Sets this buffer's position.
- Predicate<T> - Interface in reactor.fn
-
Determines if the input object matches some criteria.
- Predicates - Class in reactor.fn
-
Deprecated.
- Predicates() - Constructor for class reactor.fn.Predicates
-
Deprecated.
- prepend(Buffer) - Method in class reactor.io.buffer.Buffer
-
Prepend the given
Buffer
to this Buffer.
- prepend(String) - Method in class reactor.io.buffer.Buffer
-
Prepend the given String
to this Buffer.
- prepend(byte[]) - Method in class reactor.io.buffer.Buffer
-
Prepend the given byte[]
array to this Buffer.
- prepend(ByteBuffer) - Method in class reactor.io.buffer.Buffer
-
Prepend the given ByteBuffer
to this Buffer.
- prepend(byte) - Method in class reactor.io.buffer.Buffer
-
Prepend the given byte
to this Buffer.
- prepend(char) - Method in class reactor.io.buffer.Buffer
-
Prepend the given char
to this existing Buffer.
- prepend(short) - Method in class reactor.io.buffer.Buffer
-
Prepend the given short
to this Buffer.
- prepend(int) - Method in class reactor.io.buffer.Buffer
-
Prepend the given int
to this Buffer.
- prepend(long) - Method in class reactor.io.buffer.Buffer
-
Prepend the given long
to this Buffer.
- PROCESSORS - Static variable in class reactor.Environment
-
The number of processors available to the runtime
- PropertiesConfigurationReader - Class in reactor.core.config
-
A
ConfigurationReader
that reads the configuration from properties files
and System properties.
- PropertiesConfigurationReader() - Constructor for class reactor.core.config.PropertiesConfigurationReader
-
Creates a new PropertiesConfigurationReader
that, by default, will load its
configuration from META-INF/reactor/default.properties
.
- PropertiesConfigurationReader(String) - Constructor for class reactor.core.config.PropertiesConfigurationReader
-
- ProtobufCodec<IN,OUT> - Class in reactor.io.codec.protobuf
-
- ProtobufCodec() - Constructor for class reactor.io.codec.protobuf.ProtobufCodec
-
- ProtobufCodec(boolean) - Constructor for class reactor.io.codec.protobuf.ProtobufCodec
-
- PublisherFactory - Class in reactor.core.reactivestreams
-
A Reactive Streams Publisher
factory which callbacks on start, request and shutdown
- PublisherFactory() - Constructor for class reactor.core.reactivestreams.PublisherFactory
-
- PublisherFactory.PrematureCompleteException - Exception in reactor.core.reactivestreams
-
- random() - Static method in class reactor.core.support.UUIDUtils
-
Create a new random UUID.
- reactor - package reactor
-
- reactor.core - package reactor.core
-
Core components of the Reactor framework.
- reactor.core.config - package reactor.core.config
-
Components to facilitate flexible configuration of the Reactor
Environment
.
- reactor.core.dispatch - package reactor.core.dispatch
-
Dispatchers
provide a way for work to be done in another thread,
but unlike a standard thread pool, do so with extreme efficiency.
- reactor.core.dispatch.wait - package reactor.core.dispatch.wait
-
- reactor.core.internal - package reactor.core.internal
-
Core components of the Reactor framework.
- reactor.core.processor - package reactor.core.processor
-
This package offers a suite of asynchronous Processor
with backpressure support.
- reactor.core.processor.util - package reactor.core.processor.util
-
- reactor.core.queue - package reactor.core.queue
-
Queue
implementations that provide completable states or lock-free queue
- reactor.core.queue.internal - package reactor.core.queue.internal
-
- reactor.core.reactivestreams - package reactor.core.reactivestreams
-
- reactor.core.support - package reactor.core.support
-
- reactor.fn - package reactor.fn
-
This package contains the foundational abstractions on which Reactor's functional and reactive components are
built.
- reactor.fn.support - package reactor.fn.support
-
- reactor.fn.timer - package reactor.fn.timer
-
- reactor.fn.tuple - package reactor.fn.tuple
-
Tuples provide a type-safe way to specify multiple parameters.
- reactor.io - package reactor.io
-
Buffer-handling and other IO-related components.
- reactor.io.buffer - package reactor.io.buffer
-
- reactor.io.codec - package reactor.io.codec
-
Components to handle encoding and decoding of objects into
Buffers
.
- reactor.io.codec.compress - package reactor.io.codec.compress
-
- reactor.io.codec.json - package reactor.io.codec.json
-
Encoding and decoding using the JSON format.
- reactor.io.codec.kryo - package reactor.io.codec.kryo
-
- reactor.io.codec.protobuf - package reactor.io.codec.protobuf
-
- reactor.io.queue - package reactor.io.queue
-
Queue
implementations that provide a persistence strategy for making sure items in the Queue
aren't lost.
- reactor.io.queue.spec - package reactor.io.queue.spec
-
Specs provide a simple fluent DSL for creating
PersistentQueues
by
specifying common options.
- ReactorConfiguration - Class in reactor.core.config
-
An encapsulation of configuration for Reactor
- ReactorConfiguration(List<DispatcherConfiguration>, String, Properties) - Constructor for class reactor.core.config.ReactorConfiguration
-
- ReactorFatalException - Exception in reactor.core.support
-
an exception that should stop producing more data
- ReactorProcessor<IN,OUT> - Class in reactor.core.processor
-
A base processor
- ReactorProcessor(boolean) - Constructor for class reactor.core.processor.ReactorProcessor
-
- read() - Method in interface reactor.core.config.ConfigurationReader
-
Reads the configuration
- read() - Method in class reactor.core.config.PropertiesConfigurationReader
-
- read() - Method in class reactor.io.buffer.Buffer
-
Read a single byte
from the underlying ByteBuffer
.
- read(byte[]) - Method in class reactor.io.buffer.Buffer
-
Read at least b.length
bytes from the underlying ByteBuffer
.
- read(ByteBuffer) - Method in class reactor.io.buffer.Buffer
-
- read(ByteBuffer) - Method in class reactor.io.IO.FileContext
-
- read(ReadableByteChannel) - Static method in class reactor.io.IO
-
Transform a
ReadableByteChannel
into a
Publisher
of
Buffer
with a max chunk size of
Buffer.SMALL_BUFFER_SIZE
.
- read(ReadableByteChannel, int) - Static method in class reactor.io.IO
-
Transform a
ReadableByteChannel
into a
Publisher
of
Buffer
with a max chunk size of
chunkSize
.
- readChar() - Method in class reactor.io.buffer.Buffer
-
Read the next char
from the underlying ByteBuffer
.
- readDouble() - Method in class reactor.io.buffer.Buffer
-
Read the next double
from the underlying ByteBuffer
.
- reader() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- readFile(Path) - Static method in class reactor.io.IO
-
Read bytes as
Buffer
from file specified by the
Path
argument with a max chunk size of
Buffer.SMALL_BUFFER_SIZE
.
- readFile(Path, int) - Static method in class reactor.io.IO
-
Read bytes as
Buffer
from file specified by the
Path
argument with a max
chunkSize
Complete when channel read is negative.
- readFile(String) - Static method in class reactor.io.IO
-
Read bytes as
Buffer
from file specified by the
Path
argument with a max chunk size of
Buffer.SMALL_BUFFER_SIZE
.
- readFile(String, int) - Static method in class reactor.io.IO
-
Read bytes as
Buffer
from file specified by the
Path
argument with a max
chunkSize
Complete when channel read is negative.
- readFloat() - Method in class reactor.io.buffer.Buffer
-
Read the next float
from the underlying ByteBuffer
.
- readInt() - Method in class reactor.io.buffer.Buffer
-
Read the next int
from the underlying ByteBuffer
.
- readLong() - Method in class reactor.io.buffer.Buffer
-
Read the next long
from the underlying ByteBuffer
.
- readShort() - Method in class reactor.io.buffer.Buffer
-
Read the next short
from the underlying ByteBuffer
.
- readType(Buffer) - Method in class reactor.io.codec.SerializationCodec
-
- ready() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Check whether the current Registration is ready for execution
- Recyclable - Interface in reactor.core.support
-
A simple interface that marks an object as being recyclable.
- recycle() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
-
- recycle() - Method in interface reactor.core.support.Recyclable
-
Free any internal resources and reset the state of the object to enable reuse.
- recycle() - Method in class reactor.io.buffer.Buffer
-
- refMap() - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- remaining() - Method in class reactor.io.buffer.Buffer
-
How many bytes available in this Buffer.
- remainingSlots() - Method in class reactor.core.dispatch.MpscDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- remainingSlots() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- remainingSlots() - Method in interface reactor.core.Dispatcher
-
Request the remaining capacity for the underlying shared state structure.
- remove() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- remove(Object) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- remove() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- remove() - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- remove() - Method in interface reactor.io.queue.QueuePersistor
-
Remove the oldest item from the persistence queue.
- removeAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- removeCachedDispatchers(String) - Method in class reactor.Environment
-
Remove the dispatcherFactory
to the environment keyed as the given name
.
- removeDispatcher(String) - Method in class reactor.Environment
-
Removes the Dispatcher, stored using the given name
from the environment.
- request(long) - Method in class reactor.core.reactivestreams.SerializedSubscriber
-
- request(long) - Method in class reactor.core.reactivestreams.SubscriberBarrier
-
- request(long) - Method in class reactor.core.reactivestreams.SubscriptionWithContext
-
- reset() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Reset the Registration
- reset() - Method in class reactor.io.buffer.Buffer
-
Reset the buffer to the previously-saved position and limit.
- Resource - Interface in reactor.fn
-
A Resource is a component with an active state, generally consuming hardware capacities (memory, cpu, io).
- resume() - Method in interface reactor.fn.Pausable
-
Unpause this Pausable.
- resume() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Resume current Registration
- retainAll(Collection<?>) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- rewind() - Method in class reactor.io.buffer.Buffer
-
Rewind this Buffer to the beginning.
- rewind(int) - Method in class reactor.io.buffer.Buffer
-
Rewinds this buffer by len
bytes.
- RingBufferDispatcher - Class in reactor.core.dispatch
-
Implementation of a
Dispatcher
that uses a
RingBuffer
to queue tasks to execute.
- RingBufferDispatcher(String) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
-
Creates a new RingBufferDispatcher
with the given name
.
- RingBufferDispatcher(String, int) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
-
Creates a new RingBufferDispatcher
with the given name
and ,
configured with a producer type of MULTI
and a blocking
wait
strategy
.
- RingBufferDispatcher(String, int, Consumer<Throwable>) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
-
Creates a new RingBufferDispatcher with the given name
.
- RingBufferDispatcher(String, int, Consumer<Throwable>, ProducerType, WaitStrategy) - Constructor for class reactor.core.dispatch.RingBufferDispatcher
-
Creates a new RingBufferDispatcher with the given name
.
- RingBufferProcessor<E> - Class in reactor.core.processor
-
An implementation of a RingBuffer backed message-passing Processor.
- RingBufferSubscriberUtils - Class in reactor.core.processor.util
-
Utility methods to perform common tasks associated with Subscriber
handling when the
signals are stored in a com.lmax.disruptor.RingBuffer
.
- RingBufferWorkProcessor<E> - Class in reactor.core.processor
-
An implementation of a RingBuffer backed message-passing WorkProcessor.
- roundRobin(T...) - Static method in class reactor.fn.Suppliers
-
Deprecated.
Create a
Supplier
that continually round-robin load balances each call to
Supplier.get()
by iterating over the objects.
- route(AbstractLifecycleDispatcher.Task) - Static method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- route(MutableSignal<E>, Subscriber<? super E>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
-
- routeError(Throwable) - Method in class reactor.Environment
-
Route any exception to the environment error journal this#errorConsumer
.
- routeOnce(MutableSignal<E>, Subscriber<? super E>) - Static method in class reactor.core.processor.util.RingBufferSubscriberUtils
-
- run() - Method in class reactor.core.dispatch.MultiThreadDispatcher.MultiThreadTask
-
- run() - Method in class reactor.core.dispatch.SingleThreadDispatcher.SingleThreadTask
-
- run() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Run the delegate of the current Registration
- schedule(Consumer<Long>, long, TimeUnit, long) - Method in class reactor.fn.timer.HashWheelTimer
-
- schedule(Consumer<Long>, long, TimeUnit) - Method in class reactor.fn.timer.HashWheelTimer
-
- schedule(Consumer<Long>, long, TimeUnit, long) - Method in interface reactor.fn.timer.Timer
-
Schedule a recurring task.
- schedule(Consumer<Long>, long, TimeUnit) - Method in interface reactor.fn.timer.Timer
-
Schedule a recurring task.
- scheduleLater(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- scheduleLater(AbstractLifecycleDispatcher.Task) - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- SerializationCodec<E,IN,OUT> - Class in reactor.io.codec
-
Abstract base class for Codec Codecs
that perform serialization of objects.
- SerializationCodec(E, boolean) - Constructor for class reactor.io.codec.SerializationCodec
-
Create a SerializationCodec
using the given engine and specifying whether or not to prepend a length field
to frame the message.
- SerializedSubscriber<T> - Class in reactor.core.reactivestreams
-
- serializer(ObjectMapper) - Method in class reactor.io.codec.json.JacksonJsonCodec
-
- serializer(Kryo) - Method in class reactor.io.codec.kryo.KryoCodec
-
- serializer(KryoPool) - Method in class reactor.io.codec.kryo.KryoPoolCodec
-
- serializer(Map<Class<?>, Message>) - Method in class reactor.io.codec.protobuf.ProtobufCodec
-
- serializer(E) - Method in class reactor.io.codec.SerializationCodec
-
- setData(Object) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
-
- setDispatcher(String, Dispatcher) - Method in class reactor.Environment
-
Adds the dispatcher
to the environment, storing it using the given name
.
- setErrorConsumer(Consumer<Throwable>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
-
- setEventConsumer(Consumer<?>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
-
- setTimer(Timer) - Static method in class reactor.fn.timer.TimeUtils
-
- share() - Static method in class reactor.core.processor.RingBufferProcessor
-
- share(boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
- share(ExecutorService) - Static method in class reactor.core.processor.RingBufferProcessor
-
- share(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
- share(String, int) - Static method in class reactor.core.processor.RingBufferProcessor
-
- share(String, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using the blockingWait Strategy, passed backlog size,
and auto-cancel settings.
- share(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy
and will auto-cancel.
- share(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, blockingWait Strategy
and the auto-cancel argument.
- share(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and will auto-cancel.
- share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and auto-cancel settings.
- share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and will auto-cancel.
- share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferProcessor
-
Create a new RingBufferProcessor using passed backlog size, wait strategy
and auto-cancel settings.
- share() - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- share(boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- share(ExecutorService) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- share(ExecutorService, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
- share(String, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- share(String, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and the passed auto-cancel setting.
- share(ExecutorService, int) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- share(ExecutorService, int, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- share(String, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel.
- share(String, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, blockingWait Strategy
and auto-cancel settings.
- share(ExecutorService, int, WaitStrategy) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size and blockingWait Strategy settings
but will auto-cancel.
- share(ExecutorService, int, WaitStrategy, boolean) - Static method in class reactor.core.processor.RingBufferWorkProcessor
-
Create a new RingBufferWorkProcessor using the passed buffer size, wait strategy
and auto-cancel settings.
- SHARED - Static variable in class reactor.Environment
-
The name of the default shared dispatcher
- sharedDispatcher() - Static method in class reactor.Environment
-
Obtain the default dispatcher from the current environment.
- shutdown() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.MpscDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- shutdown() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- shutdown() - Method in class reactor.core.processor.ExecutorPoweredProcessor
-
- shutdown() - Method in class reactor.core.processor.util.SingleUseExecutor
-
- shutdown() - Method in class reactor.Environment
-
Shuts down this Environment, causing all of its
Dispatchers
to be shut down.
- shutdown() - Method in interface reactor.fn.Resource
-
Shutdown this active Resource
such that it can no longer be used.
- shutdownNow() - Method in class reactor.core.processor.util.SingleUseExecutor
-
- signalAllWhenBlocking() - Method in class reactor.core.dispatch.wait.AgileWaitingStrategy
-
- signalAllWhenBlocking() - Method in class reactor.core.dispatch.wait.ParkWaitStrategy
-
- SingleThreadDispatcher - Class in reactor.core.dispatch
-
Base Implementation for single-threaded Dispatchers.
- SingleThreadDispatcher(int) - Constructor for class reactor.core.dispatch.SingleThreadDispatcher
-
- SingleThreadDispatcher.SingleThreadTask - Class in reactor.core.dispatch
-
- SingleThreadTask() - Constructor for class reactor.core.dispatch.SingleThreadDispatcher.SingleThreadTask
-
- SingleUseExecutor - Class in reactor.core.processor.util
-
- size() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- size - Variable in class reactor.fn.tuple.Tuple
-
- size() - Method in class reactor.fn.tuple.Tuple
-
Return the number of elements in this Tuple.
- size() - Method in class reactor.io.queue.ChronicleQueuePersistor
-
- size() - Method in class reactor.io.queue.InMemoryQueuePersistor
-
- size() - Method in class reactor.io.queue.PersistentQueue
-
- size() - Method in interface reactor.io.queue.QueuePersistor
-
Get the number of items persisted right now.
- skip(int) - Method in class reactor.io.buffer.Buffer
-
Skips len
bytes.
- SleepWait() - Constructor for class reactor.fn.timer.HashWheelTimer.SleepWait
-
- slice(int, int) - Method in class reactor.io.buffer.Buffer
-
Create a copy of the given range.
- slice(int...) - Method in class reactor.io.buffer.Buffer
-
Slice this buffer at the given positions.
- SMALL_BUFFER_SIZE - Static variable in class reactor.core.processor.ReactorProcessor
-
- SMALL_BUFFER_SIZE - Static variable in class reactor.io.buffer.Buffer
-
The size, in bytes, of a small buffer.
- SnappyCodec<IN,OUT> - Class in reactor.io.codec.compress
-
- SnappyCodec(Codec<Buffer, IN, OUT>) - Constructor for class reactor.io.codec.compress.SnappyCodec
-
- snapshot() - Method in class reactor.io.buffer.Buffer
-
Save the current buffer position and limit.
- spec_2_12_exception() - Static method in class reactor.core.support.SpecificationExceptions
-
- spec_2_13_exception() - Static method in class reactor.core.support.SpecificationExceptions
-
- spec_3_09_exception(long) - Static method in class reactor.core.support.SpecificationExceptions
-
- SpecificationExceptions - Class in reactor.core.support
-
- SpecificationExceptions() - Constructor for class reactor.core.support.SpecificationExceptions
-
- split(int) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter.
- split(List<Buffer.View>, int) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter but save memory by reusing the given List
.
- split(int, boolean) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter and optionally leave the delimiter intact rather than stripping it.
- split(List<Buffer.View>, int, boolean) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter, save memory by reusing the given List
, and optionally leave the
delimiter intact rather than stripping it.
- split(Buffer) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter and leave the delimiter on the end of each segment.
- split(Buffer, boolean) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter.
- split(List<Buffer.View>, Buffer, boolean) - Method in class reactor.io.buffer.Buffer
-
Split this buffer on the given delimiter.
- StandardCodecs - Class in reactor.io.codec
-
A selection of standard codecs.
- start() - Method in class reactor.fn.timer.HashWheelTimer
-
Start the Timer
- state(boolean, String) - Static method in class reactor.core.support.Assert
-
Assert a boolean expression, throwing IllegalStateException
if the test result is false
.
- state(boolean) - Static method in class reactor.core.support.Assert
-
Assert a boolean expression, throwing IllegalStateException
if the test result is false
.
- STATUS_CANCELLED - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- STATUS_PAUSED - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- STATUS_READY - Static variable in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- STRING_CODEC - Static variable in class reactor.io.codec.StandardCodecs
-
- StringCodec - Class in reactor.io.codec
-
- StringCodec() - Constructor for class reactor.io.codec.StringCodec
-
- StringCodec(Charset) - Constructor for class reactor.io.codec.StringCodec
-
- StringCodec(Byte) - Constructor for class reactor.io.codec.StringCodec
-
- StringCodec(Byte, Charset) - Constructor for class reactor.io.codec.StringCodec
-
- StringCodec.StringEncoder - Class in reactor.io.codec
-
- StringEncoder() - Constructor for class reactor.io.codec.StringCodec.StringEncoder
-
- submit(Callable<T>) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- submit(Runnable, T) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- submit(Runnable) - Method in class reactor.core.processor.util.SingleUseExecutor
-
- submit(Consumer<Long>, long, TimeUnit) - Method in class reactor.fn.timer.HashWheelTimer
-
- submit(Consumer<Long>) - Method in class reactor.fn.timer.HashWheelTimer
-
- submit(Consumer<Long>, long, TimeUnit) - Method in interface reactor.fn.timer.Timer
-
Submit a task for arbitrary execution after the given time delay.
- submit(Consumer<Long>) - Method in interface reactor.fn.timer.Timer
-
Submit a task for arbitrary execution after the delay of this timer's resolution.
- subscribe(Subscriber<? super E>) - Method in class reactor.core.processor.RingBufferProcessor
-
- subscribe(Subscriber<? super E>) - Method in class reactor.core.processor.RingBufferWorkProcessor
-
- subscriber - Variable in class reactor.core.reactivestreams.SubscriberBarrier
-
- subscriber - Variable in class reactor.core.reactivestreams.SubscriberWithContext
-
- SUBSCRIBER_COUNT - Static variable in class reactor.core.processor.ReactorProcessor
-
- SubscriberBarrier<I,O> - Class in reactor.core.reactivestreams
-
A Subscriber
with an asymetric typed wrapped subscriber.
- SubscriberBarrier(Subscriber<? super O>) - Constructor for class reactor.core.reactivestreams.SubscriberBarrier
-
- SubscriberFactory - Class in reactor.core.reactivestreams
-
A Reactive Streams Subscriber
factory which callbacks on start, onNext, onError and shutdown
- SubscriberFactory() - Constructor for class reactor.core.reactivestreams.SubscriberFactory
-
- SubscriberWithContext<T,C> - Class in reactor.core.reactivestreams
-
A Subscriber
with a typed stateful context.
- SubscriberWithContext(C, Subscriber<? super T>) - Constructor for class reactor.core.reactivestreams.SubscriberWithContext
-
- subscription - Variable in class reactor.core.reactivestreams.SubscriptionWithContext
-
- SubscriptionWithContext<C> - Class in reactor.core.reactivestreams
-
A Subscription
with a typed stateful context.
- SubscriptionWithContext(C, Subscription) - Constructor for class reactor.core.reactivestreams.SubscriptionWithContext
-
- substring(int, int) - Method in class reactor.io.buffer.Buffer
-
Slice a portion of this buffer and convert it to a String.
- supplier(T) - Static method in class reactor.fn.Functions
-
Deprecated.
Creates a Supplier
that will always return the given value
.
- supplier(Class<T>) - Static method in class reactor.fn.Functions
-
Deprecated.
Creates a Supplier
that will return a new instance of type
each time
it's called.
- supplier(Callable<T>) - Static method in class reactor.fn.Functions
-
Deprecated.
Creates a Supplier
that will call
the callable
each time it's asked for a value.
- supplier(Future<T>) - Static method in class reactor.fn.Functions
-
Deprecated.
Creates a Supplier
that will get
its value from the
future
each time it's asked for a value.
- Supplier<T> - Interface in reactor.fn
-
Implementations of this class supply the caller with an object.
- Suppliers - Class in reactor.fn
-
Deprecated.
- supply(T) - Static method in class reactor.fn.Suppliers
-
Deprecated.
Wrap the given object that will supply the given object every time
Supplier.get()
is
called.
- supplyOnce(T) - Static method in class reactor.fn.Suppliers
-
Deprecated.
Supply the given object only once, the first time
Supplier.get()
is invoked.
- supplyWhile(T, Predicate<T>) - Static method in class reactor.fn.Suppliers
-
Deprecated.
Supply the given object to callers only as long as the given
Predicate
returns true.
- supportsOrdering() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- supportsOrdering() - Method in class reactor.core.dispatch.SingleThreadDispatcher
-
- supportsOrdering() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- supportsOrdering() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- supportsOrdering() - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- supportsOrdering() - Method in interface reactor.core.Dispatcher
-
Inspect if the dispatcher supports ordered dispatching:
Single threaded dispatchers naturally preserve event ordering on dispatch.
- sync(boolean) - Method in class reactor.io.queue.spec.PersistentQueueSpec
-
- SynchronousDispatcher - Class in reactor.core.dispatch
-
A
Dispatcher
implementation that dispatches events using the calling thread.
- SynchronousDispatcher() - Constructor for class reactor.core.dispatch.SynchronousDispatcher
-
- t1 - Variable in class reactor.fn.tuple.Tuple1
-
- t2 - Variable in class reactor.fn.tuple.Tuple2
-
- t3 - Variable in class reactor.fn.tuple.Tuple3
-
- t4 - Variable in class reactor.fn.tuple.Tuple4
-
- t5 - Variable in class reactor.fn.tuple.Tuple5
-
- t6 - Variable in class reactor.fn.tuple.Tuple6
-
- t7 - Variable in class reactor.fn.tuple.Tuple7
-
- t8 - Variable in class reactor.fn.tuple.Tuple8
-
- tailRecurse() - Static method in class reactor.Environment
-
Obtain a fresh tailRecurse Dispatcher.
- TailRecurseDispatcher - Class in reactor.core.dispatch
-
A
Dispatcher
implementation that trampolines events using the calling thread and.
- TailRecurseDispatcher() - Constructor for class reactor.core.dispatch.TailRecurseDispatcher
-
- tailRecurseSeq - Variable in class reactor.core.dispatch.SingleThreadDispatcher
-
- tailRecursionPile - Variable in class reactor.core.dispatch.SingleThreadDispatcher
-
- tailRecursionPileSize - Variable in class reactor.core.dispatch.SingleThreadDispatcher
-
- take() - Method in class reactor.core.queue.CompletableBlockingQueue
-
- Tap<T> - Class in reactor.fn.support
-
A Tap
provides a limited window into an event stream.
- Tap() - Constructor for class reactor.fn.support.Tap
-
Create a Tap
.
- Task() - Constructor for class reactor.core.dispatch.AbstractLifecycleDispatcher.Task
-
- TERMINAL_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriberWithContext
-
- terminate() - Static method in class reactor.Environment
-
Clean and Shutdown the context environment.
- TERMINATED_UPDATER - Static variable in class reactor.core.reactivestreams.SubscriptionWithContext
-
- test(T) - Method in interface reactor.fn.Predicate
-
Returns true if the input object matches some criteria.
- THREAD_POOL - Static variable in class reactor.Environment
-
The name of the default thread pool dispatcher
- ThreadPoolExecutorDispatcher - Class in reactor.core.dispatch
-
A Dispatcher
that uses a ThreadPoolExecutor
with an unbounded queue to dispatch events.
- ThreadPoolExecutorDispatcher(int, int) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
Creates a new ThreadPoolExecutorDispatcher with the given poolSize and backlog.
- ThreadPoolExecutorDispatcher(int, int, String) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
Create a new ThreadPoolExecutorDispatcher with the given size, backlog, name, and RejectedExecutionHandler
.
- ThreadPoolExecutorDispatcher(int, int, String, BlockingQueue<Runnable>, RejectedExecutionHandler) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
Create a new ThreadPoolExecutorDispatcher with the given size, backlog, name, and RejectedExecutionHandler
.
- ThreadPoolExecutorDispatcher(int, int, ExecutorService) - Constructor for class reactor.core.dispatch.ThreadPoolExecutorDispatcher
-
Create a new ThreadPoolTaskExecutor with the given backlog and ExecutorService
.
- throwIfFatal(Throwable) - Static method in class reactor.core.support.Exceptions
-
Throws a particular Throwable
only if it belongs to a set of "fatal" error varieties.
- timer() - Static method in class reactor.Environment
-
Obtain the default timer from the current environment.
- Timer - Interface in reactor.fn.timer
-
- TimerPausable(long, long, T, long) - Constructor for class reactor.fn.timer.HashWheelTimer.TimerPausable
-
Creates a new Timer Registration with given , and .
- TimeUtils - Class in reactor.fn.timer
-
- TimeUtils() - Constructor for class reactor.fn.timer.TimeUtils
-
- toArray() - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- toArray(T[]) - Method in class reactor.core.queue.internal.MpscLinkedQueue
-
- toArray() - Method in class reactor.fn.tuple.Tuple
-
Turn this Tuple into a plain Object array.
- toArray() - Method in class reactor.fn.tuple.Tuple1
-
- toArray() - Method in class reactor.fn.tuple.Tuple2
-
- toArray() - Method in class reactor.fn.tuple.Tuple3
-
- toArray() - Method in class reactor.fn.tuple.Tuple4
-
- toArray() - Method in class reactor.fn.tuple.Tuple5
-
- toArray() - Method in class reactor.fn.tuple.Tuple6
-
- toArray() - Method in class reactor.fn.tuple.Tuple7
-
- toArray() - Method in class reactor.fn.tuple.Tuple8
-
- toArray() - Method in class reactor.fn.tuple.TupleN
-
- toString() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- toString() - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- toString() - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- toString() - Method in class reactor.core.processor.RingBufferProcessor
-
- toString() - Method in class reactor.core.processor.RingBufferWorkProcessor
-
- toString() - Method in class reactor.core.reactivestreams.SerializedSubscriber
-
- toString() - Method in class reactor.fn.timer.HashWheelTimer.TimerPausable
-
- toString() - Method in class reactor.fn.timer.HashWheelTimer
-
- toString() - Method in class reactor.fn.tuple.Tuple1
-
- toString() - Method in class reactor.fn.tuple.Tuple2
-
- toString() - Method in class reactor.fn.tuple.Tuple3
-
- toString() - Method in class reactor.fn.tuple.Tuple4
-
- toString() - Method in class reactor.fn.tuple.Tuple5
-
- toString() - Method in class reactor.fn.tuple.Tuple6
-
- toString() - Method in class reactor.fn.tuple.Tuple7
-
- toString() - Method in class reactor.fn.tuple.Tuple8
-
- toString() - Method in class reactor.fn.tuple.TupleN
-
- toString() - Method in class reactor.io.buffer.Buffer
-
- TRACE_CANCEL - Static variable in exception reactor.core.processor.CancelException
-
- TRACE_NOCAPACITY - Static variable in exception reactor.core.processor.InsufficientCapacityException
-
- TraceableDelegatingDispatcher - Class in reactor.core.dispatch
-
An implementation of
Dispatcher
that traces activity through it.
- TraceableDelegatingDispatcher(Dispatcher) - Constructor for class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- tryAllocateTask() - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- tryAllocateTask() - Method in class reactor.core.dispatch.MpscDispatcher
-
- tryAllocateTask() - Method in class reactor.core.dispatch.MultiThreadDispatcher
-
- tryAllocateTask() - Method in class reactor.core.dispatch.RingBufferDispatcher
-
- tryAllocateTask() - Method in class reactor.core.dispatch.WorkQueueDispatcher
-
- tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.AbstractLifecycleDispatcher
-
- tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.SynchronousDispatcher
-
- tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TailRecurseDispatcher
-
- tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in class reactor.core.dispatch.TraceableDelegatingDispatcher
-
- tryDispatch(E, Consumer<E>, Consumer<Throwable>) - Method in interface reactor.core.Dispatcher
-
Instruct the Dispatcher
to dispatch the data
.
- Tuple - Class in reactor.fn.tuple
-
A Tuple is an immutable Collection
of objects, each of which can be of an arbitrary type.
- Tuple(int) - Constructor for class reactor.fn.tuple.Tuple
-
Creates a new Tuple
that holds the given values
.
- Tuple1<T1> - Class in reactor.fn.tuple
-
A tuple that holds a single value
- Tuple2<T1,T2> - Class in reactor.fn.tuple
-
A tuple that holds two values
- Tuple3<T1,T2,T3> - Class in reactor.fn.tuple
-
A tuple that holds three values
- Tuple4<T1,T2,T3,T4> - Class in reactor.fn.tuple
-
A tuple that holds four values
- Tuple5<T1,T2,T3,T4,T5> - Class in reactor.fn.tuple
-
A tuple that holds five values
- Tuple6<T1,T2,T3,T4,T5,T6> - Class in reactor.fn.tuple
-
A tuple that holds six values
- Tuple7<T1,T2,T3,T4,T5,T6,T7> - Class in reactor.fn.tuple
-
A tuple that holds seven values
- Tuple8<T1,T2,T3,T4,T5,T6,T7,T8> - Class in reactor.fn.tuple
-
A tuple that holds eight values
- TupleN - Class in reactor.fn.tuple
-
A tuple that holds 9 or more values
- type - Variable in class reactor.core.processor.MutableSignal
-