- failed(Throwable) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- failed(Throwable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- filter(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Filter elements emitted by this publisher using the given
Predicate
.
- filter(Predicate<? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Filter elements emitted by this publisher using the given
Predicate
.
- filter(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Filter elements emitted by this publisher using the given
Predicate
.
- FilteringOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operations for transforming a stream.
- findFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Find the first element emitted by the
Publisher
, and return it in a
CompletionStage
.
- findFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Find the first element emitted by the
Publisher
, and return it in a
CompletionStage
.
- findFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Find the first element emitted by the
Publisher
, and return it in a
CompletionStage
.
- flatMap(Function<? super R, ? extends PublisherBuilder<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- flatMap(Function<? super T, ? extends PublisherBuilder<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- flatMap(Function<? super T, ? extends PublisherBuilder<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- flatMapCompletionStage(Function<? super R, ? extends CompletionStage<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
- flatMapCompletionStage(Function<? super T, ? extends CompletionStage<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
- flatMapCompletionStage(Function<? super T, ? extends CompletionStage<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
- flatMapIterable(Function<? super R, ? extends Iterable<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Map the elements to
Iterable
's, and flatten so that the elements contained in each iterable are
emitted by this stream.
- flatMapIterable(Function<? super T, ? extends Iterable<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Map the elements to
Iterable
's, and flatten so that the elements contained in each iterable are
emitted by this stream.
- flatMapIterable(Function<? super T, ? extends Iterable<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
Map the elements to
Iterable
's, and flatten so that the elements contained in each iterable are
emitted by this stream.
- flatMapRsPublisher(Function<? super R, ? extends Publisher<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- flatMapRsPublisher(Function<? super T, ? extends Publisher<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- flatMapRsPublisher(Function<? super T, ? extends Publisher<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
Map the elements to publishers, and flatten so that the elements emitted by publishers produced by the
mapper
function are emitted from this stream.
- forEach(Consumer<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Performs an action for each element on this stream.
- forEach(Consumer<? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Performs an action for each element on this stream.
- forEach(Consumer<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Performs an action for each element on this stream.
- fromCompletionStage(CompletionStage<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromCompletionStage(CompletionStage<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- fromCompletionStageNullable(CompletionStage<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromCompletionStageNullable(CompletionStage<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- fromIterable(Iterable<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromIterable(Iterable<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- fromProcessor(Processor<? super T, ? extends R>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromProcessor(Processor<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- fromPublisher(Publisher<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromPublisher(Publisher<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- fromSubscriber(Subscriber<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- fromSubscriber(Subscriber<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- of(Subscriber<T>, CompletionStage<R>) - Static method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionSubscriber
-
- of(T) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- of(T...) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
- of(T) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- of(T...) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
- ofNullable(T) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
that will emit a single element if
t
is not null, otherwise will be
empty.
- ofNullable(T) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
PublisherBuilder
that will emit a single element if
t
is not null, otherwise will be
empty.
- onComplete(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PeekingOperators
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes.
- onComplete(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes.
- onComplete(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes.
- onError(Consumer<Throwable>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PeekingOperators
-
Returns a stream containing all the elements from this stream, additionally performing the provided action if this
stream conveys an error.
- onError(Consumer<Throwable>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action if this
stream conveys an error.
- onError(Consumer<Throwable>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action if this
stream conveys an error.
- onErrorResume(Function<Throwable, ? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ErrorHandlingOperators
-
Returns a stream containing all the elements from this stream.
- onErrorResume(Function<Throwable, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream.
- onErrorResume(Function<Throwable, ? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWith(Function<Throwable, ? extends PublisherBuilder<? extends T>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ErrorHandlingOperators
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWith(Function<Throwable, ? extends PublisherBuilder<? extends R>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWith(Function<Throwable, ? extends PublisherBuilder<? extends T>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWithRsPublisher(Function<Throwable, ? extends Publisher<? extends T>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ErrorHandlingOperators
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWithRsPublisher(Function<Throwable, ? extends Publisher<? extends R>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream.
- onErrorResumeWithRsPublisher(Function<Throwable, ? extends Publisher<? extends T>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream.
- onTerminate(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PeekingOperators
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes or failed.
- onTerminate(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes or failed.
- onTerminate(Runnable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Returns a stream containing all the elements from this stream, additionally performing the provided action when this
stream completes or failed.
- org.eclipse.microprofile.reactive.streams.operators - package org.eclipse.microprofile.reactive.streams.operators
-
- org.eclipse.microprofile.reactive.streams.operators.spi - package org.eclipse.microprofile.reactive.streams.operators.spi
-
- ReactiveStreams - Class in org.eclipse.microprofile.reactive.streams.operators
-
Primary entry point into the Reactive Streams utility API.
- ReactiveStreamsEngine - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
An engine for turning reactive streams graphs into Reactive Streams publishers/subscribers.
- ReactiveStreamsFactory - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Factory interface for providing the implementation of the static factory methods in
ReactiveStreams
.
- ReactiveStreamsFactoryResolver - Class in org.eclipse.microprofile.reactive.streams.operators.spi
-
This class is not intended to be used by end-users but for
portable container integration purpose only.
- ReactiveStreamsFactoryResolver() - Constructor for class org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsFactoryResolver
-
- reduce(T, BinaryOperator<T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Perform a reduction on the elements of this stream, using the provided identity value and the accumulation
function.
- reduce(BinaryOperator<T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Perform a reduction on the elements of this stream, using the provided accumulation function.
- reduce(R, BinaryOperator<R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Perform a reduction on the elements of this stream, using the provided identity value and the accumulation
function.
- reduce(BinaryOperator<R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Perform a reduction on the elements of this stream, using the provided accumulation function.
- reduce(T, BinaryOperator<T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Perform a reduction on the elements of this stream, using the provided identity value and the accumulation
function.
- reduce(BinaryOperator<T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Perform a reduction on the elements of this stream, using the provided accumulation function.
- run() - Method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionRunner
-
Run this stream, using the first
ReactiveStreamsEngine
found by the
ServiceLoader
.
- run(ReactiveStreamsEngine) - Method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionRunner
-
Run this stream, using the supplied ReactiveStreamsEngine
.
- setInstance(ReactiveStreamsFactory) - Static method in class org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsFactoryResolver
-
Set the instance.
- skip(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Discard the first n
of this stream.
- skip(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Discard the first n
of this stream.
- skip(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Discard the first n
of this stream.
- Stage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage of a Reactive Streams graph.
- Stage.Cancel - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A cancelling stage.
- Stage.Collect - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A collect stage.
- Stage.Concat - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
Concatenate the given graphs together.
- Stage.Coupled - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage that couples a wrapped subscriber graph to a wrapped publisher graph.
- Stage.Distinct - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage returning a stream consisting of the distinct elements (according to
Object.equals(Object)
) of this
stream.
- Stage.DropWhile - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A drop while stage.
- Stage.Failed - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A failed publisher.
- Stage.Filter - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A filter stage.
- Stage.FindFirst - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A subscriber stage that emits the first element encountered.
- Stage.FlatMap - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A flat map stage.
- Stage.FlatMapCompletionStage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
- Stage.FlatMapIterable - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A flat map stage that emits and fattens
Iterable
.
- Stage.FromCompletionStage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
- Stage.FromCompletionStageNullable - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
- Stage.Limit - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A limit stage.
- Stage.Map - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A map stage.
- Stage.Of - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A publisher of zero to many values.
- Stage.OnComplete - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage returning a stream containing all the elements from this stream, additionally performing the provided
action when this stream completes.
- Stage.OnError - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage returning a stream containing all the elements from this stream,
additionally performing the provided action if this stream conveys an error.
- Stage.OnErrorResume - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage to handle errors from upstream.
- Stage.OnErrorResumeWith - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage to handle errors from upstream.
- Stage.OnTerminate - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage returning a stream containing all the elements from this stream, additionally performing the provided
action if this stream terminates with an error, completes, or is cancelled by downstream.
- Stage.Peek - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A stage returning a stream containing all the elements from this stream,
additionally performing the provided action on each element.
- Stage.ProcessorStage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A processor stage.
- Stage.PublisherStage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A publisher stage.
- Stage.Skip - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A skip stage.
- Stage.SubscriberStage - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A subscriber.
- Stage.TakeWhile - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A take while stage.
- SubscriberBuilder<T,R> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
A builder for a Subscriber
and its result.
- SubscriberWithCompletionStage<T,R> - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A subscriber and completion stage pair.