- cache() - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(int) - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(Duration) - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(int, Duration) - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(int, Duration, Scheduler) - Method in class reactor.core.publisher.Flux
-
Turn this
Flux
into a hot source and cache last emitted signals for further
Subscriber
.
- cache() - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signals for further
Subscriber
.
- cache(Duration) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signals for further
Subscriber
, with an expiry timeout.
- cache(Duration, Scheduler) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signals for further
Subscriber
, with an expiry timeout.
- cache(Function<? super T, Duration>, Function<Throwable, Duration>, Supplier<Duration>) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signal for further
Subscriber
, with an expiry timeout (TTL) that depends on said signal.
- cache(Function<? super T, Duration>, Function<Throwable, Duration>, Supplier<Duration>, Scheduler) - Method in class reactor.core.publisher.Mono
-
Turn this
Mono
into a hot source and cache last emitted signal for further
Subscriber
, with an expiry timeout (TTL) that depends on said signal.
- cacheInvalidateIf(Predicate<? super T>) - Method in class reactor.core.publisher.Mono
-
Cache
onNext
signal received from the source and replay it to other subscribers,
while allowing invalidation by verifying the cached value against the given
Predicate
each time a late
subscription occurs.
- cacheInvalidateWhen(Function<? super T, Mono<Void>>) - Method in class reactor.core.publisher.Mono
-
Cache
onNext
signal received from the source and replay it to other subscribers,
while allowing invalidation via a
Mono<Void>
companion trigger generated from the currently
cached value.
- cacheInvalidateWhen(Function<? super T, Mono<Void>>, Consumer<? super T>) - Method in class reactor.core.publisher.Mono
-
Cache
onNext
signal received from the source and replay it to other subscribers,
while allowing invalidation via a
Mono<Void>
companion trigger generated from the currently
cached value.
- cacheLast() - Static method in class reactor.core.publisher.ReplayProcessor
-
- cacheLastOrDefault(T) - Static method in class reactor.core.publisher.ReplayProcessor
-
- canAppearAfterOnSubscribe(Subscription) - Static method in class reactor.core.publisher.Operators
-
Check whether the provided
Subscription
is the one used to satisfy Spec's §1.9 rule
before signalling an error.
- cancel() - Method in class reactor.core.publisher.BaseSubscriber
-
- cancel() - Method in class reactor.core.publisher.MonoProcessor
-
- cancel() - Method in class reactor.core.publisher.Operators.DeferredSubscription
-
- cancel() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- cancel() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- cancel() - Method in interface reactor.test.subscriber.TestSubscriber
-
- CANCELLED - Static variable in class reactor.core.Scannable.Attr
-
A
Boolean
attribute indicating whether or not a downstream component
has interrupted consuming this scanned component, e.g., a cancelled
subscription.
- cancelledSubscription() - Static method in class reactor.core.publisher.Operators
-
A singleton Subscription that represents a cancelled subscription instance and
should not be leaked to clients as it represents a terminal state.
- cancelOn(Scheduler) - Method in class reactor.core.publisher.Flux
-
Prepare this
Flux
so that subscribers will cancel from it on a
specified
Scheduler
.
- cancelOn(Scheduler) - Method in class reactor.core.publisher.Mono
-
Prepare this
Mono
so that subscribers will cancel from it on a
specified
Scheduler
.
- CAPACITY - Static variable in class reactor.core.Scannable.Attr
-
Return an an
Integer
capacity when no
Scannable.Attr.PREFETCH
is defined or
when an arbitrary maximum limit is applied to the backlog capacity of the
scanned component.
- capacity(Queue) - Static method in class reactor.util.concurrent.Queues
-
Return the capacity of a given
Queue
in a best effort fashion.
- CAPACITY_UNSURE - Static variable in class reactor.util.concurrent.Queues
-
- cast(Class<E>) - Method in class reactor.core.publisher.Flux
-
Cast the current
Flux
produced type into a target produced type.
- cast(Class<E>) - Method in class reactor.core.publisher.Mono
-
Cast the current
Mono
produced type into a target produced type.
- ceilingNextPowerOfTwo(int) - Static method in class reactor.util.concurrent.Queues
-
Calculate the next power of 2, greater than or equal to x.
- checkpoint() - Method in class reactor.core.publisher.Flux
-
Activate traceback (full assembly tracing) for this particular
Flux
, in case of an error
upstream of the checkpoint.
- checkpoint(String) - Method in class reactor.core.publisher.Flux
-
Activate traceback (assembly marker) for this particular
Flux
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.Flux
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- checkpoint() - Method in class reactor.core.publisher.Mono
-
Activate traceback (full assembly tracing) for this particular
Mono
, in case of an error
upstream of the checkpoint.
- checkpoint(String) - Method in class reactor.core.publisher.Mono
-
Activate traceback (assembly marker) for this particular
Mono
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.Mono
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- checkpoint() - Method in class reactor.core.publisher.ParallelFlux
-
Activate traceback (full assembly tracing) for this particular
ParallelFlux
, in case of an
error upstream of the checkpoint.
- checkpoint(String) - Method in class reactor.core.publisher.ParallelFlux
-
Activate traceback (assembly marker) for this particular
ParallelFlux
by giving it a description that
will be reflected in the assembly traceback in case of an error upstream of the
checkpoint.
- checkpoint(String, boolean) - Method in class reactor.core.publisher.ParallelFlux
-
Activate traceback (full assembly tracing or the lighter assembly marking depending on the
forceStackTrace
option).
- checkUnderRequesting(boolean) - Method in class reactor.test.StepVerifierOptions
-
Activate or deactivate the
StepVerifier
check of request amount
being too low.
- clear() - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
- clear() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- close() - Method in class reactor.tools.agent.ReactorDebugByteBuddyPlugin
-
- collect(Supplier<E>, BiConsumer<E, ? super T>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined container,
by applying a collector
BiConsumer
taking the container and each element.
- collect(Collector<? super T, A, ? extends R>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a container,
by applying a Java 8 Stream API
Collector
The collected result will be emitted when this sequence completes, emitting
the empty container if the sequence was empty.
- collect(Supplier<? extends C>, BiConsumer<? super C, ? super T>) - Method in class reactor.core.publisher.ParallelFlux
-
Collect the elements in each rail into a collection supplied via a
collectionSupplier and collected into with a collector action, emitting the
collection at the end.
- collectList() - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a
List
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
List
if the sequence was empty.
- collectMap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a hashed
Map
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
Map
if the sequence was empty.
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a hashed
Map
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
Map
if the sequence was empty.
- collectMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, V>>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined
Map
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
Map
if the sequence was empty.
- collectMultimap(Function<? super T, ? extends K>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a
multimap
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
multimap
if the sequence was empty.
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a
multimap
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
multimap
if the sequence was empty.
- collectMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, Collection<V>>>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
into a user-defined
multimap
that is
emitted by the resulting
Mono
when this sequence completes, emitting the
empty
multimap
if the sequence was empty.
- collectSortedList() - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
until this sequence completes,
and then sort them in natural order into a
List
that is emitted by the
resulting
Mono
.
- collectSortedList(Comparator<? super T>) - Method in class reactor.core.publisher.Flux
-
Collect all elements emitted by this
Flux
until this sequence completes,
and then sort them using a
Comparator
into a
List
that is emitted
by the resulting
Mono
.
- collectSortedList(Comparator<? super T>) - Method in class reactor.core.publisher.ParallelFlux
-
Sorts the 'rails' according to the comparator and returns a full sorted list as a
Publisher.
- collectSortedList(Comparator<? super T>, int) - Method in class reactor.core.publisher.ParallelFlux
-
Sorts the 'rails' according to the comparator and returns a full sorted list as a
Publisher.
- combineLatest(Function<Object[], V>, Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of the
Publisher
sources.
- combineLatest(Function<Object[], V>, int, Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of the
Publisher
sources.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of two
Publisher
sources.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of three
Publisher
sources.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of four
Publisher
sources.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of five
Publisher
sources.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each of six
Publisher
sources.
- combineLatest(Iterable<? extends Publisher<? extends T>>, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each
of the
Publisher
sources provided in an
Iterable
.
- combineLatest(Iterable<? extends Publisher<? extends T>>, int, Function<Object[], V>) - Static method in class reactor.core.publisher.Flux
-
Build a
Flux
whose data are generated by the combination of
the
most recently published value from each
of the
Publisher
sources provided in an
Iterable
.
- complete() - Method in interface reactor.core.publisher.FluxSink
-
Terminate the sequence successfully, generating an
onComplete
signal.
- complete(Subscriber<?>) - Static method in class reactor.core.publisher.Operators
-
Calls onSubscribe on the target Subscriber with the empty instance followed by a call to onComplete.
- complete(O) - Method in class reactor.core.publisher.Operators.MonoSubscriber
-
Tries to emit the value and complete the underlying subscriber or
stores the value away until there is a request for it.
- complete() - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a Signal
of variety Type.COMPLETE
.
- complete(Context) - Static method in interface reactor.core.publisher.Signal
-
Creates and returns a
Signal
of variety
Type.COMPLETE
, associated
with a specific
Context
.
- complete() - Method in interface reactor.core.publisher.SynchronousSink
-
- complete() - Method in class reactor.test.publisher.TestPublisher
-
- composite() - Static method in class reactor.core.Disposables
-
- composite(Disposable...) - Static method in class reactor.core.Disposables
-
- composite(Iterable<? extends Disposable>) - Static method in class reactor.core.Disposables
-
- concat(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources provided in an
Iterable
, forwarding elements
emitted by the sources downstream.
- concat(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concat(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concat(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources provided as a vararg, forwarding elements emitted by the
sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends Publisher<? extends T>>, boolean, int) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources emitted as an onNext signal from a parent
Publisher
,
forwarding elements emitted by the sources downstream.
- concatDelayError(Publisher<? extends T>...) - Static method in class reactor.core.publisher.Flux
-
Concatenate all sources provided as a vararg, forwarding elements emitted by the
sources downstream.
- concatMap(Function<? super T, ? extends Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMap(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.ParallelFlux
-
Generates and concatenates Publishers on each 'rail', signalling errors immediately
and generating 2 publishers upfront.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class reactor.core.publisher.ParallelFlux
-
Generates and concatenates Publishers on each 'rail', signalling errors immediately
and using the given prefetch amount for generating Publishers upfront.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends V>>, boolean, int) - Method in class reactor.core.publisher.Flux
-
Transform the elements emitted by this
Flux
asynchronously into Publishers,
then flatten these inner publishers into a single
Flux
, sequentially and
preserving order using concatenation.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class reactor.core.publisher.ParallelFlux
-
Generates and concatenates Publishers on each 'rail', delaying errors
and generating 2 publishers upfront.
- concatMapIterable(Function<? super T, ? extends Iterable<? extends R>>) - Method in class reactor.core.publisher.Flux
-
Transform the items emitted by this
Flux
into
Iterable
, then flatten the elements from those by
concatenating them into a single
Flux
.
- concatMapIterable(Function<? super T, ? extends Iterable<? extends R>>, int) - Method in class reactor.core.publisher.Flux
-
Transform the items emitted by this
Flux
into
Iterable
, then flatten the emissions from those by
concatenating them into a single
Flux
.
- concatWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Flux
-
Concatenate emissions of this
Flux
with the provided
Publisher
(no interleave).
- concatWith(Publisher<? extends T>) - Method in class reactor.core.publisher.Mono
-
Concatenate emissions of this
Mono
with the provided
Publisher
(no interleave).
- concatWithValues(T...) - Method in class reactor.core.publisher.Flux
-
Concatenates the values to the end of the
Flux
- ConditionalTestSubscriber<T> - Interface in reactor.test.subscriber
-
- connect() - Method in class reactor.core.publisher.ConnectableFlux
-
- connect(Consumer<? super Disposable>) - Method in class reactor.core.publisher.ConnectableFlux
-
- ConnectableFlux<T> - Class in reactor.core.publisher
-
The abstract base class for connectable publishers that let subscribers pile up
before they connect to their data source.
- ConnectableFlux() - Constructor for class reactor.core.publisher.ConnectableFlux
-
- consumeErrorWith(Consumer<Throwable>) - Method in interface reactor.test.StepVerifier.LastStep
-
Expect an error and consume with the given consumer.
- consumeNextWith(Consumer<? super T>) - Method in interface reactor.test.StepVerifier.Step
-
Expect an element and consume with the given consumer.Any
AssertionError
s thrown by the consumer will be rethrown during
verification.
- consumeRecordedWith(Consumer<? super Collection<T>>) - Method in interface reactor.test.StepVerifier.Step
-
- consumeSubscriptionWith(Consumer<? super Subscription>) - Method in interface reactor.test.StepVerifier.Step
-
- contains(Object) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- contains(Object, Object) - Method in interface reactor.test.StepVerifier.ContextExpectations
-
Check that the propagated
Context
contains the given value associated
to the given key.
- containsAll(Collection<?>) - Method in interface reactor.core.Fuseable.QueueSubscription
-
- containsAllOf(Context) - Method in interface reactor.test.StepVerifier.ContextExpectations
-
Check that the propagated
Context
contains all of the key-value pairs
of the given
Context
.
- containsAllOf(Map<?, ?>) - Method in interface reactor.test.StepVerifier.ContextExpectations
-
Check that the propagated
Context
contains all of the key-value pairs
of the given
Map
.
- containsOnly(Context) - Method in interface reactor.test.StepVerifier.ContextExpectations
-
Check that the propagated
Context
contains all of the key-value pairs
of the given
Context
, and nothing else.
- containsOnly(Map<?, ?>) - Method in interface reactor.test.StepVerifier.ContextExpectations
-
Check that the propagated
Context
contains all of the key-value pairs
of the given
Map
, and nothing else.
- Context - Interface in reactor.util.context
-
A key/value store that is propagated between components such as operators via the
context protocol.
- contextCapture() - Method in class reactor.core.publisher.Flux
-
If
context-propagation library
is on the classpath, this is a convenience shortcut to capture thread local values during the
subscription phase and put them in the
Context
that is visible upstream of this operator.
- contextCapture() - Method in class reactor.core.publisher.Mono
-
If
context-propagation library
is on the classpath, this is a convenience shortcut to capture thread local values during the
subscription phase and put them in the
Context
that is visible upstream of this operator.
- contextPut(Object, Object) - Method in class reactor.test.subscriber.TestSubscriberBuilder
-
Enrich the
Context
with a single entry.
- contextPutAll(ContextView) - Method in class reactor.test.subscriber.TestSubscriberBuilder
-
- contextView() - Method in interface reactor.core.publisher.FluxSink
-
Return the current subscriber's context as a
ContextView
for inspection.
- contextView() - Method in interface reactor.core.publisher.MonoSink
-
Return the current subscriber's context as a
ContextView
for inspection.
- contextView() - Method in interface reactor.core.publisher.SynchronousSink
-
Return the current subscriber's context as a
ContextView
for inspection.
- ContextView - Interface in reactor.util.context
-
A read-only view of a collection of key/value pairs that is propagated between components
such as operators via the context protocol.
- contextWrite(ContextView) - Method in class reactor.core.publisher.Flux
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by making all values from the provided
ContextView
visible on top
of pairs from downstream.
- contextWrite(Function<Context, Context>) - Method in class reactor.core.publisher.Flux
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by applying a
Function
to the downstream
Context
.
- contextWrite(ContextView) - Method in class reactor.core.publisher.Mono
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by making all values from the provided
ContextView
visible on top
of pairs from downstream.
- contextWrite(Function<Context, Context>) - Method in class reactor.core.publisher.Mono
-
Enrich the
Context
visible from downstream for the benefit of upstream
operators, by applying a
Function
to the downstream
Context
.
- convertToFluxBypassingHooks(Publisher<T>) - Static method in class reactor.core.publisher.Hooks
-
- convertToMonoBypassingHooks(Publisher<T>, boolean) - Static method in class reactor.core.publisher.Hooks
-
- copy() - Method in class reactor.test.StepVerifierOptions
-
- copy() - Method in interface reactor.util.retry.Retry.RetrySignal
-
An immutable copy of this
Retry.RetrySignal
which is guaranteed to give a consistent view
of the state at the time at which this method is invoked.
- CorePublisher<T> - Interface in reactor.core
-
- CoreSubscriber<T> - Interface in reactor.core
-
A
Context
aware subscriber which has relaxed rules for §1.3 and §3.9
compared to the original
Subscriber
from Reactive Streams.
- count() - Method in class reactor.core.publisher.Flux
-
Counts the number of values in this
Flux
.
- create() - Static method in class reactor.core.publisher.DirectProcessor
-
- create() - Static method in class reactor.core.publisher.EmitterProcessor
-
- create(boolean) - Static method in class reactor.core.publisher.EmitterProcessor
-
- create(int) - Static method in class reactor.core.publisher.EmitterProcessor
-
- create(int, boolean) - Static method in class reactor.core.publisher.EmitterProcessor
-
- create(Consumer<? super FluxSink<T>>) - Static method in class reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements in a synchronous or asynchronous manner through the
FluxSink
API.
- create(Consumer<? super FluxSink<T>>, FluxSink.OverflowStrategy) - Static method in class reactor.core.publisher.Flux
-
Programmatically create a
Flux
with the capability of emitting multiple
elements in a synchronous or asynchronous manner through the
FluxSink
API.
- create(Consumer<MonoSink<T>>) - Static method in class reactor.core.publisher.Mono
-
Creates a deferred emitter that can be used with callback-based
APIs to signal at most one value, a complete or an error signal.
- create() - Static method in class reactor.core.publisher.MonoProcessor
-
- create() - Static method in class reactor.core.publisher.ReplayProcessor
-
- create(int) - Static method in class reactor.core.publisher.ReplayProcessor
-
- create(int, boolean) - Static method in class reactor.core.publisher.ReplayProcessor
-
- create() - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>) - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
-
- create(Queue<E>, Consumer<? super E>, Disposable) - Static method in class reactor.core.publisher.UnicastProcessor
-
- create() - Static method in class reactor.test.publisher.TestPublisher
-
- create() - Static method in class reactor.test.scheduler.VirtualTimeScheduler
-
- create(boolean) - Static method in class reactor.test.scheduler.VirtualTimeScheduler
-
- create(Publisher<? extends T>) - Static method in interface reactor.test.StepVerifier
-
- create(Publisher<? extends T>, long) - Static method in interface reactor.test.StepVerifier
-
- create(Publisher<? extends T>, StepVerifierOptions) - Static method in interface reactor.test.StepVerifier
-
- create() - Static method in class reactor.test.StepVerifierOptions
-
Create a new default set of options for a
StepVerifier
that can be tuned
using the various available non-getter methods (which can be chained).
- create() - Static method in interface reactor.test.subscriber.TestSubscriber
-
- createCold() - Static method in class reactor.test.publisher.TestPublisher
-
Create a cold
TestPublisher
, which can be subscribed to by multiple
subscribers.
- createColdNonBuffering() - Static method in class reactor.test.publisher.TestPublisher
-
Create a cold
TestPublisher
, which can be subscribed to by multiple
subscribers.
- createColdNonCompliant(boolean, TestPublisher.Violation, TestPublisher.Violation...) - Static method in class reactor.test.publisher.TestPublisher
-
Create a cold
TestPublisher
, which can be subscribed to by multiple
subscribers.
- createListener(Publisher<? extends T>, ContextView, STATE) - Method in interface reactor.core.observability.SignalListenerFactory
-
- createNoncompliant(TestPublisher.Violation, TestPublisher.Violation...) - Static method in class reactor.test.publisher.TestPublisher
-
- createSizeAndTimeout(int, Duration) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createSizeAndTimeout(int, Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createTimeout(Duration) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createTimeout(Duration, Scheduler) - Static method in class reactor.core.publisher.ReplayProcessor
-
- createWorker() - Method in interface reactor.core.scheduler.Scheduler
-
Creates a worker of this Scheduler.
- createWorker() - Method in class reactor.test.scheduler.VirtualTimeScheduler
-
- currentContext() - Method in interface reactor.core.CoreSubscriber
-
Request a
Context
from dependent components which can include downstream
operators during subscribing or a terminal
Subscriber
.
- currentContext() - Method in class reactor.core.publisher.DirectProcessor
-
Deprecated.
- currentContext() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- currentContext() - Method in class reactor.core.publisher.FluxProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.FluxSink
-
- currentContext() - Method in class reactor.core.publisher.MonoProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.MonoSink
-
- currentContext() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- currentContext() - Method in interface reactor.core.publisher.SynchronousSink
-
- currentContext() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.
- currentSubscriberCount() - Method in class reactor.core.publisher.EmitterProcessor
-
Deprecated.
- currentSubscriberCount() - Method in class reactor.core.publisher.ReplayProcessor
-
Deprecated.
- currentSubscriberCount() - Method in interface reactor.core.publisher.Sinks.Empty
-
Get how many
Subscribers
are currently subscribed to the sink.
- currentSubscriberCount() - Method in interface reactor.core.publisher.Sinks.Many
-
Get how many
Subscribers
are currently subscribed to the sink.
- currentSubscriberCount() - Method in class reactor.core.publisher.UnicastProcessor
-
Deprecated.