Index
All Classes and Interfaces|All Packages|Serialized Form
B
- build() - Method in interface org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder
-
Build this stream, using the first
ReactiveStreamsEngine
found by theServiceLoader
. - build(ReactiveStreamsEngine) - Method in interface org.eclipse.microprofile.reactive.streams.operators.SubscriberBuilder
-
Build this stream, using the supplied
ReactiveStreamsEngine
. - buildCompletion(Graph) - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsEngine
-
Build a closed graph from the given stages.
- builder() - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
ProcessorBuilder
. - builder() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
ProcessorBuilder
. - buildProcessor(Graph) - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsEngine
-
Build a
Processor
from the given stages. - buildPublisher(Graph) - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsEngine
-
Build a
Publisher
from the given stages. - buildRs() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Build this stream, using the first
ReactiveStreamsEngine
found by theServiceLoader
. - buildRs() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Build this stream, using the first
ReactiveStreamsEngine
found by theServiceLoader
. - buildRs(ReactiveStreamsEngine) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Build this stream, using the supplied
ReactiveStreamsEngine
. - buildRs(ReactiveStreamsEngine) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Build this stream, using the supplied
ReactiveStreamsEngine
. - buildSubscriber(Graph) - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsEngine
-
Build a
Subscriber
from the given stages.
C
- cancel() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Cancels the stream as soon as it is run.
- cancel() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Cancels the stream as soon as it is run.
- cancel() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Cancels the stream as soon as it is run.
- collect(Supplier<R>, BiConsumer<R, ? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Collect the elements emitted by this stream using a
Collector
built from the givensupplier
andaccumulator
. - collect(Supplier<R>, BiConsumer<R, ? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Collect the elements emitted by this stream using a
Collector
built from the givensupplier
andaccumulator
. - collect(Supplier<S>, BiConsumer<S, ? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Collect the elements emitted by this stream using a
Collector
built from the givensupplier
andaccumulator
. - collect(Collector<? super R, A, S>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Collect the elements emitted by this stream using the given
Collector
. - collect(Collector<? super T, A, R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Collect the elements emitted by this stream using the given
Collector
. - collect(Collector<? super T, A, R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Collect the elements emitted by this stream using the given
Collector
. - CompletionRunner<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
A builder for a closed reactive streams graph.
- CompletionSubscriber<T,
R> - Interface in org.eclipse.microprofile.reactive.streams.operators -
A subscriber that redeems a completion stage when it completes.
- concat(PublisherBuilder<? extends T>, PublisherBuilder<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Concatenates two publishers.
- concat(PublisherBuilder<? extends T>, PublisherBuilder<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Concatenates two publishers.
- ConnectingOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operators for connecting different graphs together.
- ConsumingOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operators for completing a stream.
- coupled(SubscriberBuilder<? super T, ?>, PublisherBuilder<? extends R>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
- coupled(SubscriberBuilder<? super T, ?>, PublisherBuilder<? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
- coupled(Subscriber<? super T>, Publisher<? extends R>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
- coupled(Subscriber<? super T>, Publisher<? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
D
- distinct() - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Creates a stream consisting of the distinct elements (according to
Object.equals(Object)
) of this stream. - distinct() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Creates a stream consisting of the distinct elements (according to
Object.equals(Object)
) of this stream. - distinct() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Creates a stream consisting of the distinct elements (according to
Object.equals(Object)
) of this stream. - dropWhile(Predicate<? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Drop the longest prefix of elements from this stream that satisfy the given
predicate
. - dropWhile(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Drop the longest prefix of elements from this stream that satisfy the given
predicate
. - dropWhile(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Drop the longest prefix of elements from this stream that satisfy the given
predicate
.
E
- empty() - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create an empty
PublisherBuilder
. - empty() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create an empty
PublisherBuilder
. - ErrorHandlingOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operators for handling errors in streams.
F
- failed(Throwable) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a failed
PublisherBuilder
. - failed(Throwable) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a failed
PublisherBuilder
. - 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.FilteringOperators
-
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 aCompletionStage
. - findFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Find the first element emitted by the
Publisher
, and return it in aCompletionStage
. - findFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Find the first element emitted by the
Publisher
, and return it in aCompletionStage
. - 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
-
Map the elements to
CompletionStage
, and flatten so that the elements the values redeemed by eachCompletionStage
are emitted from this stream. - flatMapCompletionStage(Function<? super T, ? extends CompletionStage<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Map the elements to
CompletionStage
, and flatten so that the elements the values redeemed by eachCompletionStage
are emitted from this stream. - flatMapCompletionStage(Function<? super T, ? extends CompletionStage<? extends S>>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
Map the elements to
CompletionStage
, and flatten so that the elements the values redeemed by eachCompletionStage
are emitted from this stream. - 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 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.ConsumingOperators
-
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
-
Creates a publisher from a
CompletionStage
. - fromCompletionStage(CompletionStage<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Creates a publisher from a
CompletionStage
. - fromCompletionStageNullable(CompletionStage<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Creates a publisher from a
CompletionStage
. - fromCompletionStageNullable(CompletionStage<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Creates a publisher from a
CompletionStage
. - fromIterable(Iterable<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
that will emits the elements produced by the passed inIterable
. - fromIterable(Iterable<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
PublisherBuilder
that will emits the elements produced by the passed inIterable
. - fromProcessor(Processor<? super T, ? extends R>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
ProcessorBuilder
from the givenProcessor
. - fromProcessor(Processor<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
ProcessorBuilder
from the givenProcessor
. - fromPublisher(Publisher<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
from the givenPublisher
. - fromPublisher(Publisher<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
PublisherBuilder
from the givenPublisher
. - fromSubscriber(Subscriber<? super T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
SubscriberBuilder
from the givenSubscriber
. - fromSubscriber(Subscriber<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
SubscriberBuilder
from the givenSubscriber
.
G
- generate(Supplier<? extends T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Creates an infinite stream that emits elements supplied by the supplier
s
. - generate(Supplier<? extends T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Creates an infinite stream that emits elements supplied by the supplier
s
. - getAction() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.OnComplete
-
The action to execute.
- getAction() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.OnTerminate
-
The action to execute.
- getCollector() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Collect
-
The collector.
- getCompletion() - Method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionSubscriber
-
Get the completion stage.
- getCompletion() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.SubscriberWithCompletionStage
-
Get the completion stage.
- getCompletionStage() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.FromCompletionStage
-
Get the
CompletionStage
. - getCompletionStage() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.FromCompletionStageNullable
-
Get the
CompletionStage
. - getConsumer() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.OnError
-
The error handler.
- getConsumer() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Peek
-
The consumer function.
- getElements() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Of
-
The elements to emit.
- getError() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Failed
-
The error.
- getFirst() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Concat
-
The first graph in the stream.
- getFunction() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.OnErrorResume
-
The error handler.
- getFunction() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.OnErrorResumeWith
-
The error handler.
- getLimit() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Limit
-
The limit.
- getMapper() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.FlatMap
-
The mapper function.
- getMapper() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.FlatMapCompletionStage
-
The mapper function.
- getMapper() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.FlatMapIterable
-
The mapper function.
- getMapper() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Map
-
The mapper function.
- getPredicate() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.DropWhile
-
The predicate.
- getPredicate() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Filter
-
The predicate.
- getPredicate() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.TakeWhile
-
The predicate.
- getPublisher() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Coupled
-
Get the publisher graph.
- getRsProcessor() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.ProcessorStage
-
The processor.
- getRsPublisher() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.PublisherStage
-
The publisher.
- getRsSubscriber() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.SubscriberStage
-
The subscriber.
- getSecond() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Concat
-
The second graph in the stream.
- getSkip() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Skip
-
The number of elements to skip.
- getStages() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Graph
-
Get the stages of this graph.
- getSubscriber() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.Stage.Coupled
-
Get the subscriber graph.
- getSubscriber() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.SubscriberWithCompletionStage
-
Get the subscriber.
- Graph - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A graph.
I
- ignore() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Ignores each element of this stream.
- ignore() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Ignores each element of this stream.
- ignore() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Ignores each element of this stream.
- instance() - Static method in class org.eclipse.microprofile.reactive.streams.operators.spi.ReactiveStreamsFactoryResolver
-
Creates a ReactiveStreamsFactory object Only used internally from within
ReactiveStreams
- iterate(T, UnaryOperator<T>) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Creates an infinite stream produced by the iterative application of the function
f
to an initial elementseed
consisting ofseed
,f(seed)
,f(f(seed))
, etc. - iterate(T, UnaryOperator<T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Creates an infinite stream produced by the iterative application of the function
f
to an initial elementseed
consisting ofseed
,f(seed)
,f(f(seed))
, etc.
L
- limit(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Truncate this stream, ensuring the stream is no longer than
maxSize
elements in length. - limit(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Truncate this stream, ensuring the stream is no longer than
maxSize
elements in length. - limit(long) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Truncate this stream, ensuring the stream is no longer than
maxSize
elements in length.
M
- map(Function<? super R, ? extends S>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Map the elements emitted by this stream using the
mapper
function. - map(Function<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Map the elements emitted by this stream using the
mapper
function. - map(Function<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.TransformingOperators
-
Map the elements emitted by this stream using the
mapper
function.
O
- of(Subscriber<T>, CompletionStage<R>) - Static method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionSubscriber
-
Create a
CompletionSubscriber
by combining the given subscriber and completion stage. - of(T) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
that emits a single element. - of(T) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
PublisherBuilder
that emits a single element. - of(T...) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
that emits the given elements. - of(T...) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ReactiveStreamsFactory
-
Create a
PublisherBuilder
that emits the given elements. - ofNullable(T) - Static method in class org.eclipse.microprofile.reactive.streams.operators.ReactiveStreams
-
Create a
PublisherBuilder
that will emit a single element ift
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 ift
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 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.ErrorHandlingOperators
-
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 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.ErrorHandlingOperators
-
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 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.ErrorHandlingOperators
-
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
-
MicroProfile Reactive Streams Operators.
- org.eclipse.microprofile.reactive.streams.operators.spi - package org.eclipse.microprofile.reactive.streams.operators.spi
-
The Reactive Streams utils SPI.
P
- peek(Consumer<? super R>) - 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 on each element.
- peek(Consumer<? super T>) - 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 on each element.
- peek(Consumer<? super T>) - 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 on each element.
- PeekingOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operations for peeking at elements and signals in the stream, without impacting the stream itself.
- ProcessorBuilder<T,
R> - Interface in org.eclipse.microprofile.reactive.streams.operators -
A builder for a
Processor
. - ProducesResult<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
A stream that completes with a single result.
- PublisherBuilder<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
A builder for a
Publisher
.
R
- 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(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(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(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.
- 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(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(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.
- run() - Method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionRunner
-
Run this stream, using the first
ReactiveStreamsEngine
found by theServiceLoader
. - run(ReactiveStreamsEngine) - Method in interface org.eclipse.microprofile.reactive.streams.operators.CompletionRunner
-
Run this stream, using the supplied
ReactiveStreamsEngine
.
S
- 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
-
A flat map stage that emits and flattens
CompletionStage
. - 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
-
A publisher representation of a
CompletionStage
. - Stage.FromCompletionStageNullable - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
A publisher representation of a
CompletionStage
. - 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.
T
- takeWhile(Predicate<? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Take the longest prefix of elements from this stream that satisfy the given
predicate
. - takeWhile(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.FilteringOperators
-
Take the longest prefix of elements from this stream that satisfy the given
predicate
. - takeWhile(Predicate<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Take the longest prefix of elements from this stream that satisfy the given
predicate
. - to(SubscriberBuilder<? super R, ? extends S>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Connect the outlet of this stream to the given
SubscriberBuilder
graph. - to(SubscriberBuilder<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConnectingOperators
-
Connect the outlet of this stream to the given
SubscriberBuilder
graph. - to(SubscriberBuilder<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Connect the outlet of this stream to the given
SubscriberBuilder
graph. - to(Subscriber<? super R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Connect the outlet of the
Publisher
built by this builder to the givenSubscriber
. - to(Subscriber<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConnectingOperators
-
Connect the outlet of the
Publisher
built by this builder to the givenSubscriber
. - to(Subscriber<? super T>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Connect the outlet of the
Publisher
built by this builder to the givenSubscriber
. - toGraph() - Method in interface org.eclipse.microprofile.reactive.streams.operators.spi.ToGraphable
-
Convert this builder to a
Graph
. - ToGraphable - Interface in org.eclipse.microprofile.reactive.streams.operators.spi
-
All instances of
PublisherBuilder
,ProcessorBuilder
,SubscriberBuilder
andCompletionRunner
must implement this, to ensure that the builder can be turned into a graph by other implementations of the API. - toList() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConsumingOperators
-
Collect the elements emitted by this stream into a
List
. - toList() - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Collect the elements emitted by this stream into a
List
. - toList() - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Collect the elements emitted by this stream into a
List
. - TransformingOperators<T> - Interface in org.eclipse.microprofile.reactive.streams.operators
-
Operations for transforming a stream.
U
- UnsupportedStageException - Exception in org.eclipse.microprofile.reactive.streams.operators.spi
-
Exception thrown when a reactive streams engine doesn't support a stage that is passed to it.
- UnsupportedStageException(Stage) - Constructor for exception org.eclipse.microprofile.reactive.streams.operators.spi.UnsupportedStageException
V
- via(ProcessorBuilder<? super R, ? extends S>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Connect the outlet of the
Publisher
built by this builder to the givenProcessorBuilder
. - via(ProcessorBuilder<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConnectingOperators
-
Connect the outlet of the
Publisher
built by this builder to the givenProcessorBuilder
. - via(ProcessorBuilder<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Connect the outlet of the
Publisher
built by this builder to the givenProcessorBuilder
. - via(Processor<? super R, ? extends S>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ProcessorBuilder
-
Connect the outlet of this stream to the given
Processor
. - via(Processor<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.ConnectingOperators
-
Connect the outlet of this stream to the given
Processor
. - via(Processor<? super T, ? extends R>) - Method in interface org.eclipse.microprofile.reactive.streams.operators.PublisherBuilder
-
Connect the outlet of this stream to the given
Processor
.
All Classes and Interfaces|All Packages|Serialized Form