Skip navigation links
A B C D E F G H I J K L M N O P R S T U V W Z 

A

accept(I) - Method in class reactor.rx.action.Action
 
accept(Long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
accept(Subscriber<? super T>) - Method in class reactor.rx.action.Signal
 
accept(O) - Method in class reactor.rx.Promise
 
accept(Stream<?>) - Method in class reactor.rx.StreamUtils.StreamVisitor
 
accept(Long) - Method in class reactor.rx.subscription.PushSubscription
 
Action<I,O> - Class in reactor.rx.action
An Action is a reactive component to subscribe to a Publisher and in particular to a Stream.
Action() - Constructor for class reactor.rx.action.Action
 
Action(long) - Constructor for class reactor.rx.action.Action
 
adaptiveConsume(Consumer<? super O>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
adaptiveConsumeOn(Dispatcher, Consumer<? super O>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
AdaptiveConsumerAction<T> - Class in reactor.rx.action.terminal
 
AdaptiveConsumerAction(Dispatcher, long, Consumer<? super T>, Function<Stream<Long>, ? extends Publisher<? extends Long>>) - Constructor for class reactor.rx.action.terminal.AdaptiveConsumerAction
 
add(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
addPublisher(Publisher<? extends I>) - Method in class reactor.rx.action.combination.FanInAction
 
addSubscription(PushSubscription<O>) - Method in class reactor.rx.action.Action
 
after() - Method in class reactor.rx.Promise
Only forward onError and onComplete signals into the returned stream.
after() - Method in class reactor.rx.Stream
Only forward onError and onComplete signals into the returned stream.
AfterAction<T> - Class in reactor.rx.action.passive
 
AfterAction() - Constructor for class reactor.rx.action.passive.AfterAction
 
any(Promise<T>...) - Static method in class reactor.rx.Promises
Pick the first result coming from any of the given promises and populate a new Promise.
any(List<? extends Promise<T>>) - Static method in class reactor.rx.Promises
Pick the first result coming from any of the given promises and populate a new Promise.
await() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
await(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.
await(Publisher<?>) - Static method in class reactor.rx.Streams
Wait 30 Seconds until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long) - Static method in class reactor.rx.Streams
Wait {code timeout} Seconds until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long, TimeUnit) - Static method in class reactor.rx.Streams
Wait {code timeout} in unit until a terminal signal from the passed publisher has been emitted.
await(Publisher<?>, long, TimeUnit, boolean) - Static method in class reactor.rx.Streams
Wait {code timeout} in unit until a terminal signal from the passed publisher has been emitted.
awaitSuccess() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
awaitSuccess(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.

B

BarrierStream - Class in reactor.rx.stream
A BarrierStream provides a type of Stream into which you can bind Consumers and Functions from arbitrary components.
BarrierStream() - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Environment) - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Dispatcher) - Constructor for class reactor.rx.stream.BarrierStream
 
BarrierStream(Environment, Dispatcher) - Constructor for class reactor.rx.stream.BarrierStream
 
BatchAction<T,V> - Class in reactor.rx.action.aggregation
 
BatchAction(Dispatcher, int, boolean, boolean, boolean) - Constructor for class reactor.rx.action.aggregation.BatchAction
 
BatchAction(Dispatcher, int, boolean, boolean, boolean, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BatchAction
 
batchConsume(Consumer<? super O>, Function<Long, ? extends Long>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
batchConsumeOn(Dispatcher, Consumer<? super O>, Function<Long, ? extends Long>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
batchSize - Variable in class reactor.rx.action.aggregation.BatchAction
 
BatchSubscription<T> - Class in reactor.rx.subscription
A Subscription wrapper which request
BatchSubscription(Subscription, Subscriber<T>, int) - Constructor for class reactor.rx.subscription.BatchSubscription
 
BehaviorBroadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
BiStreams - Class in reactor.rx
A Streams add-on to work with key/value pairs hydrated in Tuple2.
broadcast() - Method in class reactor.rx.Stream
Subscribe a new Broadcaster and return it for future subscribers interactions.
broadcastComplete() - Method in class reactor.rx.action.Action
Send a complete event to all the attached Subscriber ONLY IF the underlying state is READY.
Broadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
Broadcaster(Environment, Dispatcher, long) - Constructor for class reactor.rx.broadcast.Broadcaster
INTERNAL
broadcastError(Throwable) - Method in class reactor.rx.action.Action
Send an error to all the attached Subscriber.
broadcastNext(O) - Method in class reactor.rx.action.Action
Send an element of parameterized type {link O} to all the attached Subscriber.
broadcastOn(Dispatcher) - Method in class reactor.rx.Stream
Subscribe a new Broadcaster and return it for future subscribers interactions.
broadcastTo(E) - Method in class reactor.rx.Stream
Subscribe the passed subscriber, only creating once necessary upstream Subscriptions and returning itself.
broadcastTuple() - Method in class reactor.rx.action.combination.CombineLatestAction
 
broadcastTuple(boolean) - Method in class reactor.rx.action.combination.ZipAction
 
browse(Stream<O>) - Static method in class reactor.rx.StreamUtils
 
browse(Stream<O>, StreamUtils.DebugVisitor) - Static method in class reactor.rx.StreamUtils
 
buffer() - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every time Stream.getCapacity() has been reached, or flush is triggered.
buffer(int) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets that will be pushed into the returned Stream every time Stream.getCapacity() has been reached.
buffer(Publisher<?>, Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be moved into the returned Stream every time the passed boundary publisher emits an item.
buffer(Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be moved into the returned Stream every time the passed boundary publisher emits an item.
buffer(int, int) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every time maxSize has been reached by any of them.
buffer(long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan.
buffer(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan.
buffer(long, long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets created every timeshift that will be pushed into the returned Stream every timespan.
buffer(long, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into multiple List buckets created every timeshift that will be pushed into the returned Stream every timespan.
buffer(int, long, TimeUnit) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan OR maxSize items.
buffer(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Collect incoming values into a List that will be pushed into the returned Stream every timespan OR maxSize items
buffer - Variable in class reactor.rx.subscription.ReactiveSubscription
 
BufferAction<T> - Class in reactor.rx.action.aggregation
 
BufferAction(Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.BufferAction
 
BufferAction(Dispatcher, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BufferAction
 
BufferShiftAction<T> - Class in reactor.rx.action.aggregation
 
BufferShiftAction(Dispatcher, int, int) - Constructor for class reactor.rx.action.aggregation.BufferShiftAction
 
BufferShiftAction(Dispatcher, int, int, long, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.BufferShiftAction
 
BufferShiftWhenAction<T> - Class in reactor.rx.action.aggregation
 
BufferShiftWhenAction(Publisher<?>, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.BufferShiftWhenAction
 
BufferWhenAction<T> - Class in reactor.rx.action.aggregation
 
BufferWhenAction(Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.BufferWhenAction
 

C

cache() - Method in class reactor.rx.Stream
Cache all signal to this Stream and release them on request that will observe any values accepted by this Stream.
CacheAction<T> - Class in reactor.rx.action.aggregation
 
CacheAction() - Constructor for class reactor.rx.action.aggregation.CacheAction
 
CallbackAction<T> - Class in reactor.rx.action.passive
 
CallbackAction(Consumer<? super T>, Consumer<Void>) - Constructor for class reactor.rx.action.passive.CallbackAction
 
cancel() - Method in class reactor.rx.action.Action
 
cancel() - Method in class reactor.rx.action.combination.ConcatAction
 
cancel() - Method in class reactor.rx.action.combination.FanInAction
 
cancel() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
cancel() - Method in class reactor.rx.action.combination.FanInSubscription
 
cancel() - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
cancel() - Method in class reactor.rx.action.combination.SwitchAction
 
cancel() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
cancel() - Method in class reactor.rx.action.CompositeAction
 
cancel() - Method in interface reactor.rx.action.Control
Stop consuming signals from upstream.
cancel() - Method in class reactor.rx.action.passive.LoggerAction
 
cancel() - Method in class reactor.rx.action.support.TapAndControls
 
cancel() - Method in class reactor.rx.broadcast.Broadcaster
 
cancel() - Method in class reactor.rx.subscription.DropSubscription
 
cancel() - Method in class reactor.rx.subscription.FanOutSubscription
 
cancel() - Method in class reactor.rx.subscription.PushSubscription
 
cancel() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
cancelSubscription(PushSubscription<O>) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- INTERNALS --------------------------------------------------------------------------------------------------------
cancelSubscription(PushSubscription<O>) - Method in class reactor.rx.Stream
Try cleaning a given subscription from the stream references.
capacity - Variable in class reactor.rx.action.Action
 
capacity(long) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION MODIFIERS --------------------------------------------------------------------------------------------------------
capacity(long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
capacity(long) - Method in class reactor.rx.action.CompositeAction
 
capacity(long) - Method in class reactor.rx.broadcast.Broadcaster
 
capacity(long) - Method in class reactor.rx.Stream
Bind the stream to a given volume of in-flight data: - An Action will request up to the defined volume upstream.
capacity - Variable in class reactor.rx.subscription.DropSubscription
 
capacity() - Method in class reactor.rx.subscription.ReactiveSubscription
 
CAPACITY_UPDATER - Static variable in class reactor.rx.subscription.DropSubscription
 
cast(Class<E>) - Method in class reactor.rx.Stream
Cast the current Stream flowing data type into a target class type.
checkDynamicMerge() - Method in class reactor.rx.action.combination.FanInAction
 
checkRequest(long) - Static method in class reactor.rx.action.Action
 
chronicle - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
chronicle() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
ChronicleReaderStream<K,V> - Class in reactor.rx.stream.io
Implementation of a Dispatcher that uses a IndexedChronicle to queue tasks to execute.
ChronicleReaderStream(String) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
Create a chronicle dispatcher
ChronicleReaderStream(String, Chronicle) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
Create a chronicle dispatcher
ChronicleReaderStream(String, Chronicle, Codec<Buffer, K, K>, Codec<Buffer, V, V>) - Constructor for class reactor.rx.stream.io.ChronicleReaderStream
 
ChronicleStream<K,V> - Class in reactor.rx.stream.io
 
ChronicleStream(String) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int, Chronicle) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
ChronicleStream(String, int, Chronicle, Codec<Buffer, K, K>, Codec<Buffer, V, V>) - Constructor for class reactor.rx.stream.io.ChronicleStream
 
clear() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
clear() - Method in class reactor.rx.stream.io.ChronicleStream
 
combine() - Method in class reactor.rx.action.Action
 
combine() - Method in class reactor.rx.Stream
Combine the most ancient upstream action to act as the Subscriber input component and the current stream to act as the Publisher.
combine() - Method in class reactor.rx.stream.LiftStream
 
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Function<Tuple2<T1, T2>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Tuple3<T1, T2, T3>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Tuple4<T1, T2, T3, T4>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Tuple5<T1, T2, T3, T4, T5>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Tuple6<T1, T2, T3, T4, T5, T6>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(List<? extends Publisher<?>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
combineLatest(Publisher<? extends Publisher<E>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the combination of the most recent published values from all publishers.
CombineLatestAction<O,V,TUPLE extends reactor.fn.tuple.Tuple> - Class in reactor.rx.action.combination
 
CombineLatestAction(Dispatcher, Function<TUPLE, ? extends V>, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.CombineLatestAction
 
CombineLatestAction.InnerSubscriber<O,V> - Class in reactor.rx.action.combination
 
CombineLatestAction.Zippable<O> - Class in reactor.rx.action.combination
 
complete() - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.COMPLETE.
completeAccepted() - Method in class reactor.rx.Promise
 
COMPLETING - Static variable in class reactor.rx.action.combination.FanInAction
 
CompositeAction<E,O> - Class in reactor.rx.action
Create a Processor where a given head/tail couple is provided as a Stream (Input upstream) and Action (Output downstream).
CompositeAction(Action<E, ?>, Action<?, O>) - Constructor for class reactor.rx.action.CompositeAction
 
concat(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
ConcatAction<T> - Class in reactor.rx.action.combination
 
ConcatAction() - Constructor for class reactor.rx.action.combination.ConcatAction
 
concatMap(Function<? super O, Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
concatWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values from this current upstream and then on complete consume from the passed publisher.
consume() - Method in class reactor.rx.Stream
Instruct the stream to request the produced subscription indefinitely.
consume(long) - Method in class reactor.rx.Stream
Instruct the action to request upstream subscription if any for N elements.
consume(Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
consume(Consumer<? super O>, Consumer<? super Throwable>) - Method in class reactor.rx.Stream
Attach 2 Consumer to this Stream that will consume any values signaled by this Stream.
consume(Consumer<? super O>, Consumer<? super Throwable>, Consumer<Void>) - Method in class reactor.rx.Stream
Attach 3 Consumer to this Stream that will consume any values signaled by this Stream.
consumeLater() - Method in class reactor.rx.Stream
Defer a Controls operations ready to be requested.
consumeOn(Dispatcher, Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will consume any values accepted by this Stream.
consumeOn(Dispatcher, Consumer<? super O>, Consumer<? super Throwable>) - Method in class reactor.rx.Stream
Attach 2 Consumer to this Stream that will consume any values signaled by this Stream.
consumeOn(Dispatcher, Consumer<? super O>, Consumer<? super Throwable>, Consumer<Void>) - Method in class reactor.rx.Stream
Attach 3 Consumer to this Stream that will consume any values signaled by this Stream.
CONSUMER_UPDATER - Static variable in class reactor.rx.stream.io.ChronicleReaderStream
 
ConsumerAction<T> - Class in reactor.rx.action.terminal
 
ConsumerAction(long, Dispatcher, Consumer<? super T>, Consumer<? super Throwable>, Consumer<Void>) - Constructor for class reactor.rx.action.terminal.ConsumerAction
 
consumers - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
contains(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
containsKey(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
containsValue(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
control(Stream<E>, Consumer<Tuple2<Action<I, O>, ? super E>>) - Method in class reactor.rx.action.Action
Consume a Stream to allow for dynamic Action update.
Control - Interface in reactor.rx.action
An interface generally associated with a Stream terminal action such as Stream.consume(reactor.fn.Consumer)
count() - Method in class reactor.rx.Stream
Count accepted events for each batch and pass each accumulated long to the .
count(long) - Method in class reactor.rx.Stream
Count accepted events for each batch and pass each accumulated long to the .
CountAction<T> - Class in reactor.rx.action.metrics
 
CountAction(long) - Constructor for class reactor.rx.action.metrics.CountAction
 
create(Environment) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), ().
create(Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with Action.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then ready to broadcast values with (Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create() - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Dispatcher) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with Action.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment, Dispatcher) - Static method in class reactor.rx.broadcast.Broadcaster
Build a Broadcaster, ready to broadcast values with (Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create() - Static method in class reactor.rx.broadcast.SerializedBroadcaster
Build a Broadcaster, ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Environment) - Static method in class reactor.rx.broadcast.SerializedBroadcaster
Build a Broadcaster, ready to broadcast values, ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
create(Iterable<? extends T>) - Static method in class reactor.rx.stream.IterableStream
Create an Iterable Stream Publisher
create(MapStream.Operation) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K, V) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(MapStream.Operation, K, V, V) - Static method in class reactor.rx.stream.MapStream.Signal
 
create(long, long) - Static method in class reactor.rx.stream.RangeStream
Create a Range Stream Publisher
create(Publisher<T>) - Static method in class reactor.rx.Streams
Build a custom sequence Stream from the passed Publisher that will be subscribed on the first request from the new subscriber.
createFanInSubscription() - Method in class reactor.rx.action.combination.CombineLatestAction
 
createFanInSubscription() - Method in class reactor.rx.action.combination.FanInAction
 
createFanInSubscription() - Method in class reactor.rx.action.combination.ZipAction
 
createSubscriber() - Method in class reactor.rx.action.combination.CombineLatestAction
 
createSubscriber() - Method in class reactor.rx.action.combination.FanInAction
 
createSubscriber() - Method in class reactor.rx.action.combination.MergeAction
 
createSubscriber() - Method in class reactor.rx.action.combination.ZipAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.Action
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.action.Action
 
createSubscription(Subscriber<? super T>, CompletableQueue<T>) - Method in class reactor.rx.action.aggregation.CacheAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.action.control.FlowControlAction
 
createSubscription(Subscriber<? super Void>, boolean) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
createSubscription(Subscriber<? super Void>, boolean) - Method in class reactor.rx.action.terminal.ConsumerAction
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
createSubscription(Subscriber<? super O>, CompletableQueue<O>) - Method in class reactor.rx.broadcast.Broadcaster
 
createSubscription(Subscriber<? super O>, boolean) - Method in class reactor.rx.broadcast.Broadcaster
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.Action
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.aggregation.BatchAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.combination.CombineLatestAction
 
createTrackingSubscription(Subscription) - Method in class reactor.rx.action.combination.ZipAction
 
createWindowStream() - Method in class reactor.rx.action.aggregation.WindowAction
 
createWindowStream() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
createWindowStream(T) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
createWindowStream(T) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
createWith(BiConsumer<Long, SubscriberWithContext<T, Void>>) - Static method in class reactor.rx.Streams
Create a Stream reacting on requests with the passed BiConsumer
createWith(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>) - Static method in class reactor.rx.Streams
Create a Stream 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.
createWith(BiConsumer<Long, SubscriberWithContext<T, C>>, Function<Subscriber<? super T>, C>, Consumer<C>) - Static method in class reactor.rx.Streams
Create a Stream reacting on requests with the passed BiConsumer.
currentNextSignals - Variable in class reactor.rx.subscription.ReactiveSubscription
 
currentNextSignals() - Method in class reactor.rx.subscription.ReactiveSubscription
 
currentWindow() - Method in class reactor.rx.action.aggregation.WindowAction
 
currentWindow() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 

D

debug() - Method in class reactor.rx.action.Action
Print a debugged form of the root action relative to this one.
debug() - Method in class reactor.rx.action.CompositeAction
 
debug() - Method in interface reactor.rx.action.Control
Parse the materialized upstream source to fetch a materialized map form which allows for graph-style printing.
debug() - Method in class reactor.rx.action.support.TapAndControls
 
debug() - Method in class reactor.rx.Promise
 
decode(Codec<SRC, IN, ?>, Publisher<? extends SRC>) - Static method in class reactor.rx.IOStreams
Use the given Codec to decode any SRC data published by the publisher reference.
decode(Codec<O, V, ?>) - Method in class reactor.rx.Stream
Transform a sequence of codec source elements into codec input elements through Codec.decode(Publisher)
decrementWip() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
defaultIfEmpty(O) - Method in class reactor.rx.Stream
Create an operation that returns the passed value if the Stream has completed without any emitted signals.
DefaultIfEmptyAction<T> - Class in reactor.rx.action.transformation
 
DefaultIfEmptyAction(T) - Constructor for class reactor.rx.action.transformation.DefaultIfEmptyAction
 
DefaultSubscriber<O> - Class in reactor.rx.action.support
 
DefaultSubscriber() - Constructor for class reactor.rx.action.support.DefaultSubscriber
 
defer(Supplier<? extends Publisher<T>>) - Static method in class reactor.rx.Streams
Supply a Publisher everytime subscribe is called on the returned stream.
DeferredStream<T> - Class in reactor.rx.stream
A Publisher supplier that will call the passed supplier on each subscribe call.
DeferredStream(Supplier<? extends Publisher<T>>) - Constructor for class reactor.rx.stream.DeferredStream
 
deleteOnExit() - Method in class reactor.rx.stream.io.ChronicleStream
 
dematerialize() - Method in class reactor.rx.Stream
Transform the incoming onSubscribe, onNext, onError and onComplete signals into Signal.
DematerializeAction<T> - Class in reactor.rx.action.transformation
 
DematerializeAction() - Constructor for class reactor.rx.action.transformation.DematerializeAction
 
dispatcher - Variable in class reactor.rx.action.aggregation.BatchAction
 
dispatcher - Variable in class reactor.rx.action.combination.FanInAction
 
dispatcher - Variable in class reactor.rx.broadcast.Broadcaster
 
DispatcherAction<T> - Class in reactor.rx.action.control
 
DispatcherAction(Dispatcher, Dispatcher) - Constructor for class reactor.rx.action.control.DispatcherAction
 
dispatchOn(Environment) - Method in class reactor.rx.Stream
Assign a new Environment and its default Dispatcher to the returned Stream.
dispatchOn(Dispatcher) - Method in class reactor.rx.Stream
Assign a new Dispatcher to the returned Stream.
dispatchOn(Environment, Dispatcher) - Method in class reactor.rx.Stream
Assign the a new Dispatcher and an Environment to the returned Stream.
distinct() - Method in class reactor.rx.Stream
Create a new Stream that filters in only unique values.
distinct(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Create a new Stream that filters in only values having distinct keys computed by function
DistinctAction<T,V> - Class in reactor.rx.action.filter
 
DistinctAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.filter.DistinctAction
 
distinctUntilChanged() - Method in class reactor.rx.Stream
Create a new Stream that filters out consecutive equals values.
distinctUntilChanged(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Create a new Stream that filters out consecutive values having equal keys computed by function
DistinctUntilChangedAction<T,V> - Class in reactor.rx.action.filter
 
DistinctUntilChangedAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.filter.DistinctUntilChangedAction
 
doComplete() - Method in class reactor.rx.action.Action
 
doComplete() - Method in class reactor.rx.action.aggregation.BatchAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.CacheAction
 
doComplete() - Method in class reactor.rx.action.aggregation.LastAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doComplete() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doComplete() - Method in class reactor.rx.action.combination.CombineLatestAction
 
doComplete() - Method in class reactor.rx.action.combination.SwitchAction
 
doComplete() - Method in class reactor.rx.action.combination.ZipAction
 
doComplete() - Method in class reactor.rx.action.conditional.ExistsAction
 
doComplete() - Method in class reactor.rx.action.control.RepeatWhenAction
 
doComplete() - Method in class reactor.rx.action.error.RetryWhenAction
 
doComplete() - Method in class reactor.rx.action.filter.DistinctAction
 
doComplete() - Method in class reactor.rx.action.filter.ElementAtAction
 
doComplete() - Method in class reactor.rx.action.metrics.CountAction
 
doComplete() - Method in class reactor.rx.action.pair.ReduceByKeyAction
 
doComplete() - Method in class reactor.rx.action.passive.AfterAction
 
doComplete() - Method in class reactor.rx.action.passive.CallbackAction
 
doComplete() - Method in class reactor.rx.action.passive.FinallyAction
 
doComplete() - Method in class reactor.rx.action.passive.LoggerAction
 
doComplete() - Method in class reactor.rx.action.terminal.ConsumerAction
 
doComplete() - Method in class reactor.rx.action.transformation.DefaultIfEmptyAction
 
doComplete() - Method in class reactor.rx.action.transformation.GroupByAction
 
doComplete() - Method in class reactor.rx.action.transformation.MaterializeAction
 
doComplete() - Method in class reactor.rx.action.transformation.ScanAction
 
doComplete() - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
doError(Throwable) - Method in class reactor.rx.action.Action
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.CacheAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorReturnAction
 
doError(Throwable) - Method in class reactor.rx.action.error.ErrorWithValueAction
 
doError(Throwable) - Method in class reactor.rx.action.error.IgnoreErrorAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.AfterAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.FinallyAction
 
doError(Throwable) - Method in class reactor.rx.action.passive.LoggerAction
 
doError(Throwable) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doError(Throwable) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doError(Throwable) - Method in class reactor.rx.action.transformation.MaterializeAction
 
doError(Throwable) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
doFallbackNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doNext(I) - Method in class reactor.rx.action.Action
 
doNext(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.CacheAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.LastAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doNext(T) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doNext(CombineLatestAction.Zippable<O>) - Method in class reactor.rx.action.combination.CombineLatestAction
 
doNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.ConcatAction
 
doNext(Publisher<? extends I>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
doNext(O) - Method in class reactor.rx.action.combination.MergeAction
 
doNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.SwitchAction
 
doNext(ZipAction.Zippable<O>) - Method in class reactor.rx.action.combination.ZipAction
 
doNext(E) - Method in class reactor.rx.action.CompositeAction
 
doNext(T) - Method in class reactor.rx.action.conditional.ExistsAction
 
doNext(T) - Method in class reactor.rx.action.control.DispatcherAction
 
doNext(O) - Method in class reactor.rx.action.control.FlowControlAction
 
doNext(T) - Method in class reactor.rx.action.control.RepeatAction
 
doNext(T) - Method in class reactor.rx.action.control.RepeatWhenAction
 
doNext(T) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
doNext(T) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
doNext(T) - Method in class reactor.rx.action.error.ErrorReturnAction
 
doNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doNext(T) - Method in class reactor.rx.action.error.IgnoreErrorAction
 
doNext(T) - Method in class reactor.rx.action.error.RetryAction
 
doNext(T) - Method in class reactor.rx.action.error.RetryWhenAction
 
doNext(T) - Method in class reactor.rx.action.filter.DistinctAction
 
doNext(T) - Method in class reactor.rx.action.filter.DistinctUntilChangedAction
 
doNext(T) - Method in class reactor.rx.action.filter.ElementAtAction
 
doNext(T) - Method in class reactor.rx.action.filter.FilterAction
 
doNext(T) - Method in class reactor.rx.action.filter.SkipAction
 
doNext(T) - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
doNext(T) - Method in class reactor.rx.action.filter.TakeAction
 
doNext(T) - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
doNext(T) - Method in class reactor.rx.action.filter.TakeWhileAction
 
doNext(T) - Method in class reactor.rx.action.metrics.CountAction
 
doNext(T) - Method in class reactor.rx.action.metrics.ElapsedAction
 
doNext(T) - Method in class reactor.rx.action.metrics.TimestampAction
 
doNext(PushSubscription<Tuple2<K, V>>, Tuple2<K, V>) - Method in class reactor.rx.action.pair.ReduceByKeyAction
 
doNext(Tuple2<K, V>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
doNext(PushSubscription<Tuple2<K, V>>, Tuple2<K, V>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
doNext(T) - Method in class reactor.rx.action.passive.AfterAction
 
doNext(T) - Method in class reactor.rx.action.passive.CallbackAction
 
doNext(T) - Method in class reactor.rx.action.passive.FinallyAction
 
doNext(T) - Method in class reactor.rx.action.passive.LoggerAction
 
doNext(T) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doNext(T) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doNext(T) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doNext(T) - Method in class reactor.rx.action.transformation.DefaultIfEmptyAction
 
doNext(Signal<T>) - Method in class reactor.rx.action.transformation.DematerializeAction
 
doNext(T) - Method in class reactor.rx.action.transformation.GroupByAction
 
doNext(T) - Method in class reactor.rx.action.transformation.MapAction
 
doNext(T) - Method in class reactor.rx.action.transformation.MaterializeAction
 
doNext(T) - Method in class reactor.rx.action.transformation.ScanAction
 
doNext(Iterable<? extends T>) - Method in class reactor.rx.action.transformation.SplitAction
 
doNext(O) - Method in class reactor.rx.broadcast.Broadcaster
 
doNormalNext(T) - Method in class reactor.rx.action.error.ErrorAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.ErrorWithValueAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.FallbackAction
 
doNormalNext(T) - Method in class reactor.rx.action.error.TimeoutAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.Action
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferShiftWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.BufferWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.ConcatAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.FanInAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.combination.ZipAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.DispatcherAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.RepeatAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.control.RepeatWhenAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.error.RetryAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.metrics.ElapsedAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.passive.LoggerAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doOnSubscribe(Subscription) - Method in class reactor.rx.action.terminal.ConsumerAction
 
doRequest(long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
doRetry() - Method in class reactor.rx.action.control.RepeatWhenAction
 
doRetry() - Method in class reactor.rx.action.error.RetryWhenAction
 
doShutdown() - Method in class reactor.rx.action.Action
 
doShutdown() - Method in class reactor.rx.action.combination.SwitchAction
 
doShutdown() - Method in class reactor.rx.action.control.ThrottleRequestAction
 
doShutdown() - Method in class reactor.rx.action.error.TimeoutAction
 
doShutdown() - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
doShutdown() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
doStart() - Method in class reactor.rx.action.Action
 
doSwitch() - Method in class reactor.rx.action.error.FallbackAction
 
downstreamSubscription - Variable in class reactor.rx.action.Action
 
downstreamSubscription() - Method in class reactor.rx.action.Action
Get the current action child subscription
downstreamSubscription() - Method in class reactor.rx.Stream
Get the current action child subscription
draining - Variable in class reactor.rx.subscription.ReactiveSubscription
 
DropSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
DropSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.DropSubscription
 
DynamicMergeAction<I,O> - Class in reactor.rx.action.combination
 
DynamicMergeAction(FanInAction<I, ?, O, ? extends FanInAction.InnerSubscriber<I, ?, O>>) - Constructor for class reactor.rx.action.combination.DynamicMergeAction
 
dynamicMergeAction() - Method in class reactor.rx.action.combination.FanInAction
 

E

elapsed() - Method in class reactor.rx.Stream
Create a new Stream that accepts a Tuple2 of T1 Long timemillis and T2 associated data.
ElapsedAction<T> - Class in reactor.rx.action.metrics
 
ElapsedAction() - Constructor for class reactor.rx.action.metrics.ElapsedAction
 
elementAt(int) - Method in class reactor.rx.Stream
Create a new Stream that emits an item at a specified index from a source Stream
ElementAtAction<T> - Class in reactor.rx.action.filter
 
ElementAtAction(int) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
ElementAtAction(int, T) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
ElementAtAction(int, T, boolean) - Constructor for class reactor.rx.action.filter.ElementAtAction
 
elementAtOrDefault(int, O) - Method in class reactor.rx.Stream
Create a new Stream that emits an item at a specified index from a source Stream or default value when index is out of bounds
EMPTY - Static variable in class reactor.rx.stream.SingleValueStream
 
empty() - Static method in class reactor.rx.Streams
Build a Stream that will only emit a complete signal to any new subscriber.
encode(Codec<V, ?, O>) - Method in class reactor.rx.Stream
Transform a sequence of codec output elements into codec source elements through Codec.encode(Publisher)
entrySet() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
env(Environment) - Method in class reactor.rx.Stream
Assign an Environment to be provided to this Stream Subscribers
environment - Variable in class reactor.rx.broadcast.Broadcaster
 
equals(Object) - Method in class reactor.rx.action.Signal
 
equals(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
equals(Object) - Method in class reactor.rx.subscription.PushSubscription
 
equals(Object) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
error(Throwable) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.ERROR, and assigns it an exception.
error(Throwable) - Static method in class reactor.rx.Promises
Create synchronous Promise and use the given error to complete the Promise immediately.
error(Environment, Throwable) - Static method in class reactor.rx.Promises
Create a Promise and use the given error to complete the Promise immediately.
error(Environment, Dispatcher, Throwable) - Static method in class reactor.rx.Promises
Create a Promise and use the given error to complete the Promise immediately.
errorAccepted(Throwable) - Method in class reactor.rx.Promise
 
ErrorAction<T,E extends java.lang.Throwable> - Class in reactor.rx.action.error
 
ErrorAction(Class<E>, Consumer<? super E>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.ErrorAction
 
ErrorReturnAction<T,E extends java.lang.Throwable> - Class in reactor.rx.action.error
 
ErrorReturnAction(Class<E>, Function<? super E, ? extends T>) - Constructor for class reactor.rx.action.error.ErrorReturnAction
 
ErrorStream<O,T extends java.lang.Throwable> - Class in reactor.rx.stream
A Stream that emits a sigle error signal.
ErrorStream(T) - Constructor for class reactor.rx.stream.ErrorStream
 
ErrorWithValueAction<T,E extends java.lang.Throwable> - Class in reactor.rx.action.error
 
ErrorWithValueAction(Class<E>, BiConsumer<Object, ? super E>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.ErrorWithValueAction
 
evaluateCapacity(long) - Static method in class reactor.rx.action.Action
 
exists(Predicate<? super O>) - Method in class reactor.rx.Stream
Create a new Stream that emits true when any value satisfies a predicate and false otherwise
ExistsAction<T> - Class in reactor.rx.action.conditional
 
ExistsAction(Predicate<? super T>) - Constructor for class reactor.rx.action.conditional.ExistsAction
 

F

fail(T) - Static method in class reactor.rx.Streams
Build a Stream that will only emit an error signal to any new subscriber.
fallback - Variable in class reactor.rx.action.error.FallbackAction
 
FallbackAction<T> - Class in reactor.rx.action.error
 
FallbackAction(Publisher<? extends T>) - Constructor for class reactor.rx.action.error.FallbackAction
 
fanIn(FanInAction<T, ?, V, ? extends FanInAction.InnerSubscriber<T, ?, V>>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream calling the logic inside the provided fanInAction for complex merging strategies.
FanInAction<I,E,O,SUBSCRIBER extends FanInAction.InnerSubscriber<I,E,O>> - Class in reactor.rx.action.combination
The best moment of my life so far, not.
FanInAction(Dispatcher) - Constructor for class reactor.rx.action.combination.FanInAction
 
FanInAction(Dispatcher, List<? extends Publisher<? extends I>>) - Constructor for class reactor.rx.action.combination.FanInAction
 
FanInAction.InnerSubscriber<I,E,O> - Class in reactor.rx.action.combination
 
FanInSubscription<O,E,X,SUBSCRIBER extends FanInAction.InnerSubscriber<O,E,X>> - Class in reactor.rx.action.combination
 
FanInSubscription(Subscriber<? super E>) - Constructor for class reactor.rx.action.combination.FanInSubscription
 
FanInSubscription.InnerSubscription<O,E,SUBSCRIBER extends FanInAction.InnerSubscriber<O,E,?>> - Class in reactor.rx.action.combination
 
FanOutSubscription<O> - Class in reactor.rx.subscription
A composite subscription used to achieve pub/sub pattern.
FanOutSubscription(Stream<O>, PushSubscription<O>, PushSubscription<O>) - Constructor for class reactor.rx.subscription.FanOutSubscription
 
filter(Predicate<? super O>) - Method in class reactor.rx.Stream
Evaluate each accepted value against the given Predicate.
filter() - Method in class reactor.rx.Stream
Evaluate each accepted boolean value.
FilterAction<T> - Class in reactor.rx.action.filter
 
FilterAction(Predicate<? super T>) - Constructor for class reactor.rx.action.filter.FilterAction
 
FinallyAction<T> - Class in reactor.rx.action.passive
 
FinallyAction(Consumer<Signal<T>>) - Constructor for class reactor.rx.action.passive.FinallyAction
 
finallyDo(Consumer<Signal<O>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe terminal signal complete|error.
findOldestStream() - Method in class reactor.rx.Promise
 
findOldestUpstream(Class<P>) - Method in class reactor.rx.action.Action
Utility to find the most ancient subscribed Action.
first - Variable in class reactor.rx.action.aggregation.BatchAction
 
first(T) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, rfirst broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with .Broadcaster#onNext(Object), Broadcaster.onError(Throwable), ().
first(T, Environment) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with Broadcaster.onNext(Object), Broadcaster.onError(Throwable), ().
first(T, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with Action.onNext(Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
first(T, Environment, Dispatcher) - Static method in class reactor.rx.broadcast.BehaviorBroadcaster
Build a Broadcaster, first broadcasting the most recent signal then starting with the passed value, then ready to broadcast values with (Object), Broadcaster.onError(Throwable), Broadcaster.onComplete().
firstCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
firstCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
firstCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
flatMap(Function<? super O, ? extends Publisher<? extends V>>) - Method in class reactor.rx.Promise
Assign a Function that will either be invoked later, when the Promise is successfully completed with a value, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
flatMap(Function<? super O, ? extends Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
FlowControlAction<O> - Class in reactor.rx.action.control
 
FlowControlAction(Supplier<? extends CompletableQueue<O>>) - Constructor for class reactor.rx.action.control.FlowControlAction
 
flush - Variable in class reactor.rx.action.aggregation.BatchAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.BufferAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.SortAction
 
flushCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
flushConsumer - Variable in class reactor.rx.action.aggregation.BatchAction
 
fn - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
forEach(Consumer<FanInSubscription.InnerSubscription<O, E, SUBSCRIBER>>) - Method in class reactor.rx.action.combination.FanInSubscription
 
forEach(Consumer<PushSubscription<O>>) - Method in class reactor.rx.subscription.FanOutSubscription
 
from(Iterable<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
from(T[]) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed array on subscription request.
from(Future<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream that will only emit the result of the future and then complete.
from(Future<? extends T>, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit the result of the future and then complete.
FutureStream<T> - Class in reactor.rx.stream
A Stream that emits a result of a Future and then complete.
FutureStream(Future<? extends T>) - Constructor for class reactor.rx.stream.FutureStream
 
FutureStream(Future<? extends T>, long, TimeUnit) - Constructor for class reactor.rx.stream.FutureStream
 

G

generate(Supplier<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data is generated by the passed supplier on subscription request.
get() - Method in class reactor.rx.action.Signal
Retrieves the item associated with this (onNext) signal.
get() - Method in class reactor.rx.action.support.TapAndControls
 
get() - Method in class reactor.rx.Promise
Returns the value that completed this promise.
get(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
getBuffer() - Method in class reactor.rx.subscription.ReactiveSubscription
 
getBufferSize() - Method in class reactor.rx.subscription.ReactiveSubscription
 
getCapacity() - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION STATE --------------------------------------------------------------------------------------------------------
getCapacity() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
getCapacity() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
getCapacity() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
getCapacity() - Method in class reactor.rx.action.support.DefaultSubscriber
 
getCapacity() - Method in class reactor.rx.Promise
 
getCapacity() - Method in class reactor.rx.Stream
 
getCapacity() - Method in class reactor.rx.stream.LiftStream
 
getDelegate() - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
getDispatcher() - Method in class reactor.rx.action.aggregation.BatchAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
getDispatcher() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
getDispatcher() - Method in class reactor.rx.action.combination.FanInAction
 
getDispatcher() - Method in class reactor.rx.action.combination.SwitchAction
 
getDispatcher() - Method in class reactor.rx.action.control.DispatcherAction
 
getDispatcher() - Method in class reactor.rx.action.control.RepeatAction
 
getDispatcher() - Method in class reactor.rx.action.control.RepeatWhenAction
 
getDispatcher() - Method in class reactor.rx.action.error.RetryAction
 
getDispatcher() - Method in class reactor.rx.action.error.RetryWhenAction
 
getDispatcher() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
getDispatcher() - Method in class reactor.rx.action.terminal.ConsumerAction
 
getDispatcher() - Method in class reactor.rx.action.transformation.GroupByAction
 
getDispatcher() - Method in class reactor.rx.broadcast.Broadcaster
 
getDispatcher() - Method in class reactor.rx.Stream
Get the dispatcher used to execute signals on this Stream instance.
getDispatcher() - Method in class reactor.rx.stream.LiftStream
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowShiftAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowShiftWhenAction
 
getEnvironment() - Method in class reactor.rx.action.aggregation.WindowWhenAction
 
getEnvironment() - Method in class reactor.rx.action.transformation.GroupByAction
 
getEnvironment() - Method in class reactor.rx.Promise
 
getEnvironment() - Method in class reactor.rx.Stream
Get the assigned Environment.
getEnvironment() - Method in class reactor.rx.stream.LiftStream
 
getPublisher() - Method in class reactor.rx.subscription.PushSubscription
 
getPublisher() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
getSubscriber() - Method in class reactor.rx.subscription.PushSubscription
 
getSubscription() - Method in class reactor.rx.action.Action
Get the current upstream subscription if any
getSubscription() - Method in class reactor.rx.action.combination.FanInAction
 
getSubscription() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
getSubscription() - Method in class reactor.rx.action.Signal
Read the subscription associated with this (onSubscribe) signal.
getSubscriptions() - Method in class reactor.rx.subscription.FanOutSubscription
 
getSwitchSubscriber() - Method in class reactor.rx.action.combination.SwitchAction
 
getThrowable() - Method in class reactor.rx.action.Signal
Read the exception associated with this (onError) signal.
getTimer() - Method in class reactor.rx.Stream
Get the current timer available if any or try returning the shared Environment one (which may cause an exception if no Environment has been globally initialized)
getType() - Method in class reactor.rx.action.Signal
Read the type of this signal: Subscribe, Next, Error, or Complete
groupBy(Function<? super O, ? extends K>) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
GroupByAction<T,K> - Class in reactor.rx.action.transformation
Manage a dynamic registry of substreams for a given key extracted from the incoming data.
GroupByAction(Environment, Function<? super T, ? extends K>, Dispatcher) - Constructor for class reactor.rx.action.transformation.GroupByAction
 
groupByMap() - Method in class reactor.rx.action.transformation.GroupByAction
 
GroupedStream<K,T> - Class in reactor.rx.stream
The Stream will complete or fail whever the parent groupBy action terminates itself.
GroupedStream(K) - Constructor for class reactor.rx.stream.GroupedStream
 

H

hasError() - Method in class reactor.rx.action.Signal
Read whether this signal is on error and carries the cause.
hashCode() - Method in class reactor.rx.action.Signal
 
hashCode() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
hashCode() - Method in class reactor.rx.subscription.PushSubscription
 
hashCode() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
hasPublisher() - Method in class reactor.rx.subscription.PushSubscription
 
hasPublisher() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
hasValue() - Method in class reactor.rx.action.Signal
Has this signal an item associated with it ?
HOT_SUBSCRIPTION - Static variable in class reactor.rx.broadcast.Broadcaster
 

I

ignoreError() - Method in class reactor.rx.Stream
Connect an error-proof action that will transform an incoming error signal into a complete signal.
ignoreError(Predicate<? super Throwable>) - Method in class reactor.rx.Stream
Connect an error-proof action based on the given predicate matching the current error.
IgnoreErrorAction<T> - Class in reactor.rx.action.error
 
IgnoreErrorAction(Predicate<? super Throwable>) - Constructor for class reactor.rx.action.error.IgnoreErrorAction
 
index - Variable in class reactor.rx.action.aggregation.BatchAction
 
initUpstreamPublisherAndCapacity() - Method in class reactor.rx.action.combination.CombineLatestAction
 
initUpstreamPublisherAndCapacity() - Method in class reactor.rx.action.combination.FanInAction
 
InnerSubscription(Subscription, SUBSCRIBER) - Constructor for class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
input() - Method in class reactor.rx.action.CompositeAction
 
IOStreams - Class in reactor.rx
A Streams add-on to work with IO components such as ChronicleStreams.
isComplete() - Method in class reactor.rx.Promise
Indicates whether this Promise has been completed with either an error or a value
isComplete() - Method in class reactor.rx.subscription.FanOutSubscription
 
isComplete() - Method in class reactor.rx.subscription.PushSubscription
 
isComplete() - Method in class reactor.rx.subscription.ReactiveSubscription
 
isComplete() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
isEmpty() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
isEmpty() - Method in class reactor.rx.subscription.FanOutSubscription
 
isError() - Method in class reactor.rx.Promise
Indicates whether this Promise has been completed with an error.
isOnComplete() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onComplete event.
isOnError() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onError event.
isOnNext() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onNext event.
isOnSubscribe() - Method in class reactor.rx.action.Signal
Indicates whether this signal represents an onSubscribe event.
isPending() - Method in class reactor.rx.Promise
Indicates whether this Promise has yet to be completed with a value or an error.
isPublishing() - Method in class reactor.rx.action.Action
 
isPublishing() - Method in interface reactor.rx.action.Control
Check if the current stream is emitting any signal.
isPublishing() - Method in class reactor.rx.action.support.TapAndControls
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.aggregation.BatchAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.DispatcherAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.FlowControlAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.support.DefaultSubscriber
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.action.terminal.ConsumerAction
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.Promise
 
isReactivePull(Dispatcher, long) - Method in class reactor.rx.Stream
 
isSuccess() - Method in class reactor.rx.Promise
Indicates whether this Promise has been successfully completed a value.
IterableStream<T> - Class in reactor.rx.stream
A Stream that emits Iterable values one by one and then complete.
IterableStream() - Constructor for class reactor.rx.stream.IterableStream
 

J

join() - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
join(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(List<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
join(Publisher<? extends Publisher<T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are aggregated from the passed publishers (1 element consumed for each merged publisher.
joinWith(Publisher<? extends V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
joinZipper() - Static method in class reactor.rx.action.combination.ZipAction
 
just(T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by the passed element on subscription request.
just(T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.
just(T, T, T, T, T, T, T, T) - Static method in class reactor.rx.Streams
Build a Stream whom data is sourced by each element of the passed iterable on subscription request.

K

keepAlive() - Method in class reactor.rx.Stream
Prevent a Stream to be cancelled.
key() - Method in class reactor.rx.stream.GroupedStream
 
key(K) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
key() - Method in class reactor.rx.stream.MapStream.Signal
 
keyCodec - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
keyCodec() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
keySet() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 

L

last() - Method in class reactor.rx.Stream
Create a new Stream that will signal the last element observed before complete signal.
LastAction<T> - Class in reactor.rx.action.aggregation
 
LastAction() - Constructor for class reactor.rx.action.aggregation.LastAction
 
leftIndex - Variable in class reactor.rx.action.combination.FanInSubscription
 
lift(Supplier<? extends Action<O, V>>) - Method in class reactor.rx.Stream
Defer the subscription of an Action to the actual pipeline.
LiftStream<O,V> - Class in reactor.rx.stream
A Stream wrapper that defers a parent stream subscription to the child action subscribe() call.
LiftStream(Stream<O>, Supplier<? extends Action<O, V>>) - Constructor for class reactor.rx.stream.LiftStream
 
localCache - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
localCache() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
log() - Method in class reactor.rx.Stream
Attach a java.util.logging.Logger to this Stream that will observe any signal emitted.
log(String) - Method in class reactor.rx.Stream
Attach a java.util.logging.Logger to this Stream that will observe any signal emitted.
LoggerAction<T> - Class in reactor.rx.action.passive
 
LoggerAction(String) - Constructor for class reactor.rx.action.passive.LoggerAction
 

M

map(Function<? super O, V>) - Method in class reactor.rx.Promise
Assign a Function that will either be invoked later, when the Promise is successfully completed with a value, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
map(Function<? super O, ? extends V>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a V and pass it into another Stream.
MapAction<T,V> - Class in reactor.rx.action.transformation
 
MapAction(Function<? super T, ? extends V>) - Constructor for class reactor.rx.action.transformation.MapAction
 
mapListener - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
MapStream<K,V> - Class in reactor.rx.stream
A SubscribableMap is an event-driven Map that signals logged operations to its subscribers.
MapStream() - Constructor for class reactor.rx.stream.MapStream
 
MapStream.MutableSignal<K,V> - Class in reactor.rx.stream
 
MapStream.Operation - Enum in reactor.rx.stream
 
MapStream.Signal<K,V> - Class in reactor.rx.stream
 
markAsDeferredStart() - Method in class reactor.rx.subscription.PushSubscription
 
markAsStarted() - Method in class reactor.rx.subscription.PushSubscription
 
materialize() - Method in class reactor.rx.Stream
Transform the incoming onSubscribe, onNext, onError and onComplete signals into Signal.
MaterializeAction<T> - Class in reactor.rx.action.transformation
 
MaterializeAction() - Constructor for class reactor.rx.action.transformation.MaterializeAction
 
maxCapacity(long) - Method in class reactor.rx.subscription.PushSubscription
 
maxCapacity - Variable in class reactor.rx.subscription.ReactiveSubscription
 
maxCapacity(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
maxCapacity(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
merge() - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream.
merge(Iterable<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
merge(Publisher<? extends Publisher<E>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
merge(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
MergeAction<O> - Class in reactor.rx.action.combination
 
MergeAction(Dispatcher) - Constructor for class reactor.rx.action.combination.MergeAction
 
MergeAction(Dispatcher, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.MergeAction
 
MergeAction.InnerSubscriber<I> - Class in reactor.rx.action.combination
 
mergedStream() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
mergeWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values from this current upstream and from the passed publisher.
MutableSignal() - Constructor for class reactor.rx.stream.MapStream.MutableSignal
 

N

name - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
nest() - Method in class reactor.rx.Stream
Create a new Stream whose only value will be the current instance of the Stream.
never() - Static method in class reactor.rx.Streams
Build a Stream that will never emit anything.
next - Variable in class reactor.rx.action.aggregation.BatchAction
 
next(T) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.NEXT, and assigns it a value.
next() - Method in class reactor.rx.Stream
Return the promise of the next triggered signal.
nextCallback(T) - Method in class reactor.rx.action.aggregation.BatchAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.BufferAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.SampleAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.SortAction
 
nextCallback(T) - Method in class reactor.rx.action.aggregation.WindowAction
 
NO_CAPACITY - Static variable in class reactor.rx.action.Action
 
NOT_STARTED - Static variable in class reactor.rx.action.combination.FanInAction
 

O

observe(Consumer<? super O>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any values accepted by this Stream.
observeCancel(Consumer<Void>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any cancel signal
observeComplete(Consumer<Void>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any complete signal
observeError(Class<E>, BiConsumer<Object, ? super E>) - Method in class reactor.rx.Stream
Assign an error handler that will pass eventual associated values and exceptions of the given type.
observeStart(Consumer<? super Subscription>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any onSubscribe signal
observeSubscribe(Consumer<? super Subscriber<? super O>>) - Method in class reactor.rx.Stream
Attach a Consumer to this Stream that will observe any subscribe signal
onComplete() - Method in class reactor.rx.action.Action
 
onComplete() - Method in class reactor.rx.action.combination.ConcatAction
 
onComplete() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onComplete() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
onComplete() - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onComplete() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onComplete() - Method in class reactor.rx.action.CompositeAction
 
onComplete() - Method in class reactor.rx.action.control.DispatcherAction
 
onComplete() - Method in class reactor.rx.action.control.RepeatAction
 
onComplete() - Method in class reactor.rx.action.control.RepeatWhenAction
 
onComplete() - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
onComplete() - Method in class reactor.rx.action.support.DefaultSubscriber
 
onComplete() - Method in class reactor.rx.broadcast.Broadcaster
 
onComplete() - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onComplete(Consumer<Promise<O>>) - Method in class reactor.rx.Promise
Assign a Consumer that will either be invoked later, when the Promise is completed by either setting a value or propagating an error, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
onComplete() - Method in class reactor.rx.Promise
 
onComplete() - Method in class reactor.rx.subscription.FanOutSubscription
 
onComplete() - Method in class reactor.rx.subscription.PushSubscription
 
onComplete() - Method in class reactor.rx.subscription.ReactiveSubscription
 
onError(Throwable) - Method in class reactor.rx.action.Action
 
onError(Throwable) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onError(Throwable) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
onError(Throwable) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onError(Throwable) - Method in class reactor.rx.action.CompositeAction
 
onError(Throwable) - Method in class reactor.rx.action.control.DispatcherAction
 
onError(Throwable) - Method in class reactor.rx.action.control.FlowControlAction
 
onError(Throwable) - Method in class reactor.rx.action.error.RetryAction
 
onError(Throwable) - Method in class reactor.rx.action.error.RetryWhenAction
 
onError(Throwable) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onError(Throwable) - Method in class reactor.rx.broadcast.Broadcaster
 
onError(Throwable) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onError(Consumer<Throwable>) - Method in class reactor.rx.Promise
Assign a Consumer that will either be invoked later, when the Promise is completed with an error, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
onError(Throwable) - Method in class reactor.rx.Promise
 
onError(Throwable) - Method in class reactor.rx.subscription.FanOutSubscription
 
onError(Throwable) - Method in class reactor.rx.subscription.PushSubscription
 
onErrorResumeNext(Publisher<? extends O>) - Method in class reactor.rx.Stream
Subscribe to a fallback publisher when any exception occurs.
onErrorResumeNext(Class<E>, Publisher<? extends O>) - Method in class reactor.rx.Stream
Subscribe to a fallback publisher when exceptions of the given type occur, otherwise propagate the error.
onErrorReturn(Function<Throwable, ? extends O>) - Method in class reactor.rx.Stream
Produce a default value if any exception occurs.
onErrorReturn(Class<E>, Function<E, ? extends O>) - Method in class reactor.rx.Stream
Produce a default value when exceptions of the given type occur, otherwise propagate the error.
onLift() - Method in class reactor.rx.stream.LiftStream
 
onNext(I) - Method in class reactor.rx.action.Action
 
onNext(O) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
onNext(Publisher<? extends I>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onNext(E) - Method in class reactor.rx.action.combination.FanInAction
 
onNext(I) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
onNext(Publisher<? extends T>) - Method in class reactor.rx.action.combination.SwitchAction
 
onNext(T) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onNext(O) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onNext(E) - Method in class reactor.rx.action.CompositeAction
 
onNext(T) - Method in class reactor.rx.action.control.DispatcherAction
 
onNext(O) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onNext(O) - Method in class reactor.rx.broadcast.BehaviorBroadcaster
 
onNext(O) - Method in class reactor.rx.broadcast.Broadcaster
 
onNext(O) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onNext(O) - Method in class reactor.rx.Promise
 
onNext(O) - Method in class reactor.rx.subscription.DropSubscription
 
onNext(O) - Method in class reactor.rx.subscription.FanOutSubscription
 
onNext(O) - Method in class reactor.rx.subscription.PushSubscription
 
onNext(O) - Method in class reactor.rx.subscription.ReactiveSubscription
 
onOverflowBuffer(Supplier<? extends CompletableQueue<O>>) - Method in class reactor.rx.action.Action
 
onOverflowBuffer() - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of buffering incoming values if not enough demand is signaled downstream.
onOverflowBuffer(Supplier<? extends CompletableQueue<O>>) - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of buffering incoming values if not enough demand is signaled downstream.
onOverflowDrop() - Method in class reactor.rx.Stream
Attach a No-Op Action that only serves the purpose of dropping incoming values if not enough demand is signaled downstream.
onPut() - Method in class reactor.rx.stream.MapStream
Return a Stream of key/value tuples for only new or updated entries.
onRemove() - Method in class reactor.rx.stream.MapStream
Return a Stream of key/value tuples for only removed entries.
onRequest(long) - Method in class reactor.rx.action.combination.FanInSubscription
 
onRequest(long) - Method in class reactor.rx.subscription.PushSubscription
 
onRequest(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
onSubscribe(Subscription) - Method in class reactor.rx.action.Action
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.FanInSubscription
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.action.CompositeAction
 
onSubscribe(Subscription) - Method in class reactor.rx.action.support.DefaultSubscriber
 
onSubscribe(Subscription) - Method in class reactor.rx.broadcast.Broadcaster
 
onSubscribe(Subscription) - Method in class reactor.rx.broadcast.SerializedBroadcaster
 
onSubscribe(Subscription) - Method in class reactor.rx.Promise
 
onSuccess(Consumer<O>) - Method in class reactor.rx.Promise
Assign a Consumer that will either be invoked later, when the Promise is successfully completed with a value, or, if this Promise has already been fulfilled, is immediately scheduled to be executed on the current Dispatcher.
op(MapStream.Operation) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
op() - Method in class reactor.rx.stream.MapStream.Signal
 
output() - Method in class reactor.rx.action.CompositeAction
 

P

pair() - Method in class reactor.rx.stream.MapStream.Signal
 
parallelRequest(long) - Method in class reactor.rx.action.combination.FanInSubscription
 
partition() - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
partition(int) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream for each unique key evaluated by the {param keyMapper}.
peek() - Method in class reactor.rx.action.combination.FanInSubscription
 
PENDING_UPDATER - Static variable in class reactor.rx.subscription.PushSubscription
 
pendingRequestSignals - Variable in class reactor.rx.subscription.PushSubscription
 
pendingRequestSignals() - Method in class reactor.rx.subscription.PushSubscription
 
period(long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after on each period from the subscribe call.
period(Timer, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after on each period from the subscribe call.
period(long, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
period(Timer, long, long) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
period(long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(Timer, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(long, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the subscribe call on each period.
period(Timer, long, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will emit ever increasing counter from 0 after the time delay on each period.
PeriodicTimerStream - Class in reactor.rx.stream
A Stream that emits 0 after an initial delay and ever incrementing long counter if the period argument is specified.
PeriodicTimerStream(long, long, TimeUnit, Timer) - Constructor for class reactor.rx.stream.PeriodicTimerStream
 
persistentMap(String) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
persistentMap(String, boolean) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
persistentMapReader(String) - Static method in class reactor.rx.IOStreams
A Persistent Map is a MapStream that fulfill both the Map and the Stream contract.
poll() - Method in class reactor.rx.Promise
Block the calling thread, waiting for the completion of this Promise.
poll(long, TimeUnit) - Method in class reactor.rx.Promise
Block the calling thread for the specified time, waiting for the completion of this Promise.
prepare() - Static method in class reactor.rx.Promises
Create a synchronous Promise.
prepare(Environment) - Static method in class reactor.rx.Promises
Create a Promise.
previous(V) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
previous() - Method in class reactor.rx.stream.MapStream.Signal
 
process(Processor<O, E>) - Method in class reactor.rx.Stream
Create a Tap that maintains a reference to the last value seen by this Stream.
Promise<O> - Class in reactor.rx
A Promise is a stateful event container that accepts a single value or error.
Promise() - Constructor for class reactor.rx.Promise
Creates a new unfulfilled promise.
Promise(Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new unfulfilled promise.
Promise(O, Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new promise that has been fulfilled with the given value.
Promise(Throwable, Dispatcher, Environment) - Constructor for class reactor.rx.Promise
Creates a new promise that has failed with the given error.
Promise.FinalState - Enum in reactor.rx
 
Promises - Class in reactor.rx
Helper methods for creating Promise instances.
Promises() - Constructor for class reactor.rx.Promises
 
publisher - Variable in class reactor.rx.subscription.PushSubscription
 
PublisherStream<T> - Class in reactor.rx.stream
A Publisher wrapper that takes care of lazy subscribing.
PublisherStream(Publisher<T>) - Constructor for class reactor.rx.stream.PublisherStream
 
PushSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
PushSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.PushSubscription
 
pushSubscription - Variable in class reactor.rx.subscription.support.WrappedSubscription
 
put(K, V) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
put(K, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
putAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
putAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleStream
 

R

range(long, long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit a sequence of longs within the specified range and then complete.
RangeStream - Class in reactor.rx.stream
A Stream that emits N Long from the inclusive start value defined to the inclusive end and then complete.
RangeStream() - Constructor for class reactor.rx.stream.RangeStream
 
ReactiveSubscription<O> - Class in reactor.rx.subscription
Relationship between a Stream (Publisher) and a Subscriber.
ReactiveSubscription(Stream<O>, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.ReactiveSubscription
 
ReactiveSubscription(Stream<O>, Subscriber<? super O>, CompletableQueue<O>) - Constructor for class reactor.rx.subscription.ReactiveSubscription
 
reactor.rx - package reactor.rx
Streams are reactive components derived from Reactive Extensions and implementing Reactive Streams specification.
reactor.rx.action - package reactor.rx.action
Actions are Reactive Streams components derived from Reactive Extensions and beyond.
reactor.rx.action.aggregation - package reactor.rx.action.aggregation
 
reactor.rx.action.combination - package reactor.rx.action.combination
 
reactor.rx.action.conditional - package reactor.rx.action.conditional
 
reactor.rx.action.control - package reactor.rx.action.control
 
reactor.rx.action.error - package reactor.rx.action.error
 
reactor.rx.action.filter - package reactor.rx.action.filter
 
reactor.rx.action.metrics - package reactor.rx.action.metrics
 
reactor.rx.action.pair - package reactor.rx.action.pair
 
reactor.rx.action.passive - package reactor.rx.action.passive
 
reactor.rx.action.support - package reactor.rx.action.support
 
reactor.rx.action.terminal - package reactor.rx.action.terminal
 
reactor.rx.action.transformation - package reactor.rx.action.transformation
 
reactor.rx.broadcast - package reactor.rx.broadcast
Broadcasters are akin to Reactive Extensions Subject.
reactor.rx.stream - package reactor.rx.stream
 
reactor.rx.stream.io - package reactor.rx.stream.io
Stream implementations that provide for IO access, for instance read/read-write persisting streams
reactor.rx.subscription - package reactor.rx.subscription
 
reactor.rx.subscription.support - package reactor.rx.subscription.support
 
ready(Environment, Dispatcher) - Static method in class reactor.rx.Promises
Create a Promise.
reason() - Method in class reactor.rx.Promise
Return the error (if any) that has completed this Promise.
recover(Class<? extends Throwable>, Subscriber<Object>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair if the exception is of the given type.
recycle() - Method in class reactor.rx.action.Action
 
recycle() - Method in class reactor.rx.broadcast.Broadcaster
 
reduce(BiFunction<O, O, O>) - Method in class reactor.rx.Stream
Reduce the values passing through this Stream into an object T.
reduce(A, BiFunction<A, ? super O, A>) - Method in class reactor.rx.Stream
Reduce the values passing through this Stream into an object A.
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, MapStream<KEY, VALUE>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
reduceByKey(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
ReduceByKeyAction<K,V> - Class in reactor.rx.action.pair
 
ReduceByKeyAction(BiFunction<? super V, ? super V, V>, MapStream<K, V>) - Constructor for class reactor.rx.action.pair.ReduceByKeyAction
 
ReduceByKeyAction(BiFunction<? super V, ? super V, V>, Map<K, V>, Publisher<? extends MapStream.Signal<K, V>>) - Constructor for class reactor.rx.action.pair.ReduceByKeyAction
 
reduceByKeyOn(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
remove(Object) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
remove(Object) - Method in class reactor.rx.stream.io.ChronicleStream
 
remove(PushSubscription<O>) - Method in class reactor.rx.subscription.FanOutSubscription
 
repeat() - Method in class reactor.rx.Stream
Create a new Stream which will keep re-subscribing its oldest parent-child stream pair on complete.
repeat(int) - Method in class reactor.rx.Stream
Create a new Stream which will keep re-subscribing its oldest parent-child stream pair on complete.
RepeatAction<T> - Class in reactor.rx.action.control
 
RepeatAction(Dispatcher, int, Publisher<? extends T>) - Constructor for class reactor.rx.action.control.RepeatAction
 
repeatWhen(Function<? super Stream<? extends Long>, ? extends Publisher<?>>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair if the backOff stream produced by the passed mapper emits any next signal.
RepeatWhenAction<T> - Class in reactor.rx.action.control
 
RepeatWhenAction(Dispatcher, Function<? super Stream<? extends Long>, ? extends Publisher<?>>, Publisher<? extends T>) - Constructor for class reactor.rx.action.control.RepeatWhenAction
 
request(long) - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
request(long) - Method in class reactor.rx.action.combination.FanInSubscription.InnerSubscription
 
request(long) - Method in class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
request(long) - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
request(long) - Method in class reactor.rx.subscription.BatchSubscription
 
request(long) - Method in class reactor.rx.subscription.DropSubscription
 
request(long) - Method in class reactor.rx.subscription.PushSubscription
 
request(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
request(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
requestAll() - Method in class reactor.rx.action.Action
 
requestAll() - Method in interface reactor.rx.action.Control
Usually requests Long.MAX_VALUE, which instructs a stream to never end until completed or cancelled.
requestAll() - Method in class reactor.rx.action.support.TapAndControls
 
REQUESTED_UPDATER - Static variable in class reactor.rx.action.combination.DynamicMergeAction
 
requestMore(long) - Method in class reactor.rx.action.Action
 
requestMore(long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
requestMore(long) - Method in class reactor.rx.action.combination.FanInAction
 
requestMore(long) - Method in class reactor.rx.action.control.DispatcherAction
 
requestMore(long) - Method in class reactor.rx.action.control.RepeatAction
 
requestMore(long) - Method in class reactor.rx.action.control.RepeatWhenAction
 
requestMore(long) - Method in interface reactor.rx.action.Control
Request the next n elements from the source
requestMore(long) - Method in class reactor.rx.action.control.ThrottleRequestAction
 
requestMore(long) - Method in class reactor.rx.action.control.ThrottleRequestWhenAction
 
requestMore(long) - Method in class reactor.rx.action.error.RetryAction
 
requestMore(long) - Method in class reactor.rx.action.error.TimeoutAction
 
requestMore(long) - Method in class reactor.rx.action.filter.TakeAction
 
requestMore(long) - Method in class reactor.rx.action.passive.LoggerAction
 
requestMore(long) - Method in class reactor.rx.action.support.TapAndControls
 
requestMore(long) - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
requestMore(long) - Method in class reactor.rx.action.terminal.ConsumerAction
 
requestMore(long) - Method in class reactor.rx.action.transformation.GroupByAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.Action
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.ConcatAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.FanInAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.SwitchAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.combination.ZipAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.control.DispatcherAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.action.error.FallbackAction
 
requestUpstream(long, boolean, long) - Method in class reactor.rx.broadcast.Broadcaster
 
requestWhen(Function<? super Stream<? extends Long>, ? extends Publisher<? extends Long>>) - Method in class reactor.rx.Stream
Request the parent stream every time the passed throttleStream signals a Long request volume.
RESERVED_SLOTS - Static variable in class reactor.rx.action.Action
onComplete, onError, request, onSubscribe are dispatched events, therefore up to capacity + 4 events can be in-flight stacking into a Dispatcher.
retry() - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(int) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(Predicate<Throwable>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
retry(int, Predicate<Throwable>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair.
RetryAction<T> - Class in reactor.rx.action.error
 
RetryAction(Dispatcher, int, Predicate<Throwable>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.RetryAction
 
retryStream() - Method in class reactor.rx.action.error.RetryWhenAction
 
retryWhen(Function<? super Stream<? extends Throwable>, ? extends Publisher<?>>) - Method in class reactor.rx.Stream
Create a new Stream which will re-subscribe its oldest parent-child stream pair if the backOff stream produced by the passed mapper emits any next data or complete signal.
RetryWhenAction<T> - Class in reactor.rx.action.error
 
RetryWhenAction(Dispatcher, Function<? super Stream<? extends Throwable>, ? extends Publisher<?>>, Publisher<? extends T>) - Constructor for class reactor.rx.action.error.RetryWhenAction
 
RUNNING - Static variable in class reactor.rx.action.combination.FanInAction
 

S

sameOrNotEqual(V, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
sample() - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int, long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
sample(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the last value of each batch.
SampleAction<T> - Class in reactor.rx.action.aggregation
 
SampleAction(Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
SampleAction(Dispatcher, boolean, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
SampleAction(Dispatcher, int, boolean) - Constructor for class reactor.rx.action.aggregation.SampleAction
 
sampleFirst() - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int, long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
sampleFirst(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream whose values will be only the first value of each batch.
scan(BiFunction<O, O, O>) - Method in class reactor.rx.Stream
Scan the values passing through this Stream into an object A.
scan(A, BiFunction<A, ? super O, A>) - Method in class reactor.rx.Stream
Scan the values passing through this Stream into an object A.
ScanAction<T,A> - Class in reactor.rx.action.transformation
 
ScanAction(A, BiFunction<A, ? super T, A>) - Constructor for class reactor.rx.action.transformation.ScanAction
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, MapStream<KEY, VALUE>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
scanByKey(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
ScanByKeyAction<K,V> - Class in reactor.rx.action.pair
 
ScanByKeyAction(BiFunction<? super V, ? super V, V>, MapStream<K, V>) - Constructor for class reactor.rx.action.pair.ScanByKeyAction
 
ScanByKeyAction(BiFunction<? super V, ? super V, V>, Map<K, V>, Publisher<? extends MapStream.Signal<K, V>>) - Constructor for class reactor.rx.action.pair.ScanByKeyAction
 
scanByKeyOn(Publisher<Tuple2<KEY, VALUE>>, Map<KEY, VALUE>, Publisher<? extends MapStream.Signal<KEY, VALUE>>, BiFunction<VALUE, VALUE, VALUE>) - Static method in class reactor.rx.BiStreams
 
scheduleCompletion() - Method in class reactor.rx.action.combination.FanInAction
 
serialComplete() - Method in class reactor.rx.action.combination.FanInSubscription
 
serialError(Throwable) - Method in class reactor.rx.action.combination.FanInSubscription
 
SerializedBroadcaster<O> - Class in reactor.rx.broadcast
A Broadcaster is a subclass of Stream which exposes methods for publishing values into the pipeline.
serializer - Variable in class reactor.rx.action.combination.FanInSubscription
 
serialNext(E) - Method in class reactor.rx.action.combination.FanInSubscription
 
shift(int) - Method in class reactor.rx.action.combination.FanInSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.PushSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.ReactiveSubscription
 
shouldRequestPendingSignals() - Method in class reactor.rx.subscription.support.WrappedSubscription
 
Signal<T> - Class in reactor.rx.action
A domain representation of a Reactive Stream signal.
Signal.Type - Enum in reactor.rx.action
 
simplePredicate - Static variable in class reactor.rx.action.filter.FilterAction
 
SingleTimerStream - Class in reactor.rx.stream
A Stream that emits 0 after an initial delay and then complete
SingleTimerStream(long, TimeUnit, Timer) - Constructor for class reactor.rx.stream.SingleTimerStream
 
SingleValueStream<T> - Class in reactor.rx.stream
A Stream that emits only one value and then complete.
SingleValueStream(T) - Constructor for class reactor.rx.stream.SingleValueStream
 
size() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
size() - Method in class reactor.rx.stream.io.ChronicleStream
 
skip(long) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to times.
skip(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to the specified .
skip(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements up to the specified .
SkipAction<T> - Class in reactor.rx.action.filter
 
SkipAction(Predicate<T>, long) - Constructor for class reactor.rx.action.filter.SkipAction
 
SkipUntilTimeout<T> - Class in reactor.rx.action.filter
 
SkipUntilTimeout(long, TimeUnit, Timer) - Constructor for class reactor.rx.action.filter.SkipUntilTimeout
 
skipWhile(Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements while is true.
skipWhile(long, Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will NOT signal next elements while is true or up to times.
sort() - Method in class reactor.rx.Stream
Stage incoming values into a java.util.PriorityQueue that will be re-ordered and signaled to the returned fresh Stream.
sort(int) - Method in class reactor.rx.Stream
Stage incoming values into a java.util.PriorityQueue that will be re-ordered and signaled to the returned fresh Stream.
sort(Comparator<? super O>) - Method in class reactor.rx.Stream
Stage incoming values into a java.util.PriorityQueue that will be re-ordered and signaled to the returned fresh Stream.
sort(int, Comparator<? super O>) - Method in class reactor.rx.Stream
Stage incoming values into a java.util.PriorityQueue that will be re-ordered and signaled to the returned fresh Stream.
SortAction<T> - Class in reactor.rx.action.aggregation
 
SortAction(Dispatcher, int, Comparator<? super T>) - Constructor for class reactor.rx.action.aggregation.SortAction
 
split() - Method in class reactor.rx.Stream
Create a new Stream whose values will be each element E of any Iterable flowing this Stream When a new batch is triggered, the last value of that next batch will be pushed into this Stream.
split(long) - Method in class reactor.rx.Stream
Create a new Stream whose values will be each element E of any Iterable flowing this Stream
SplitAction<T> - Class in reactor.rx.action.transformation
 
SplitAction() - Constructor for class reactor.rx.action.transformation.SplitAction
 
start() - Method in class reactor.rx.subscription.FanOutSubscription
 
start() - Method in class reactor.rx.subscription.PushSubscription
 
startWith(Iterable<O>) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
startWith(O) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
startWith(Publisher<? extends O>) - Method in class reactor.rx.Stream
Start emitting all items from the passed publisher then emits from the current stream.
store - Variable in class reactor.rx.action.pair.ScanByKeyAction
 
stream() - Method in class reactor.rx.Promise
 
Stream<O> - Class in reactor.rx
Base class for components designed to provide a succinct API for working with future values.
Stream() - Constructor for class reactor.rx.Stream
 
Streams - Class in reactor.rx
A public factory to build Stream, Streams provide for common transformations from a few structures such as Iterable or Future to a Stream, in addition to provide for combinatory operations (merge, switchOnNext...).
Streams() - Constructor for class reactor.rx.Streams
 
StreamStateCallbackAction<T> - Class in reactor.rx.action.passive
 
StreamStateCallbackAction(Consumer<? super Subscriber<? super T>>, Consumer<Void>, Consumer<? super Subscription>) - Constructor for class reactor.rx.action.passive.StreamStateCallbackAction
 
StreamUtils - Class in reactor.rx
A simple collection of utils to assist in various tasks such as Debugging
StreamUtils() - Constructor for class reactor.rx.StreamUtils
 
StreamUtils.StreamVisitor - Class in reactor.rx
 
StreamVisitor(StreamUtils.DebugVisitor) - Constructor for class reactor.rx.StreamUtils.StreamVisitor
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.Action
-------------------------------------------------------------------------------------------------------- ACTION SIGNAL HANDLING --------------------------------------------------------------------------------------------------------
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.combination.ConcatAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.combination.DynamicMergeAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.combination.FanInAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.combination.SwitchAction
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.action.CompositeAction
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.action.metrics.CountAction
 
subscribe(Subscriber<? super Tuple2<K, V>>) - Method in class reactor.rx.action.pair.ScanByKeyAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.passive.LoggerAction
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.action.passive.StreamStateCallbackAction
 
subscribe(Subscription) - Static method in class reactor.rx.action.Signal
Creates and returns a Signal of variety Type.COMPLETE.
subscribe(Subscriber<? super O>) - Method in class reactor.rx.Promise
 
subscribe(Subscriber<? super List<Object>>) - Method in class reactor.rx.stream.BarrierStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.DeferredStream
 
subscribe(Subscriber<? super O>) - Method in class reactor.rx.stream.ErrorStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.FutureStream
 
subscribe(Subscriber<? super MapStream.Signal<K, V>>) - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
subscribe(Subscriber<? super V>) - Method in class reactor.rx.stream.LiftStream
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.stream.PeriodicTimerStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.PublisherStream
 
subscribe(Subscriber<? super Long>) - Method in class reactor.rx.stream.SingleTimerStream
 
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.SingleValueStream
 
subscribe(CompositeAction<O, A>) - Method in class reactor.rx.Stream
Subscribe the CompositeAction.input() to this Stream.
subscribe(Subscriber<? super T>) - Method in class reactor.rx.stream.SupplierStream
 
subscribeOn(Environment) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscribeOn(Dispatcher, Subscriber<? super O>) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscribeOn(Dispatcher) - Method in class reactor.rx.Stream
Assign a new Dispatcher to handle upstream request to the returned Stream.
subscriber - Variable in class reactor.rx.subscription.PushSubscription
 
subscribeWithSubscription(Subscriber<? super O>, PushSubscription<O>) - Method in class reactor.rx.action.Action
Subscribe a given subscriber and pairs it with a given subscription instead of letting the Stream pick it automatically.
subscribeWithSubscription(Subscriber<? super T>, PushSubscription<T>) - Method in class reactor.rx.action.aggregation.CacheAction
 
subscribeWithSubscription(Subscriber<? super T>, PushSubscription<T>) - Method in class reactor.rx.action.combination.ConcatAction
 
subscribeWithSubscription(Subscriber<? super O>, PushSubscription<O>) - Method in class reactor.rx.broadcast.Broadcaster
 
subscription - Variable in class reactor.rx.Promise
 
subscription - Variable in class reactor.rx.subscription.support.WrappedSubscription
 
subscriptions - Variable in class reactor.rx.action.combination.FanInSubscription
 
success(T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
success() - Static method in class reactor.rx.Promises
Create a Promise already completed without any data.
success(Environment, T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
success(Environment, Dispatcher, T) - Static method in class reactor.rx.Promises
Create a Promise using the given value to complete the Promise immediately.
SupplierStream<T> - Class in reactor.rx.stream
A Stream that returns the result from Supplier.get() everytime it is requested via Subscription.request(long).
SupplierStream(Dispatcher, Supplier<? extends T>) - Constructor for class reactor.rx.stream.SupplierStream
 
SwitchAction<T> - Class in reactor.rx.action.combination
 
SwitchAction(Dispatcher) - Constructor for class reactor.rx.action.combination.SwitchAction
 
SwitchAction.SwitchSubscriber - Class in reactor.rx.action.combination
 
switchMap(Function<? super O, Publisher<? extends V>>) - Method in class reactor.rx.Stream
Assign the given Function to transform the incoming value T into a Stream<O,V> and pass it into another Stream.
switchOnNext() - Static method in class reactor.rx.Streams
Build a Synchronous Action whose data are emitted by the most recent Action.onNext(Object) signaled publisher.
switchOnNext(Dispatcher) - Static method in class reactor.rx.Streams
Build an Action whose data are emitted by the most recent Action.onNext(Object) signaled publisher.
switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class reactor.rx.Streams
Build a Synchronous Stream whose data are emitted by the most recent passed publisher.
switchOnNext(Publisher<? extends Publisher<? extends T>>, Dispatcher) - Static method in class reactor.rx.Streams
Build a Stream whose data are emitted by the most recent passed publisher.
SwitchSubscriber(Publisher<? extends T>) - Constructor for class reactor.rx.action.combination.SwitchAction.SwitchSubscriber
 
syncTask(Supplier<T>) - Static method in class reactor.rx.Promises
Create a synchronous Promise producing the value for the Promise using the given supplier.

T

take(long) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to times.
take(long, TimeUnit) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to the specified .
take(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements up to the specified .
TakeAction<T> - Class in reactor.rx.action.filter
 
TakeAction(long) - Constructor for class reactor.rx.action.filter.TakeAction
 
TakeUntilTimeout<T> - Class in reactor.rx.action.filter
 
TakeUntilTimeout(Dispatcher, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.filter.TakeUntilTimeout
 
takeWhile(Predicate<O>) - Method in class reactor.rx.Stream
Create a new Stream that will signal next elements while is true.
TakeWhileAction<T> - Class in reactor.rx.action.filter
 
TakeWhileAction(Predicate<T>) - Constructor for class reactor.rx.action.filter.TakeWhileAction
 
tap() - Method in class reactor.rx.Stream
Create a Tap that maintains a reference to the last value seen by this Stream.
TapAndControls<O> - Class in reactor.rx.action.support
 
TapAndControls(Tap<? extends O>, Control) - Constructor for class reactor.rx.action.support.TapAndControls
 
task(Environment, Supplier<T>) - Static method in class reactor.rx.Promises
Create a Promise producing the value for the Promise using the given supplier.
task(Environment, Dispatcher, Supplier<T>) - Static method in class reactor.rx.Promises
Create a Promise producing the value for the Promise using the given supplier.
TERMINAL_UPDATER - Static variable in class reactor.rx.subscription.PushSubscription
 
terminate() - Method in class reactor.rx.subscription.PushSubscription
 
terminated - Variable in class reactor.rx.action.combination.FanInSubscription
 
terminated - Variable in class reactor.rx.subscription.PushSubscription
 
throttle(long) - Method in class reactor.rx.Stream
Request once the parent stream every milliseconds.
throttle(long, Timer) - Method in class reactor.rx.Stream
Request once the parent stream every milliseconds after an initial .
ThrottleRequestAction<T> - Class in reactor.rx.action.control
 
ThrottleRequestAction(Dispatcher, Timer, long) - Constructor for class reactor.rx.action.control.ThrottleRequestAction
 
ThrottleRequestWhenAction<T> - Class in reactor.rx.action.control
 
ThrottleRequestWhenAction(Dispatcher, Function<? super Stream<? extends Long>, ? extends Publisher<? extends Long>>) - Constructor for class reactor.rx.action.control.ThrottleRequestWhenAction
 
timeout(long) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
timeout(long, TimeUnit) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
timeout(long, TimeUnit, Publisher<? extends O>) - Method in class reactor.rx.Stream
Switch to the fallback Publisher if no data has been emitted for milliseconds.
timeout(long, TimeUnit, Publisher<? extends O>, Timer) - Method in class reactor.rx.Stream
Signal an error if no data has been emitted for milliseconds.
TimeoutAction<T> - Class in reactor.rx.action.error
 
TimeoutAction(Dispatcher, Publisher<? extends T>, Timer, long) - Constructor for class reactor.rx.action.error.TimeoutAction
 
timer - Variable in class reactor.rx.action.aggregation.BatchAction
 
timer(long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(Timer, long) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timer(Timer, long, TimeUnit) - Static method in class reactor.rx.Streams
Build a Stream that will only emit 0l after the time delay and then complete.
timespan - Variable in class reactor.rx.action.aggregation.BatchAction
 
timestamp() - Method in class reactor.rx.Stream
Create a new Stream that accepts a Tuple2 of T1 Long system time in millis and T2 associated data
TimestampAction<T> - Class in reactor.rx.action.metrics
 
TimestampAction() - Constructor for class reactor.rx.action.metrics.TimestampAction
 
toBlockingQueue() - Method in class reactor.rx.Stream
Blocking call to pass values from this stream to the queue that can be polled from a consumer.
toBlockingQueue(int) - Method in class reactor.rx.Stream
Blocking call to eagerly fetch values from this stream
toBroadcastCompleteConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast complete signal from any accepted value.
toBroadcastErrorConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast error signal from any accepted value.
toBroadcastNextConsumer() - Method in class reactor.rx.action.Action
Create a consumer that broadcast next signal from accepted values.
toList() - Method in class reactor.rx.Stream
Fetch all values in a List to the returned Promise
toList(long) - Method in class reactor.rx.Stream
Return the promise of N signals collected into an array list.
toMap() - Method in class reactor.rx.StreamUtils.StreamVisitor
 
toString() - Method in class reactor.rx.action.Action
 
toString() - Method in class reactor.rx.action.aggregation.BatchAction
 
toString() - Method in class reactor.rx.action.aggregation.BufferShiftAction
 
toString() - Method in class reactor.rx.action.aggregation.SampleAction
 
toString() - Method in class reactor.rx.action.combination.CombineLatestAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.CombineLatestAction
 
toString() - Method in class reactor.rx.action.combination.DynamicMergeAction
 
toString() - Method in class reactor.rx.action.combination.FanInAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.FanInAction
 
toString() - Method in class reactor.rx.action.combination.FanInSubscription
 
toString() - Method in class reactor.rx.action.combination.MergeAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.ZipAction.InnerSubscriber
 
toString() - Method in class reactor.rx.action.combination.ZipAction
 
toString() - Method in class reactor.rx.action.combination.ZipAction.Zippable
 
toString() - Method in class reactor.rx.action.CompositeAction
 
toString() - Method in class reactor.rx.action.control.DispatcherAction
 
toString() - Method in class reactor.rx.action.error.ErrorAction
 
toString() - Method in class reactor.rx.action.error.ErrorReturnAction
 
toString() - Method in class reactor.rx.action.error.ErrorWithValueAction
 
toString() - Method in class reactor.rx.action.error.IgnoreErrorAction
 
toString() - Method in class reactor.rx.action.filter.SkipAction
 
toString() - Method in class reactor.rx.action.filter.SkipUntilTimeout
 
toString() - Method in class reactor.rx.action.filter.TakeAction
 
toString() - Method in class reactor.rx.action.filter.TakeUntilTimeout
 
toString() - Method in class reactor.rx.action.filter.TakeWhileAction
 
toString() - Method in class reactor.rx.action.passive.LoggerAction
 
toString() - Method in class reactor.rx.action.Signal
 
toString() - Method in class reactor.rx.action.terminal.AdaptiveConsumerAction
 
toString() - Method in class reactor.rx.action.terminal.ConsumerAction
 
toString() - Method in class reactor.rx.Promise
 
toString() - Method in class reactor.rx.stream.ErrorStream
 
toString() - Method in class reactor.rx.stream.GroupedStream
 
toString() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
toString() - Method in class reactor.rx.stream.LiftStream
 
toString() - Method in class reactor.rx.stream.MapStream.Signal
 
toString() - Method in class reactor.rx.stream.PeriodicTimerStream
 
toString() - Method in class reactor.rx.stream.SingleTimerStream
 
toString() - Method in class reactor.rx.stream.SingleValueStream
 
toString() - Method in class reactor.rx.Stream
 
toString() - Method in class reactor.rx.StreamUtils.StreamVisitor
 
toString() - Method in class reactor.rx.subscription.DropSubscription
 
toString() - Method in class reactor.rx.subscription.PushSubscription
 
toString() - Method in class reactor.rx.subscription.ReactiveSubscription
 
toString() - Method in class reactor.rx.subscription.support.WrappedSubscription
 

U

unbounded() - Method in class reactor.rx.Stream
Make this Stream subscribers unbounded
unit - Variable in class reactor.rx.action.aggregation.BatchAction
 
updatePendingRequests(long) - Method in class reactor.rx.subscription.PushSubscription
 
updatePendingRequests(long) - Method in class reactor.rx.subscription.ReactiveSubscription
 
updatePendingRequests(long) - Method in class reactor.rx.subscription.support.WrappedSubscription
 
upstreamSubscription - Variable in class reactor.rx.action.Action
The upstream request tracker to avoid dispatcher overrun, based on the current this#capacity

V

value(V) - Method in class reactor.rx.stream.MapStream.MutableSignal
 
value() - Method in class reactor.rx.stream.MapStream.Signal
 
valueAccepted(O) - Method in class reactor.rx.Promise
 
valueCodec - Variable in class reactor.rx.stream.io.ChronicleReaderStream
 
valueCodec() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
valueOf(String) - Static method in enum reactor.rx.action.Signal.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.rx.Promise.FinalState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum reactor.rx.stream.MapStream.Operation
Returns the enum constant of this type with the specified name.
values() - Static method in enum reactor.rx.action.Signal.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum reactor.rx.Promise.FinalState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class reactor.rx.stream.io.ChronicleReaderStream
 
values() - Static method in enum reactor.rx.stream.MapStream.Operation
Returns an array containing the constants of this enum type, in the order they are declared.

W

when(Promise<T1>, Promise<T2>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>, Promise<T7>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Promise<T1>, Promise<T2>, Promise<T3>, Promise<T4>, Promise<T5>, Promise<T6>, Promise<T7>, Promise<T8>) - Static method in class reactor.rx.Promises
Merge given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(List<? extends Promise<T>>) - Static method in class reactor.rx.Promises
Aggregate given promises into a new a Promise that will be fulfilled when all of the given Promise Promises have been fulfilled.
when(Class<E>, Consumer<E>) - Method in class reactor.rx.Stream
Assign an error handler to exceptions of the given type.
window() - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined Stream.getCapacity() times.
window(int) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined times.
window(int, int) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every skip and complete every time maxSize has been reached by any of them.
window(Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every and complete every time boundarySupplier stream emits an item.
window(Publisher<?>, Supplier<? extends Publisher<?>>) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every and complete every time boundarySupplier stream emits an item.
window(long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan.
window(long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan.
window(int, long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan OR maxSize items.
window(int, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into a dynamically created Stream every pre-defined timespan OR maxSize items.
window(long, long, TimeUnit) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every timeshift period.
window(long, long, TimeUnit, Timer) - Method in class reactor.rx.Stream
Re-route incoming values into bucket streams that will be pushed into the returned Stream every timeshift period.
WindowAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowAction(Environment, Dispatcher, int) - Constructor for class reactor.rx.action.aggregation.WindowAction
 
WindowAction(Environment, Dispatcher, int, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.WindowAction
 
WindowShiftAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowShiftAction(Environment, Dispatcher, int, int) - Constructor for class reactor.rx.action.aggregation.WindowShiftAction
 
WindowShiftAction(Environment, Dispatcher, int, int, long, long, TimeUnit, Timer) - Constructor for class reactor.rx.action.aggregation.WindowShiftAction
 
WindowShiftWhenAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until is reached, after that streams collected events further, complete it and create a fresh new stream.
WindowShiftWhenAction(Environment, Dispatcher, Publisher<?>, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.WindowShiftWhenAction
 
WindowWhenAction<T> - Class in reactor.rx.action.aggregation
WindowAction is forwarding events on a steam until returned stream emits a signal, after that streams collected events further, complete it and create a fresh new stream.
WindowWhenAction(Environment, Dispatcher, Supplier<? extends Publisher<?>>) - Constructor for class reactor.rx.action.aggregation.WindowWhenAction
 
WIP_UPDATER - Static variable in class reactor.rx.action.combination.DynamicMergeAction
 
wrap(Function<I, O>) - Method in class reactor.rx.stream.BarrierStream
 
wrap(Consumer<I>) - Method in class reactor.rx.stream.BarrierStream
 
wrap(Publisher<T>) - Static method in class reactor.rx.Streams
A simple decoration of the given Publisher to expose Stream API and proxy any subscribe call to the publisher.
wrap(Subscription, Subscriber<? super O>) - Static method in class reactor.rx.subscription.PushSubscription
Wrap the subscription behind a push subscription to start tracking its requests
WrappedSubscription<O> - Class in reactor.rx.subscription.support
 
WrappedSubscription(Subscription, Subscriber<? super O>) - Constructor for class reactor.rx.subscription.support.WrappedSubscription
 
writePut(K, V, V) - Method in class reactor.rx.stream.io.ChronicleStream
 
writePutAll(Map<? extends K, ? extends V>) - Method in class reactor.rx.stream.io.ChronicleStream
 
writeRemove(Object) - Method in class reactor.rx.stream.io.ChronicleStream
 

Z

zip(Function<TupleN, ? extends V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Function<Tuple2<T1, T2>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function<Tuple3<T1, T2, T3>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function<Tuple4<T1, T2, T3, T4>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function<Tuple5<T1, T2, T3, T4, T5>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function<Tuple6<T1, T2, T3, T4, T5, T6>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function<Tuple7<T1, T2, T3, T4, T5, T6, T7>, V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function<Tuple8<T1, T2, T3, T4, T5, T6, T7, T8>, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(List<? extends Publisher<?>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
zip(Publisher<? extends Publisher<E>>, Function<TUPLE, ? extends V>) - Static method in class reactor.rx.Streams
Build a Stream whose data are generated by the passed publishers.
ZipAction<O,V,TUPLE extends reactor.fn.tuple.Tuple> - Class in reactor.rx.action.combination
 
ZipAction(Dispatcher, Function<TUPLE, ? extends V>, List<? extends Publisher<? extends O>>) - Constructor for class reactor.rx.action.combination.ZipAction
 
ZipAction.InnerSubscriber<O,V> - Class in reactor.rx.action.combination
 
ZipAction.Zippable<O> - Class in reactor.rx.action.combination
 
Zippable(int, O) - Constructor for class reactor.rx.action.combination.CombineLatestAction.Zippable
 
Zippable(int, O) - Constructor for class reactor.rx.action.combination.ZipAction.Zippable
 
zipWith(Iterable<? extends T2>, Function<Tuple2<O, T2>, V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) all the nested Publisher values to a new Stream until one of them complete.
zipWith(Publisher<? extends T2>, Function<Tuple2<O, T2>, V>) - Method in class reactor.rx.Stream
Stream.lift(Supplier) with the passed Publisher values to a new Stream until one of them complete.
A B C D E F G H I J K L M N O P R S T U V W Z 
Skip navigation links