Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.internal.functions | |
io.reactivex.internal.operators.flowable | |
io.reactivex.internal.operators.maybe | |
io.reactivex.internal.operators.observable | |
io.reactivex.internal.operators.parallel | |
io.reactivex.internal.util | |
io.reactivex.parallel |
Contains the base type
ParallelFlowable ,
a sub-DSL for working with Flowable sequences in parallel. |
io.reactivex.plugins |
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers. |
Modifier and Type | Method and Description |
---|---|
static <T1,T2,R> Observable<R> |
Observable.combineLatest(ObservableSource<? extends T1> source1,
ObservableSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> combiner)
Combines two source ObservableSources by emitting an item that aggregates the latest values of each of the
source ObservableSources each time an item is received from either of the source ObservableSources, where this
aggregation is defined by a specified function.
|
static <T1,T2,R> Flowable<R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> combiner)
Combines two source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from either of the source Publishers, where this
aggregation is defined by a specified function.
|
<U,R> Maybe<R> |
Maybe.flatMap(Function<? super T,? extends MaybeSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> resultSelector)
Returns a Maybe that emits the results of a specified function to the pair of values emitted by the
source Maybe and a specified mapped MaybeSource.
|
<U,R> Observable<R> |
Observable.flatMap(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> resultSelector)
Returns an Observable that emits the results of a specified function to the pair of values emitted by the
source ObservableSource and a specified collection ObservableSource.
|
<U,R> Observable<R> |
Observable.flatMap(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors)
Returns an Observable that emits the results of a specified function to the pair of values emitted by the
source ObservableSource and a specified collection ObservableSource.
|
<U,R> Observable<R> |
Observable.flatMap(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors,
int maxConcurrency)
Returns an Observable that emits the results of a specified function to the pair of values emitted by the
source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent
subscriptions to these ObservableSources.
|
<U,R> Observable<R> |
Observable.flatMap(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors,
int maxConcurrency,
int bufferSize)
Returns an Observable that emits the results of a specified function to the pair of values emitted by the
source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent
subscriptions to these ObservableSources.
|
<U,R> Observable<R> |
Observable.flatMap(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
int maxConcurrency)
Returns an Observable that emits the results of a specified function to the pair of values emitted by the
source ObservableSource and a specified collection ObservableSource, while limiting the maximum number of concurrent
subscriptions to these ObservableSources.
|
<U,R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner)
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the
source Publisher and a specified collection Publisher.
|
<U,R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors)
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the
source Publisher and a specified collection Publisher.
|
<U,R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors,
int maxConcurrency)
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the
source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
<U,R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
boolean delayErrors,
int maxConcurrency,
int bufferSize)
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the
source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
<U,R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner,
int maxConcurrency)
Returns a Flowable that emits the results of a specified function to the pair of values emitted by the
source Publisher and a specified collection Publisher, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
<U,V> Observable<V> |
Observable.flatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper,
BiFunction<? super T,? super U,? extends V> resultSelector)
Returns an Observable that emits the results of applying a function to the pair of values from the source
ObservableSource and an Iterable corresponding to that item that is generated by a selector.
|
<U,V> Flowable<V> |
Flowable.flatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper,
BiFunction<? super T,? super U,? extends V> resultSelector)
Returns a Flowable that emits the results of applying a function to the pair of values from the source
Publisher and an Iterable corresponding to that item that is generated by a selector.
|
<U,V> Flowable<V> |
Flowable.flatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper,
BiFunction<? super T,? super U,? extends V> resultSelector,
int prefetch)
Returns a Flowable that merges each item emitted by the source Publisher with the values in an
Iterable corresponding to that item that is generated by a selector, while limiting the number of concurrent
subscriptions to these Publishers.
|
static <T,S> Observable<T> |
Observable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator)
Returns a cold, synchronous and stateful generator of values.
|
static <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator)
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
|
static <T,S> Observable<T> |
Observable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous and stateful generator of values.
|
static <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
|
<TRight,TLeftEnd,TRightEnd,R> |
Observable.groupJoin(ObservableSource<? extends TRight> other,
Function<? super T,? extends ObservableSource<TLeftEnd>> leftEnd,
Function<? super TRight,? extends ObservableSource<TRightEnd>> rightEnd,
BiFunction<? super T,? super Observable<TRight>,? extends R> resultSelector)
Returns an Observable that correlates two ObservableSources when they overlap in time and groups the results.
|
<TRight,TLeftEnd,TRightEnd,R> |
Flowable.groupJoin(org.reactivestreams.Publisher<? extends TRight> other,
Function<? super T,? extends org.reactivestreams.Publisher<TLeftEnd>> leftEnd,
Function<? super TRight,? extends org.reactivestreams.Publisher<TRightEnd>> rightEnd,
BiFunction<? super T,? super Flowable<TRight>,? extends R> resultSelector)
Returns a Flowable that correlates two Publishers when they overlap in time and groups the results.
|
<TRight,TLeftEnd,TRightEnd,R> |
Observable.join(ObservableSource<? extends TRight> other,
Function<? super T,? extends ObservableSource<TLeftEnd>> leftEnd,
Function<? super TRight,? extends ObservableSource<TRightEnd>> rightEnd,
BiFunction<? super T,? super TRight,? extends R> resultSelector)
Correlates the items emitted by two ObservableSources based on overlapping durations.
|
<TRight,TLeftEnd,TRightEnd,R> |
Flowable.join(org.reactivestreams.Publisher<? extends TRight> other,
Function<? super T,? extends org.reactivestreams.Publisher<TLeftEnd>> leftEnd,
Function<? super TRight,? extends org.reactivestreams.Publisher<TRightEnd>> rightEnd,
BiFunction<? super T,? super TRight,? extends R> resultSelector)
Correlates the items emitted by two Publishers based on overlapping durations.
|
Maybe<T> |
Observable.reduce(BiFunction<T,T,T> reducer)
Returns a Maybe that applies a specified accumulator function to the first item emitted by a source
ObservableSource, then feeds the result of that function along with the second item emitted by the source
ObservableSource into the same function, and so on until all items have been emitted by the finite source ObservableSource,
and emits the final result from the final call to your function as its sole item.
|
Maybe<T> |
Flowable.reduce(BiFunction<T,T,T> reducer)
Returns a Maybe that applies a specified accumulator function to the first item emitted by a source
Publisher, then feeds the result of that function along with the second item emitted by the source
Publisher into the same function, and so on until all items have been emitted by the finite source Publisher,
and emits the final result from the final call to your function as its sole item.
|
<R> Single<R> |
Observable.reduce(R seed,
BiFunction<R,? super T,R> reducer)
Returns a Single that applies a specified accumulator function to the first item emitted by a source
ObservableSource and a specified seed value, then feeds the result of that function along with the second item
emitted by an ObservableSource into the same function, and so on until all items have been emitted by the
finite source ObservableSource, emitting the final result from the final call to your function as its sole item.
|
<R> Single<R> |
Flowable.reduce(R seed,
BiFunction<R,? super T,R> reducer)
Returns a Single that applies a specified accumulator function to the first item emitted by a source
Publisher and a specified seed value, then feeds the result of that function along with the second item
emitted by a Publisher into the same function, and so on until all items have been emitted by the
finite source Publisher, emitting the final result from the final call to your function as its sole item.
|
<R> Single<R> |
Observable.reduceWith(Callable<R> seedSupplier,
BiFunction<R,? super T,R> reducer)
Returns a Single that applies a specified accumulator function to the first item emitted by a source
ObservableSource and a seed value derived from calling a specified seedSupplier, then feeds the result
of that function along with the second item emitted by an ObservableSource into the same function,
and so on until all items have been emitted by the finite source ObservableSource, emitting the final result
from the final call to your function as its sole item.
|
<R> Single<R> |
Flowable.reduceWith(Callable<R> seedSupplier,
BiFunction<R,? super T,R> reducer)
Returns a Single that applies a specified accumulator function to the first item emitted by a source
Publisher and a seed value derived from calling a specified seedSupplier, then feeds the result
of that function along with the second item emitted by a Publisher into the same function, and so on until
all items have been emitted by the finite source Publisher, emitting the final result from the final call to your
function as its sole item.
|
Observable<T> |
Observable.scan(BiFunction<T,T,T> accumulator)
Returns an Observable that applies a specified accumulator function to the first item emitted by a source
ObservableSource, then feeds the result of that function along with the second item emitted by the source
ObservableSource into the same function, and so on until all items have been emitted by the source ObservableSource,
emitting the result of each of these iterations.
|
Flowable<T> |
Flowable.scan(BiFunction<T,T,T> accumulator)
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source
Publisher, then feeds the result of that function along with the second item emitted by the source
Publisher into the same function, and so on until all items have been emitted by the source Publisher,
emitting the result of each of these iterations.
|
<R> Observable<R> |
Observable.scan(R initialValue,
BiFunction<R,? super T,R> accumulator)
Returns an Observable that applies a specified accumulator function to the first item emitted by a source
ObservableSource and a seed value, then feeds the result of that function along with the second item emitted by
the source ObservableSource into the same function, and so on until all items have been emitted by the source
ObservableSource, emitting the result of each of these iterations.
|
<R> Flowable<R> |
Flowable.scan(R initialValue,
BiFunction<R,? super T,R> accumulator)
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source
Publisher and a seed value, then feeds the result of that function along with the second item emitted by
the source Publisher into the same function, and so on until all items have been emitted by the source
Publisher, emitting the result of each of these iterations.
|
<R> Observable<R> |
Observable.scanWith(Callable<R> seedSupplier,
BiFunction<R,? super T,R> accumulator)
Returns an Observable that applies a specified accumulator function to the first item emitted by a source
ObservableSource and a seed value, then feeds the result of that function along with the second item emitted by
the source ObservableSource into the same function, and so on until all items have been emitted by the source
ObservableSource, emitting the result of each of these iterations.
|
<R> Flowable<R> |
Flowable.scanWith(Callable<R> seedSupplier,
BiFunction<R,? super T,R> accumulator)
Returns a Flowable that applies a specified accumulator function to the first item emitted by a source
Publisher and a seed value, then feeds the result of that function along with the second item emitted by
the source Publisher into the same function, and so on until all items have been emitted by the source
Publisher, emitting the result of each of these iterations.
|
<U,R> Observable<R> |
Observable.withLatestFrom(ObservableSource<? extends U> other,
BiFunction<? super T,? super U,? extends R> combiner)
Merges the specified ObservableSource into this ObservableSource sequence by using the
resultSelector
function only when the source ObservableSource (this instance) emits an item. |
<U,R> Flowable<R> |
Flowable.withLatestFrom(org.reactivestreams.Publisher<? extends U> other,
BiFunction<? super T,? super U,? extends R> combiner)
Merges the specified Publisher into this Publisher sequence by using the
resultSelector
function only when the source Publisher (this instance) emits an item. |
static <T1,T2,R> Maybe<R> |
Maybe.zip(MaybeSource<? extends T1> source1,
MaybeSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper)
Returns a Maybe that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other MaybeSources.
|
static <T1,T2,R> Observable<R> |
Observable.zip(ObservableSource<? extends T1> source1,
ObservableSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper)
Returns an Observable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other ObservableSources.
|
static <T1,T2,R> Observable<R> |
Observable.zip(ObservableSource<? extends T1> source1,
ObservableSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper,
boolean delayError)
Returns an Observable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other ObservableSources.
|
static <T1,T2,R> Observable<R> |
Observable.zip(ObservableSource<? extends T1> source1,
ObservableSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper,
boolean delayError,
int bufferSize)
Returns an Observable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other ObservableSources.
|
static <T1,T2,R> Flowable<R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other Publishers.
|
static <T1,T2,R> Flowable<R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper,
boolean delayError)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other Publishers.
|
static <T1,T2,R> Flowable<R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper,
boolean delayError,
int bufferSize)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
two items emitted, in sequence, by two other Publishers.
|
static <T1,T2,R> Single<R> |
Single.zip(SingleSource<? extends T1> source1,
SingleSource<? extends T2> source2,
BiFunction<? super T1,? super T2,? extends R> zipper)
Returns a Single that emits the results of a specified combiner function applied to two items emitted by
two other Singles.
|
<U,R> Observable<R> |
Observable.zipWith(Iterable<U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Returns an Observable that emits items that are the result of applying a specified function to pairs of
values, one each from the source ObservableSource and a specified Iterable sequence.
|
<U,R> Flowable<R> |
Flowable.zipWith(Iterable<U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Returns a Flowable that emits items that are the result of applying a specified function to pairs of
values, one each from the source Publisher and a specified Iterable sequence.
|
<U,R> Maybe<R> |
Maybe.zipWith(MaybeSource<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Waits until this and the other MaybeSource signal a success value then applies the given BiFunction
to those values and emits the BiFunction's resulting value to downstream.
|
<U,R> Observable<R> |
Observable.zipWith(ObservableSource<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Returns an Observable that emits items that are the result of applying a specified function to pairs of
values, one each from the source ObservableSource and another specified ObservableSource.
|
<U,R> Observable<R> |
Observable.zipWith(ObservableSource<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper,
boolean delayError)
Returns an Observable that emits items that are the result of applying a specified function to pairs of
values, one each from the source ObservableSource and another specified ObservableSource.
|
<U,R> Observable<R> |
Observable.zipWith(ObservableSource<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper,
boolean delayError,
int bufferSize)
Returns an Observable that emits items that are the result of applying a specified function to pairs of
values, one each from the source ObservableSource and another specified ObservableSource.
|
<U,R> Flowable<R> |
Flowable.zipWith(org.reactivestreams.Publisher<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Returns a Flowable that emits items that are the result of applying a specified function to pairs of
values, one each from the source Publisher and another specified Publisher.
|
<U,R> Flowable<R> |
Flowable.zipWith(org.reactivestreams.Publisher<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper,
boolean delayError)
Returns a Flowable that emits items that are the result of applying a specified function to pairs of
values, one each from the source Publisher and another specified Publisher.
|
<U,R> Flowable<R> |
Flowable.zipWith(org.reactivestreams.Publisher<? extends U> other,
BiFunction<? super T,? super U,? extends R> zipper,
boolean delayError,
int bufferSize)
Returns a Flowable that emits items that are the result of applying a specified function to pairs of
values, one each from the source Publisher and another specified Publisher.
|
<U,R> Single<R> |
Single.zipWith(SingleSource<U> other,
BiFunction<? super T,? super U,? extends R> zipper)
Returns a Single that emits the result of applying a specified function to the pair of items emitted by
the source Single and another specified Single.
|
Modifier and Type | Method and Description |
---|---|
static <T1,T2,R> Function<Object[],R> |
Functions.toFunction(BiFunction<? super T1,? super T2,? extends R> f) |
Modifier and Type | Method and Description |
---|---|
static <T,S> BiFunction<S,Emitter<T>,S> |
FlowableInternalHelper.simpleBiGenerator(BiConsumer<S,Emitter<T>> consumer) |
static <T,S> BiFunction<S,Emitter<T>,S> |
FlowableInternalHelper.simpleGenerator(Consumer<Emitter<T>> consumer) |
Modifier and Type | Method and Description |
---|---|
static <T,U,R> Function<T,org.reactivestreams.Publisher<R>> |
FlowableInternalHelper.flatMapWithCombiner(Function<? super T,? extends org.reactivestreams.Publisher<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner) |
Constructor and Description |
---|
FlowableGenerate(Callable<S> stateSupplier,
BiFunction<S,Emitter<T>,S> generator,
Consumer<? super S> disposeState) |
FlowableGroupJoin(Flowable<TLeft> source,
org.reactivestreams.Publisher<? extends TRight> other,
Function<? super TLeft,? extends org.reactivestreams.Publisher<TLeftEnd>> leftEnd,
Function<? super TRight,? extends org.reactivestreams.Publisher<TRightEnd>> rightEnd,
BiFunction<? super TLeft,? super Flowable<TRight>,? extends R> resultSelector) |
FlowableJoin(Flowable<TLeft> source,
org.reactivestreams.Publisher<? extends TRight> other,
Function<? super TLeft,? extends org.reactivestreams.Publisher<TLeftEnd>> leftEnd,
Function<? super TRight,? extends org.reactivestreams.Publisher<TRightEnd>> rightEnd,
BiFunction<? super TLeft,? super TRight,? extends R> resultSelector) |
FlowableReduce(Flowable<T> source,
BiFunction<T,T,T> reducer) |
FlowableReduceMaybe(Flowable<T> source,
BiFunction<T,T,T> reducer) |
FlowableReduceSeedSingle(org.reactivestreams.Publisher<T> source,
R seed,
BiFunction<R,? super T,R> reducer) |
FlowableReduceWithSingle(org.reactivestreams.Publisher<T> source,
Callable<R> seedSupplier,
BiFunction<R,? super T,R> reducer) |
FlowableScan(Flowable<T> source,
BiFunction<T,T,T> accumulator) |
FlowableScanSeed(Flowable<T> source,
Callable<R> seedSupplier,
BiFunction<R,? super T,R> accumulator) |
FlowableWithLatestFrom(Flowable<T> source,
BiFunction<? super T,? super U,? extends R> combiner,
org.reactivestreams.Publisher<? extends U> other) |
FlowableZipIterable(Flowable<T> source,
Iterable<U> other,
BiFunction<? super T,? super U,? extends V> zipper) |
Constructor and Description |
---|
MaybeFlatMapBiSelector(MaybeSource<T> source,
Function<? super T,? extends MaybeSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> resultSelector) |
Modifier and Type | Method and Description |
---|---|
static <T,S> BiFunction<S,Emitter<T>,S> |
ObservableInternalHelper.simpleBiGenerator(BiConsumer<S,Emitter<T>> consumer) |
static <T,S> BiFunction<S,Emitter<T>,S> |
ObservableInternalHelper.simpleGenerator(Consumer<Emitter<T>> consumer) |
Modifier and Type | Method and Description |
---|---|
static <T,U,R> Function<T,ObservableSource<R>> |
ObservableInternalHelper.flatMapWithCombiner(Function<? super T,? extends ObservableSource<? extends U>> mapper,
BiFunction<? super T,? super U,? extends R> combiner) |
Constructor and Description |
---|
ParallelDoOnNextTry(ParallelFlowable<T> source,
Consumer<? super T> onNext,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler) |
ParallelFilterTry(ParallelFlowable<T> source,
Predicate<? super T> predicate,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler) |
ParallelMapTry(ParallelFlowable<T> source,
Function<? super T,? extends R> mapper,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler) |
ParallelReduce(ParallelFlowable<? extends T> source,
Callable<R> initialSupplier,
BiFunction<R,? super T,R> reducer) |
ParallelReduceFull(ParallelFlowable<? extends T> source,
BiFunction<T,T,T> reducer) |
Modifier and Type | Class and Description |
---|---|
class |
ListAddBiConsumer |
class |
MergerBiFunction<T>
A BiFunction that merges two Lists into a new list.
|
Modifier and Type | Method and Description |
---|---|
static <T> BiFunction<List<T>,T,List<T>> |
ListAddBiConsumer.instance() |
Modifier and Type | Class and Description |
---|---|
class |
ParallelFailureHandling
Enumerations for handling failure within a parallel operator.
|
Modifier and Type | Method and Description |
---|---|
ParallelFlowable<T> |
ParallelFlowable.doOnNext(Consumer<? super T> onNext,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler)
Call the specified consumer with the current element passing through any 'rail' and
handles errors based on the returned value by the handler function.
|
ParallelFlowable<T> |
ParallelFlowable.filter(Predicate<? super T> predicate,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler)
Filters the source values on each 'rail' and
handles errors based on the returned value by the handler function.
|
<R> ParallelFlowable<R> |
ParallelFlowable.map(Function<? super T,? extends R> mapper,
BiFunction<? super Long,? super Throwable,ParallelFailureHandling> errorHandler)
Maps the source values on each 'rail' to another value and
handles errors based on the returned value by the handler function.
|
Flowable<T> |
ParallelFlowable.reduce(BiFunction<T,T,T> reducer)
Reduces all values within a 'rail' and across 'rails' with a reducer function into a single
sequential value.
|
<R> ParallelFlowable<R> |
ParallelFlowable.reduce(Callable<R> initialSupplier,
BiFunction<R,? super T,R> reducer)
Reduces all values within a 'rail' to a single value (with a possibly different type) via
a reducer function that is initialized on each rail from an initialSupplier value.
|
Modifier and Type | Method and Description |
---|---|
static BiFunction<? super Completable,? super CompletableObserver,? extends CompletableObserver> |
RxJavaPlugins.getOnCompletableSubscribe()
Returns the current hook function.
|
static BiFunction<? super Flowable,? super org.reactivestreams.Subscriber,? extends org.reactivestreams.Subscriber> |
RxJavaPlugins.getOnFlowableSubscribe()
Returns the current hook function.
|
static BiFunction<? super Maybe,? super MaybeObserver,? extends MaybeObserver> |
RxJavaPlugins.getOnMaybeSubscribe()
Returns the current hook function.
|
static BiFunction<? super Observable,? super Observer,? extends Observer> |
RxJavaPlugins.getOnObservableSubscribe()
Returns the current hook function.
|
static BiFunction<? super Single,? super SingleObserver,? extends SingleObserver> |
RxJavaPlugins.getOnSingleSubscribe()
Returns the current hook function.
|
Modifier and Type | Method and Description |
---|---|
static void |
RxJavaPlugins.setOnCompletableSubscribe(BiFunction<? super Completable,? super CompletableObserver,? extends CompletableObserver> onCompletableSubscribe)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnFlowableSubscribe(BiFunction<? super Flowable,? super org.reactivestreams.Subscriber,? extends org.reactivestreams.Subscriber> onFlowableSubscribe)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnMaybeSubscribe(BiFunction<? super Maybe,MaybeObserver,? extends MaybeObserver> onMaybeSubscribe)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnObservableSubscribe(BiFunction<? super Observable,? super Observer,? extends Observer> onObservableSubscribe)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setOnSingleSubscribe(BiFunction<? super Single,? super SingleObserver,? extends SingleObserver> onSingleSubscribe)
Sets the specific hook function.
|
Copyright © 2019. All rights reserved.