Package | Description |
---|---|
io.reactivex |
Base reactive classes:
Flowable , Observable ,
Single , Maybe and
Completable ; base reactive consumers;
other common base interfaces. |
io.reactivex.flowables |
Classes supporting the Flowable base reactive class:
ConnectableFlowable and
GroupedFlowable . |
io.reactivex.parallel |
Contains the base type
ParallelFlowable ,
a sub-DSL for working with Flowable sequences in parallel. |
io.reactivex.processors |
Classes extending the Flowable base reactive class and implementing
the Subscriber interface at the same time (aka hot Flowables).
|
Modifier and Type | Method and Description |
---|---|
Single<Boolean> |
Flowable.all(Predicate<? super T> predicate)
Returns a Single that emits a Boolean that indicates whether all of the items emitted by the source
Publisher satisfy a condition.
|
static <T> Flowable<T> |
Flowable.amb(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Mirrors the one Publisher in an Iterable of several Publishers that first either emits an item or sends
a termination notification.
|
static <T> Flowable<T> |
Flowable.ambArray(org.reactivestreams.Publisher<? extends T>... sources)
Mirrors the one Publisher in an array of several Publishers that first either emits an item or sends
a termination notification.
|
Flowable<T> |
Flowable.ambWith(org.reactivestreams.Publisher<? extends T> other)
Mirrors the Publisher (current or provided) that first either emits an item or sends a termination
notification.
|
<T> Flowable<T> |
Completable.andThen(org.reactivestreams.Publisher<T> next)
Returns a Flowable which will subscribe to this Completable and once that is completed then
will subscribe to the
next Flowable. |
Single<Boolean> |
Flowable.any(Predicate<? super T> predicate)
Returns a Single that emits
true if any item emitted by the source Publisher satisfies a
specified condition, otherwise false . |
<R> R |
Flowable.as(FlowableConverter<T,? extends R> converter)
Calls the specified converter function during assembly time and returns its resulting value.
|
T |
Flowable.blockingFirst()
Returns the first item emitted by this
Flowable , or throws
NoSuchElementException if it emits no items. |
T |
Flowable.blockingFirst(T defaultItem)
Returns the first item emitted by this
Flowable , or a default value if it emits no
items. |
void |
Flowable.blockingForEach(Consumer<? super T> onNext)
Consumes the upstream
Flowable in a blocking fashion and invokes the given
Consumer with each upstream item on the current thread until the
upstream terminates. |
Iterable<T> |
Flowable.blockingIterable()
Converts this
Flowable into an Iterable . |
Iterable<T> |
Flowable.blockingIterable(int bufferSize)
Converts this
Flowable into an Iterable . |
T |
Flowable.blockingLast()
Returns the last item emitted by this
Flowable , or throws
NoSuchElementException if this Flowable emits no items. |
T |
Flowable.blockingLast(T defaultItem)
Returns the last item emitted by this
Flowable , or a default value if it emits no
items. |
Iterable<T> |
Flowable.blockingLatest()
Returns an
Iterable that returns the latest item emitted by this Flowable ,
waiting if necessary for one to become available. |
Iterable<T> |
Flowable.blockingMostRecent(T initialItem)
Returns an
Iterable that always returns the item most recently emitted by this
Flowable . |
Iterable<T> |
Flowable.blockingNext()
Returns an
Iterable that blocks until this Flowable emits another item, then
returns that item. |
T |
Flowable.blockingSingle()
If this
Flowable completes after emitting a single item, return that item, otherwise
throw a NoSuchElementException . |
T |
Flowable.blockingSingle(T defaultItem)
If this
Flowable completes after emitting a single item, return that item; if it emits
more than one item, throw an IllegalArgumentException ; if it emits no items, return a default
value. |
void |
Flowable.blockingSubscribe()
Runs the source Flowable to a terminal event, ignoring any values and rethrowing any exception.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(Consumer<? super T> onNext,
int bufferSize)
Subscribes to the source and calls the given callbacks on the current thread.
|
void |
Flowable.blockingSubscribe(org.reactivestreams.Subscriber<? super T> subscriber)
Subscribes to the source and calls the
Subscriber methods on the current thread. |
<B> Flowable<List<T>> |
Flowable.buffer(Callable<? extends org.reactivestreams.Publisher<B>> boundaryIndicatorSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<B,U extends Collection<? super T>> |
Flowable.buffer(Callable<? extends org.reactivestreams.Publisher<B>> boundaryIndicatorSupplier,
Callable<U> bufferSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<TOpening,TClosing> |
Flowable.buffer(Flowable<? extends TOpening> openingIndicator,
Function<? super TOpening,? extends org.reactivestreams.Publisher<? extends TClosing>> closingIndicator)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<TOpening,TClosing,U extends Collection<? super T>> |
Flowable.buffer(Flowable<? extends TOpening> openingIndicator,
Function<? super TOpening,? extends org.reactivestreams.Publisher<? extends TClosing>> closingIndicator,
Callable<U> bufferSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(int count)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<U extends Collection<? super T>> |
Flowable.buffer(int count,
Callable<U> bufferSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(int count,
int skip)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<U extends Collection<? super T>> |
Flowable.buffer(int count,
int skip,
Callable<U> bufferSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
long timeskip,
TimeUnit unit)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<U extends Collection<? super T>> |
Flowable.buffer(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
Callable<U> bufferSupplier)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
TimeUnit unit)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
TimeUnit unit,
int count)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
Flowable<List<T>> |
Flowable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler,
int count)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<U extends Collection<? super T>> |
Flowable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler,
int count,
Callable<U> bufferSupplier,
boolean restartTimerOnMaxSize)
Returns a Flowable that emits buffers of items it collects from the source Publisher.
|
<B> Flowable<List<T>> |
Flowable.buffer(org.reactivestreams.Publisher<B> boundaryIndicator)
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the
specified boundary Publisher emits an item.
|
<B,U extends Collection<? super T>> |
Flowable.buffer(org.reactivestreams.Publisher<B> boundaryIndicator,
Callable<U> bufferSupplier)
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the
specified boundary Publisher emits an item.
|
<B> Flowable<List<T>> |
Flowable.buffer(org.reactivestreams.Publisher<B> boundaryIndicator,
int initialCapacity)
Returns a Flowable that emits non-overlapping buffered items from the source Publisher each time the
specified boundary Publisher emits an item.
|
Flowable<T> |
Flowable.cache()
Returns a Flowable that subscribes to this Publisher lazily, caches all of its events
and replays them, in the same order as received, to all the downstream subscribers.
|
Flowable<T> |
Flowable.cacheWithInitialCapacity(int initialCapacity)
Returns a Flowable that subscribes to this Publisher lazily, caches all of its events
and replays them, in the same order as received, to all the downstream subscribers.
|
<U> Flowable<U> |
Flowable.cast(Class<U> clazz)
Returns a Flowable that emits the items emitted by the source Publisher, converted to the specified
type.
|
<U> Single<U> |
Flowable.collect(Callable<? extends U> initialItemSupplier,
BiConsumer<? super U,? super T> collector)
Collects items emitted by the finite source Publisher into a single mutable data structure and returns
a Single that emits this structure.
|
<U> Single<U> |
Flowable.collectInto(U initialItem,
BiConsumer<? super U,? super T> collector)
Collects items emitted by the finite source Publisher into a single mutable data structure and returns
a Single that emits this structure.
|
static <T,R> Flowable<R> |
Flowable.combineLatest(Function<? super Object[],? extends R> combiner,
org.reactivestreams.Publisher<? extends T>... sources)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatest(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> combiner)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatest(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> combiner,
int bufferSize)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T>[] sources,
Function<? super Object[],? extends R> combiner)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T>[] sources,
Function<? super Object[],? extends R> combiner,
int bufferSize)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, 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.
|
static <T1,T2,T3,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
Function3<? super T1,? super T2,? super T3,? extends R> combiner)
Combines three source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
Function4<? super T1,? super T2,? super T3,? super T4,? extends R> combiner)
Combines four source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,T5,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
Function5<? super T1,? super T2,? super T3,? super T4,? super T5,? extends R> combiner)
Combines five source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,T5,T6,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
Function6<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? extends R> combiner)
Combines six source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,T5,T6,T7,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
Function7<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? extends R> combiner)
Combines seven source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
Function8<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? extends R> combiner)
Combines eight source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,T9,R> |
Flowable.combineLatest(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
org.reactivestreams.Publisher<? extends T9> source9,
Function9<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? super T9,? extends R> combiner)
Combines nine source Publishers by emitting an item that aggregates the latest values of each of the
source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(Function<? super Object[],? extends R> combiner,
int bufferSize,
org.reactivestreams.Publisher<? extends T>... sources)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publisher, where this
aggregation is defined by a specified function and delays any error from the sources until
all source Publishers terminate.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(Function<? super Object[],? extends R> combiner,
org.reactivestreams.Publisher<? extends T>... sources)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source Publishers terminate.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> combiner)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source Publishers terminate.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> combiner,
int bufferSize)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source Publishers terminate.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(org.reactivestreams.Publisher<? extends T>[] sources,
Function<? super Object[],? extends R> combiner)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function.
|
static <T,R> Flowable<R> |
Flowable.combineLatestDelayError(org.reactivestreams.Publisher<? extends T>[] sources,
Function<? super Object[],? extends R> combiner,
int bufferSize)
Combines a collection of source Publishers by emitting an item that aggregates the latest values of each of
the source Publishers each time an item is received from any of the source Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source Publishers terminate.
|
<R> Flowable<R> |
Flowable.compose(FlowableTransformer<? super T,? extends R> composer)
Transform a Publisher by applying a particular Transformer function to it.
|
static <T> Flowable<T> |
Maybe.concat(Iterable<? extends MaybeSource<? extends T>> sources)
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by
an Iterable sequence.
|
static <T> Flowable<T> |
Flowable.concat(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Concatenates elements of each Publisher provided via an Iterable sequence into a single sequence
of elements without interleaving them.
|
static <T> Flowable<T> |
Single.concat(Iterable<? extends SingleSource<? extends T>> sources)
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by
an Iterable sequence.
|
static <T> Flowable<T> |
Maybe.concat(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2)
Returns a Flowable that emits the items emitted by two MaybeSources, one after the other.
|
static <T> Flowable<T> |
Maybe.concat(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3)
Returns a Flowable that emits the items emitted by three MaybeSources, one after the other.
|
static <T> Flowable<T> |
Maybe.concat(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3,
MaybeSource<? extends T> source4)
Returns a Flowable that emits the items emitted by four MaybeSources, one after the other.
|
static Completable |
Completable.concat(org.reactivestreams.Publisher<? extends CompletableSource> sources)
Returns a Completable which completes only when all sources complete, one after another.
|
static Completable |
Completable.concat(org.reactivestreams.Publisher<? extends CompletableSource> sources,
int prefetch)
Returns a Completable which completes only when all sources complete, one after another.
|
static <T> Flowable<T> |
Maybe.concat(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources)
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by
a Publisher sequence.
|
static <T> Flowable<T> |
Maybe.concat(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources,
int prefetch)
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources provided by
a Publisher sequence.
|
static <T> Flowable<T> |
Flowable.concat(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Returns a Flowable that emits the items emitted by each of the Publishers emitted by the source
Publisher, one after the other, without interleaving them.
|
static <T> Flowable<T> |
Flowable.concat(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int prefetch)
Returns a Flowable that emits the items emitted by each of the Publishers emitted by the source
Publisher, one after the other, without interleaving them.
|
static <T> Flowable<T> |
Single.concat(org.reactivestreams.Publisher<? extends SingleSource<? extends T>> sources)
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by
a Publisher sequence.
|
static <T> Flowable<T> |
Single.concat(org.reactivestreams.Publisher<? extends SingleSource<? extends T>> sources,
int prefetch)
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided by
a Publisher sequence and prefetched by the specified amount.
|
static <T> Flowable<T> |
Flowable.concat(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2)
Returns a Flowable that emits the items emitted by two Publishers, one after the other, without
interleaving them.
|
static <T> Flowable<T> |
Flowable.concat(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3)
Returns a Flowable that emits the items emitted by three Publishers, one after the other, without
interleaving them.
|
static <T> Flowable<T> |
Flowable.concat(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3,
org.reactivestreams.Publisher<? extends T> source4)
Returns a Flowable that emits the items emitted by four Publishers, one after the other, without
interleaving them.
|
static <T> Flowable<T> |
Single.concat(SingleSource<? extends T> source1,
SingleSource<? extends T> source2)
Returns a Flowable that emits the items emitted by two Singles, one after the other.
|
static <T> Flowable<T> |
Single.concat(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3)
Returns a Flowable that emits the items emitted by three Singles, one after the other.
|
static <T> Flowable<T> |
Single.concat(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3,
SingleSource<? extends T> source4)
Returns a Flowable that emits the items emitted by four Singles, one after the other.
|
static <T> Flowable<T> |
Maybe.concatArray(MaybeSource<? extends T>... sources)
Concatenate the single values, in a non-overlapping fashion, of the MaybeSource sources in the array.
|
static <T> Flowable<T> |
Flowable.concatArray(org.reactivestreams.Publisher<? extends T>... sources)
Concatenates a variable number of Publisher sources.
|
static <T> Flowable<T> |
Single.concatArray(SingleSource<? extends T>... sources)
Concatenate the single values, in a non-overlapping fashion, of the SingleSources provided in
an array.
|
static <T> Flowable<T> |
Maybe.concatArrayDelayError(MaybeSource<? extends T>... sources)
Concatenates a variable number of MaybeSource sources and delays errors from any of them
till all terminate.
|
static <T> Flowable<T> |
Flowable.concatArrayDelayError(org.reactivestreams.Publisher<? extends T>... sources)
Concatenates a variable number of Publisher sources and delays errors from any of them
till all terminate.
|
static <T> Flowable<T> |
Flowable.concatArrayEager(int maxConcurrency,
int prefetch,
org.reactivestreams.Publisher<? extends T>... sources)
Concatenates an array of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Maybe.concatArrayEager(MaybeSource<? extends T>... sources)
Concatenates a sequence of MaybeSource eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatArrayEager(org.reactivestreams.Publisher<? extends T>... sources)
Concatenates an array of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Single.concatArrayEager(SingleSource<? extends T>... sources)
Concatenates a sequence of SingleSource eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatArrayEagerDelayError(int maxConcurrency,
int prefetch,
org.reactivestreams.Publisher<? extends T>... sources)
Concatenates an array of
Publisher s eagerly into a single stream of values
and delaying any errors until all sources terminate. |
static <T> Flowable<T> |
Flowable.concatArrayEagerDelayError(org.reactivestreams.Publisher<? extends T>... sources)
Concatenates an array of
Publisher s eagerly into a single stream of values
and delaying any errors until all sources terminate. |
static <T> Flowable<T> |
Maybe.concatDelayError(Iterable<? extends MaybeSource<? extends T>> sources)
Concatenates the Iterable sequence of MaybeSources into a single sequence by subscribing to each MaybeSource,
one after the other, one at a time and delays any errors till the all inner MaybeSources terminate.
|
static <T> Flowable<T> |
Flowable.concatDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Concatenates the Iterable sequence of Publishers into a single sequence by subscribing to each Publisher,
one after the other, one at a time and delays any errors till the all inner Publishers terminate.
|
static <T> Flowable<T> |
Maybe.concatDelayError(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources)
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher,
one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
|
static <T> Flowable<T> |
Flowable.concatDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher,
one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
|
static <T> Flowable<T> |
Flowable.concatDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int prefetch,
boolean tillTheEnd)
Concatenates the Publisher sequence of Publishers into a single sequence by subscribing to each inner Publisher,
one after the other, one at a time and delays any errors till the all inner and the outer Publishers terminate.
|
static <T> Flowable<T> |
Maybe.concatEager(Iterable<? extends MaybeSource<? extends T>> sources)
Concatenates a sequence of MaybeSources eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatEager(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Concatenates a sequence of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatEager(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency,
int prefetch)
Concatenates a sequence of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Single.concatEager(Iterable<? extends SingleSource<? extends T>> sources)
Concatenates a sequence of SingleSources eagerly into a single stream of values.
|
static <T> Flowable<T> |
Maybe.concatEager(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources)
Concatenates a Publisher sequence of MaybeSources eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatEager(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Concatenates a Publisher sequence of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Flowable.concatEager(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency,
int prefetch)
Concatenates a Publisher sequence of Publishers eagerly into a single stream of values.
|
static <T> Flowable<T> |
Single.concatEager(org.reactivestreams.Publisher<? extends SingleSource<? extends T>> sources)
Concatenates a Publisher sequence of SingleSources eagerly into a single stream of values.
|
<R> Flowable<R> |
Flowable.concatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a new Flowable that emits items resulting from applying a function that you supply to each item
emitted by the source Publisher, where that function returns a Publisher, and then emitting the items
that result from concatenating those resulting Publishers.
|
<R> Flowable<R> |
Flowable.concatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int prefetch)
Returns a new Flowable that emits items resulting from applying a function that you supply to each item
emitted by the source Publisher, where that function returns a Publisher, and then emitting the items
that result from concatenating those resulting Publishers.
|
Completable |
Flowable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes. |
Completable |
Flowable.concatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
int prefetch)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other completes. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
Completable |
Flowable.concatMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper,
boolean tillTheEnd,
int prefetch)
Maps the upstream items into
CompletableSource s and subscribes to them one after the
other terminates, optionally delaying all errors till both this Flowable and all
inner CompletableSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Maps each of the items into a Publisher, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner Publishers
till all of them terminate.
|
<R> Flowable<R> |
Flowable.concatMapDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int prefetch,
boolean tillTheEnd)
Maps each of the items into a Publisher, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner Publishers
till all of them terminate.
|
<R> Flowable<R> |
Flowable.concatMapEager(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single
Publisher.
|
<R> Flowable<R> |
Flowable.concatMapEager(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int maxConcurrency,
int prefetch)
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single
Publisher.
|
<R> Flowable<R> |
Flowable.concatMapEagerDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
boolean tillTheEnd)
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single
Publisher.
|
<R> Flowable<R> |
Flowable.concatMapEagerDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int maxConcurrency,
int prefetch,
boolean tillTheEnd)
Maps a sequence of values into Publishers and concatenates these Publishers eagerly into a single
Publisher.
|
<U> Flowable<U> |
Flowable.concatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper)
Returns a Flowable that concatenate each item emitted by the source Publisher with the values in an
Iterable corresponding to that item that is generated by a selector.
|
<U> Flowable<U> |
Flowable.concatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper,
int prefetch)
Returns a Flowable that concatenate each item emitted by the source Publisher with the values in an
Iterable corresponding to that item that is generated by a selector.
|
<R> Flowable<R> |
Flowable.concatMapMaybe(Function<? super T,? extends MaybeSource<? extends R>> mapper)
Maps the upstream items into
MaybeSource s and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either this Flowable or the current inner MaybeSource fail. |
<R> Flowable<R> |
Flowable.concatMapMaybe(Function<? super T,? extends MaybeSource<? extends R>> mapper,
int prefetch)
Maps the upstream items into
MaybeSource s and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either this Flowable or the current inner MaybeSource fail. |
<R> Flowable<R> |
Flowable.concatMapMaybeDelayError(Function<? super T,? extends MaybeSource<? extends R>> mapper)
Maps the upstream items into
MaybeSource s and subscribes to them one after the
other terminates, emits their success value if available and delaying all errors
till both this Flowable and all inner MaybeSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapMaybeDelayError(Function<? super T,? extends MaybeSource<? extends R>> mapper,
boolean tillTheEnd)
Maps the upstream items into
MaybeSource s and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both this Flowable and all inner MaybeSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapMaybeDelayError(Function<? super T,? extends MaybeSource<? extends R>> mapper,
boolean tillTheEnd,
int prefetch)
Maps the upstream items into
MaybeSource s and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both this Flowable and all inner MaybeSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapSingle(Function<? super T,? extends SingleSource<? extends R>> mapper)
Maps the upstream items into
SingleSource s and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either this Flowable or the current inner SingleSource fail. |
<R> Flowable<R> |
Flowable.concatMapSingle(Function<? super T,? extends SingleSource<? extends R>> mapper,
int prefetch)
Maps the upstream items into
SingleSource s and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either this Flowable or the current inner SingleSource fail. |
<R> Flowable<R> |
Flowable.concatMapSingleDelayError(Function<? super T,? extends SingleSource<? extends R>> mapper)
Maps the upstream items into
SingleSource s and subscribes to them one after the
other succeeds or fails, emits their success values and delays all errors
till both this Flowable and all inner SingleSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapSingleDelayError(Function<? super T,? extends SingleSource<? extends R>> mapper,
boolean tillTheEnd)
Maps the upstream items into
SingleSource s and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays all errors
till both this Flowable and all inner SingleSource s terminate. |
<R> Flowable<R> |
Flowable.concatMapSingleDelayError(Function<? super T,? extends SingleSource<? extends R>> mapper,
boolean tillTheEnd,
int prefetch)
Maps the upstream items into
SingleSource s and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays errors
till both this Flowable and all inner SingleSource s terminate. |
Flowable<T> |
Flowable.concatWith(CompletableSource other)
Returns a
Flowable that emits items from this Flowable and when it completes normally, the
other CompletableSource is subscribed to and the returned Flowable emits its terminal events. |
Flowable<T> |
Maybe.concatWith(MaybeSource<? extends T> other)
Returns a Flowable that emits the items emitted from the current MaybeSource, then the next, one after
the other, without interleaving them.
|
Flowable<T> |
Flowable.concatWith(MaybeSource<? extends T> other)
Returns a
Flowable that emits the items from this Flowable followed by the success item or terminal events
of the other MaybeSource . |
Flowable<T> |
Flowable.concatWith(org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that emits the items emitted from the current Publisher, then the next, one after
the other, without interleaving them.
|
Flowable<T> |
Single.concatWith(SingleSource<? extends T> other)
Returns a Flowable that emits the item emitted by the source Single, then the item emitted by the
specified Single.
|
Flowable<T> |
Flowable.concatWith(SingleSource<? extends T> other)
Returns a
Flowable that emits the items from this Flowable followed by the success item or error event
of the other SingleSource . |
Single<Boolean> |
Flowable.contains(Object item)
Returns a Single that emits a Boolean that indicates whether the source Publisher emitted a
specified item.
|
Single<Long> |
Flowable.count()
Returns a Single that counts the total number of items emitted by the source Publisher and emits
this count as a 64-bit Long.
|
static <T> Flowable<T> |
Flowable.create(FlowableOnSubscribe<T> source,
BackpressureStrategy mode)
Provides an API (via a cold Flowable) that bridges the reactive world with the callback-style,
generally non-backpressured world.
|
<U> Flowable<T> |
Flowable.debounce(Function<? super T,? extends org.reactivestreams.Publisher<U>> debounceIndicator)
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the
source Publisher that are followed by another item within a computed debounce duration.
|
Flowable<T> |
Flowable.debounce(long timeout,
TimeUnit unit)
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the
source Publisher that are followed by newer items before a timeout value expires.
|
Flowable<T> |
Flowable.debounce(long timeout,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the
source Publisher that are followed by newer items before a timeout value expires on a specified
Scheduler.
|
Flowable<T> |
Flowable.defaultIfEmpty(T defaultItem)
Returns a Flowable that emits the items emitted by the source Publisher or a specified default item
if the source Publisher is empty.
|
static <T> Flowable<T> |
Flowable.defer(Callable<? extends org.reactivestreams.Publisher<? extends T>> supplier)
Returns a Flowable that calls a Publisher factory to create a Publisher for each new Subscriber
that subscribes.
|
<U> Flowable<T> |
Flowable.delay(Function<? super T,? extends org.reactivestreams.Publisher<U>> itemDelayIndicator)
Returns a Flowable that delays the emissions of the source Publisher via another Publisher on a
per-item basis.
|
Flowable<T> |
Flowable.delay(long delay,
TimeUnit unit)
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a
specified delay.
|
Flowable<T> |
Flowable.delay(long delay,
TimeUnit unit,
boolean delayError)
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a
specified delay.
|
Flowable<T> |
Flowable.delay(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a
specified delay.
|
Flowable<T> |
Flowable.delay(long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns a Flowable that emits the items emitted by the source Publisher shifted forward in time by a
specified delay.
|
<U,V> Maybe<T> |
Maybe.delay(org.reactivestreams.Publisher<U> delayIndicator)
Delays the emission of this Maybe until the given Publisher signals an item or completes.
|
<U,V> Flowable<T> |
Flowable.delay(org.reactivestreams.Publisher<U> subscriptionIndicator,
Function<? super T,? extends org.reactivestreams.Publisher<V>> itemDelayIndicator)
Returns a Flowable that delays the subscription to and emissions from the source Publisher via another
Publisher on a per-item basis.
|
Flowable<T> |
Flowable.delaySubscription(long delay,
TimeUnit unit)
Returns a Flowable that delays the subscription to the source Publisher by a given amount of time.
|
Flowable<T> |
Flowable.delaySubscription(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that delays the subscription to the source Publisher by a given amount of time,
both waiting and subscribing on a given Scheduler.
|
<U> Single<T> |
Single.delaySubscription(org.reactivestreams.Publisher<U> other)
Delays the actual subscription to the current Single until the given other Publisher
signals its first value or completes.
|
<U> Maybe<T> |
Maybe.delaySubscription(org.reactivestreams.Publisher<U> subscriptionIndicator)
Returns a Maybe that delays the subscription to this Maybe
until the other Publisher emits an element or completes normally.
|
<U> Flowable<T> |
Flowable.delaySubscription(org.reactivestreams.Publisher<U> subscriptionIndicator)
Returns a Flowable that delays the subscription to this Publisher
until the other Publisher emits an element or completes normally.
|
<T2> Flowable<T2> |
Flowable.dematerialize()
Deprecated.
in 2.2.4; inherently type-unsafe as it overrides the output generic type. Use
Flowable.dematerialize(Function) instead. |
<R> Flowable<R> |
Flowable.dematerialize(Function<? super T,Notification<R>> selector)
Returns a Flowable that reverses the effect of
materialize by transforming the
Notification objects extracted from the source items via a selector function
into their respective Subscriber signal types. |
Flowable<T> |
Flowable.distinct()
Returns a Flowable that emits all items emitted by the source Publisher that are distinct
based on
Object.equals(Object) comparison. |
<K> Flowable<T> |
Flowable.distinct(Function<? super T,K> keySelector)
Returns a Flowable that emits all items emitted by the source Publisher that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function. |
<K> Flowable<T> |
Flowable.distinct(Function<? super T,K> keySelector,
Callable<? extends Collection<? super K>> collectionSupplier)
Returns a Flowable that emits all items emitted by the source Publisher that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function. |
Flowable<T> |
Flowable.distinctUntilChanged()
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their
immediate predecessors based on
Object.equals(Object) comparison. |
Flowable<T> |
Flowable.distinctUntilChanged(BiPredicate<? super T,? super T> comparer)
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their
immediate predecessors when compared with each other via the provided comparator function.
|
<K> Flowable<T> |
Flowable.distinctUntilChanged(Function<? super T,K> keySelector)
Returns a Flowable that emits all items emitted by the source Publisher that are distinct from their
immediate predecessors, according to a key selector function and based on
Object.equals(Object) comparison
of those objects returned by the key selector function. |
Flowable<T> |
Flowable.doAfterNext(Consumer<? super T> onAfterNext)
Calls the specified consumer with the current item after this item has been emitted to the downstream.
|
Flowable<T> |
Flowable.doAfterTerminate(Action onAfterTerminate)
|
Flowable<T> |
Flowable.doFinally(Action onFinally)
Calls the specified action after this Flowable signals onError or onCompleted or gets canceled by
the downstream.
|
Flowable<T> |
Flowable.doOnCancel(Action onCancel)
Calls the cancel
Action if the downstream cancels the sequence. |
Flowable<T> |
Flowable.doOnComplete(Action onComplete)
Modifies the source Publisher so that it invokes an action when it calls
onComplete . |
Flowable<T> |
Flowable.doOnEach(Consumer<? super Notification<T>> onNotification)
Modifies the source Publisher so that it invokes an action for each item it emits.
|
Flowable<T> |
Flowable.doOnEach(org.reactivestreams.Subscriber<? super T> subscriber)
Modifies the source Publisher so that it notifies a Subscriber for each item and terminal event it emits.
|
Flowable<T> |
Flowable.doOnError(Consumer<? super Throwable> onError)
Modifies the source Publisher so that it invokes an action if it calls
onError . |
Flowable<T> |
Flowable.doOnLifecycle(Consumer<? super org.reactivestreams.Subscription> onSubscribe,
LongConsumer onRequest,
Action onCancel)
Calls the appropriate onXXX method (shared between all Subscribers) for the lifecycle events of
the sequence (subscription, cancellation, requesting).
|
Flowable<T> |
Flowable.doOnNext(Consumer<? super T> onNext)
Modifies the source Publisher so that it invokes an action when it calls
onNext . |
Flowable<T> |
Flowable.doOnRequest(LongConsumer onRequest)
Modifies the source
Publisher so that it invokes the given action when it receives a
request for more items. |
Flowable<T> |
Flowable.doOnSubscribe(Consumer<? super org.reactivestreams.Subscription> onSubscribe)
Modifies the source
Publisher so that it invokes the given action when it is subscribed from
its subscribers. |
Flowable<T> |
Flowable.doOnTerminate(Action onTerminate)
Modifies the source Publisher so that it invokes an action when it calls
onComplete or
onError . |
Maybe<T> |
Flowable.elementAt(long index)
Returns a Maybe that emits the single item at a specified index in a sequence of emissions from
this Flowable or completes if this Flowable sequence has fewer elements than index.
|
Single<T> |
Flowable.elementAt(long index,
T defaultItem)
Returns a Flowable that emits the item found at a specified index in a sequence of emissions from
this Flowable, or a default item if that index is out of range.
|
Single<T> |
Flowable.elementAtOrError(long index)
Returns a Flowable that emits the item found at a specified index in a sequence of emissions from
this Flowable or signals a
NoSuchElementException if this Flowable has fewer elements than index. |
static <T> Flowable<T> |
Flowable.empty()
Returns a Flowable that emits no items to the
Subscriber and immediately invokes its
onComplete method. |
static <T> Flowable<T> |
Flowable.error(Callable<? extends Throwable> supplier)
Returns a Flowable that invokes a
Subscriber 's onError method when the
Subscriber subscribes to it. |
static <T> Flowable<T> |
Flowable.error(Throwable throwable)
Returns a Flowable that invokes a
Subscriber 's onError method when the
Subscriber subscribes to it. |
Flowable<T> |
Flowable.filter(Predicate<? super T> predicate)
Filters items emitted by a Publisher by only emitting those that satisfy a specified predicate.
|
Single<T> |
Flowable.first(T defaultItem)
Returns a Single that emits only the very first item emitted by this Flowable, or a default
item if this Flowable completes without emitting anything.
|
Maybe<T> |
Flowable.firstElement()
Returns a Maybe that emits only the very first item emitted by this Flowable or
completes if this Flowable is empty.
|
Single<T> |
Flowable.firstOrError()
Returns a Single that emits only the very first item emitted by this Flowable or
signals a
NoSuchElementException if this Flowable is empty. |
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a Flowable that emits items based on applying a function that you supply to each item emitted
by the source Publisher, where that function returns a Publisher, and then merging those resulting
Publishers and emitting the results of this merger.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
boolean delayErrors)
Returns a Flowable that emits items based on applying a function that you supply to each item emitted
by the source Publisher, where that function returns a Publisher, and then merging those resulting
Publishers and emitting the results of this merger.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
boolean delayErrors,
int maxConcurrency)
Returns a Flowable that emits items based on applying a function that you supply to each item emitted
by the source Publisher, where that function returns a Publisher, and then merging those resulting
Publishers and emitting the results of this merger, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
boolean delayErrors,
int maxConcurrency,
int bufferSize)
Returns a Flowable that emits items based on applying a function that you supply to each item emitted
by the source Publisher, where that function returns a Publisher, and then merging those resulting
Publishers and emitting the results of this merger, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> onNextMapper,
Function<? super Throwable,? extends org.reactivestreams.Publisher<? extends R>> onErrorMapper,
Callable<? extends org.reactivestreams.Publisher<? extends R>> onCompleteSupplier)
Returns a Flowable that applies a function to each item emitted or notification raised by the source
Publisher and then flattens the Publishers returned from these functions and emits the resulting items.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> onNextMapper,
Function<Throwable,? extends org.reactivestreams.Publisher<? extends R>> onErrorMapper,
Callable<? extends org.reactivestreams.Publisher<? extends R>> onCompleteSupplier,
int maxConcurrency)
Returns a Flowable that applies a function to each item emitted or notification raised by the source
Publisher and then flattens the Publishers returned from these functions and emits the resulting items,
while limiting the maximum number of concurrent subscriptions to these Publishers.
|
<R> Flowable<R> |
Flowable.flatMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int maxConcurrency)
Returns a Flowable that emits items based on applying a function that you supply to each item emitted
by the source Publisher, where that function returns a Publisher, and then merging those resulting
Publishers and emitting the results of this merger, 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)
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.
|
Completable |
Flowable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete.
|
Completable |
Flowable.flatMapCompletable(Function<? super T,? extends CompletableSource> mapper,
boolean delayErrors,
int maxConcurrency)
Maps each element of the upstream Flowable into CompletableSources, subscribes to them and
waits until the upstream and all CompletableSources complete, optionally delaying all errors.
|
<U> Flowable<U> |
Flowable.flatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper)
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.
|
<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.
|
<U> Flowable<U> |
Flowable.flatMapIterable(Function<? super T,? extends Iterable<? extends U>> mapper,
int bufferSize)
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.
|
<R> Flowable<R> |
Flowable.flatMapMaybe(Function<? super T,? extends MaybeSource<? extends R>> mapper)
Maps each element of the upstream Flowable into MaybeSources, subscribes to all of them
and merges their onSuccess values, in no particular order, into a single Flowable sequence.
|
<R> Flowable<R> |
Flowable.flatMapMaybe(Function<? super T,? extends MaybeSource<? extends R>> mapper,
boolean delayErrors,
int maxConcurrency)
Maps each element of the upstream Flowable into MaybeSources, subscribes to at most
maxConcurrency MaybeSources at a time and merges their onSuccess values,
in no particular order, into a single Flowable sequence, optionally delaying all errors. |
<R> Flowable<R> |
Single.flatMapPublisher(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a Flowable that emits items based on applying a specified function to the item emitted by the
source Single, where that function returns a Publisher.
|
<R> Flowable<R> |
Maybe.flatMapPublisher(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a Flowable that emits items based on applying a specified function to the item emitted by the
source Maybe, where that function returns a Publisher.
|
<R> Flowable<R> |
Flowable.flatMapSingle(Function<? super T,? extends SingleSource<? extends R>> mapper)
Maps each element of the upstream Flowable into SingleSources, subscribes to all of them
and merges their onSuccess values, in no particular order, into a single Flowable sequence.
|
<R> Flowable<R> |
Flowable.flatMapSingle(Function<? super T,? extends SingleSource<? extends R>> mapper,
boolean delayErrors,
int maxConcurrency)
Maps each element of the upstream Flowable into SingleSources, subscribes to at most
maxConcurrency SingleSources at a time and merges their onSuccess values,
in no particular order, into a single Flowable sequence, optionally delaying all errors. |
<U> Flowable<U> |
Single.flattenAsFlowable(Function<? super T,? extends Iterable<? extends U>> mapper)
Returns a Flowable that merges each item emitted by the source Single with the values in an
Iterable corresponding to that item that is generated by a selector.
|
<U> Flowable<U> |
Maybe.flattenAsFlowable(Function<? super T,? extends Iterable<? extends U>> mapper)
Returns a Flowable that merges each item emitted by the source Maybe with the values in an
Iterable corresponding to that item that is generated by a selector.
|
Disposable |
Flowable.forEach(Consumer<? super T> onNext)
Subscribes to the
Publisher and receives notifications for each element. |
Disposable |
Flowable.forEachWhile(Predicate<? super T> onNext)
Subscribes to the
Publisher and receives notifications for each element until the
onNext Predicate returns false. |
Disposable |
Flowable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to the
Publisher and receives notifications for each element and error events until the
onNext Predicate returns false. |
Disposable |
Flowable.forEachWhile(Predicate<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to the
Publisher and receives notifications for each element and the terminal events until the
onNext Predicate returns false. |
static <T> Flowable<T> |
Flowable.fromArray(T... items)
Converts an Array into a Publisher that emits the items in the Array.
|
static <T> Flowable<T> |
Flowable.fromCallable(Callable<? extends T> supplier)
Returns a Flowable that, when a Subscriber subscribes to it, invokes a function you specify and then
emits the value returned from that function.
|
static <T> Flowable<T> |
Flowable.fromFuture(Future<? extends T> future)
Converts a
Future into a Publisher. |
static <T> Flowable<T> |
Flowable.fromFuture(Future<? extends T> future,
long timeout,
TimeUnit unit)
Converts a
Future into a Publisher, with a timeout on the Future. |
static <T> Flowable<T> |
Flowable.fromFuture(Future<? extends T> future,
long timeout,
TimeUnit unit,
Scheduler scheduler)
Converts a
Future into a Publisher, with a timeout on the Future. |
static <T> Flowable<T> |
Flowable.fromFuture(Future<? extends T> future,
Scheduler scheduler)
|
static <T> Flowable<T> |
Flowable.fromIterable(Iterable<? extends T> source)
Converts an
Iterable sequence into a Publisher that emits the items in the sequence. |
static <T> Single<T> |
Single.fromPublisher(org.reactivestreams.Publisher<? extends T> publisher)
Wraps a specific Publisher into a Single and signals its single element or error.
|
static <T> Observable<T> |
Observable.fromPublisher(org.reactivestreams.Publisher<? extends T> publisher)
Converts an arbitrary Reactive-Streams Publisher into an Observable.
|
static <T> Flowable<T> |
Flowable.fromPublisher(org.reactivestreams.Publisher<? extends T> source)
Converts an arbitrary Reactive-Streams Publisher into a Flowable if not already a
Flowable.
|
static <T> Completable |
Completable.fromPublisher(org.reactivestreams.Publisher<T> publisher)
Returns a Completable instance that subscribes to the given publisher, ignores all values and
emits only the terminal event.
|
static <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiConsumer<S,Emitter<T>> generator)
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
|
static <T,S> Flowable<T> |
Flowable.generate(Callable<S> initialState,
BiConsumer<S,Emitter<T>> generator,
Consumer<? super S> disposeState)
Returns a cold, synchronous, stateful and backpressure-aware 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> 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.
|
static <T> Flowable<T> |
Flowable.generate(Consumer<Emitter<T>> generator)
Returns a cold, synchronous, stateless and backpressure-aware generator of values.
|
<K> Flowable<GroupedFlowable<K,T>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<K> Flowable<GroupedFlowable<K,T>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
boolean delayError)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<K,V> Flowable<GroupedFlowable<K,V>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<K,V> Flowable<GroupedFlowable<K,V>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
boolean delayError)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<K,V> Flowable<GroupedFlowable<K,V>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
boolean delayError,
int bufferSize)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<K,V> Flowable<GroupedFlowable<K,V>> |
Flowable.groupBy(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
boolean delayError,
int bufferSize,
Function<? super Consumer<Object>,? extends Map<K,Object>> evictingMapFactory)
Groups the items emitted by a
Publisher according to a specified criterion, and emits these
grouped items as GroupedFlowable s. |
<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.
|
Flowable<T> |
Flowable.hide()
Hides the identity of this Flowable and its Subscription.
|
Completable |
Flowable.ignoreElements()
Ignores all items emitted by the source Publisher and only calls
onComplete or onError . |
static Flowable<Long> |
Flowable.interval(long initialDelay,
long period,
TimeUnit unit)
Returns a Flowable that emits a
0L after the initialDelay and ever-increasing numbers
after each period of time thereafter. |
static Flowable<Long> |
Flowable.interval(long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits a
0L after the initialDelay and ever-increasing numbers
after each period of time thereafter, on a specified Scheduler . |
static Flowable<Long> |
Flowable.interval(long period,
TimeUnit unit)
Returns a Flowable that emits a sequential number every specified interval of time.
|
static Flowable<Long> |
Flowable.interval(long period,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits a sequential number every specified interval of time, on a
specified Scheduler.
|
static Flowable<Long> |
Flowable.intervalRange(long start,
long count,
long initialDelay,
long period,
TimeUnit unit)
Signals a range of long values, the first after some initial delay and the rest periodically after.
|
static Flowable<Long> |
Flowable.intervalRange(long start,
long count,
long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler)
Signals a range of long values, the first after some initial delay and the rest periodically after.
|
Single<Boolean> |
Flowable.isEmpty()
Returns a Single that emits
true if the source Publisher is empty, otherwise false . |
<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.
|
static <T> Flowable<T> |
Flowable.just(T item)
Returns a Flowable that signals the given (constant reference) item and then completes.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2)
Converts two items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3)
Converts three items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4)
Converts four items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5)
Converts five items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5,
T item6)
Converts six items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5,
T item6,
T item7)
Converts seven items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5,
T item6,
T item7,
T item8)
Converts eight items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5,
T item6,
T item7,
T item8,
T item9)
Converts nine items into a Publisher that emits those items.
|
static <T> Flowable<T> |
Flowable.just(T item1,
T item2,
T item3,
T item4,
T item5,
T item6,
T item7,
T item8,
T item9,
T item10)
Converts ten items into a Publisher that emits those items.
|
Single<T> |
Flowable.last(T defaultItem)
Returns a Single that emits only the last item emitted by this Flowable, or a default item
if this Flowable completes without emitting any items.
|
Maybe<T> |
Flowable.lastElement()
Returns a Maybe that emits the last item emitted by this Flowable or completes if
this Flowable is empty.
|
Single<T> |
Flowable.lastOrError()
Returns a Single that emits only the last item emitted by this Flowable or signals
a
NoSuchElementException if this Flowable is empty. |
<R> Flowable<R> |
Flowable.lift(FlowableOperator<? extends R,? super T> lifter)
This method requires advanced knowledge about building operators, please consider
other standard composition methods first;
Returns a
Flowable which, when subscribed to, invokes the apply(Subscriber) method
of the provided FlowableOperator for each individual downstream Subscriber and allows the
insertion of a custom operator by accessing the downstream's Subscriber during this subscription phase
and providing a new Subscriber , containing the custom operator's intended business logic, that will be
used in the subscription process going further upstream. |
Flowable<T> |
Flowable.limit(long count)
Limits both the number of upstream items (after which the sequence completes)
and the total downstream request amount requested from the upstream to
possibly prevent the creation of excess items by the upstream.
|
<R> Flowable<R> |
Flowable.map(Function<? super T,? extends R> mapper)
Returns a Flowable that applies a specified function to each item emitted by the source Publisher and
emits the results of these function applications.
|
Flowable<Notification<T>> |
Flowable.materialize()
Returns a Flowable that represents all of the emissions and notifications from the source
Publisher into emissions marked with their original types within
Notification objects. |
static <T> Flowable<T> |
Maybe.merge(Iterable<? extends MaybeSource<? extends T>> sources)
Merges an Iterable sequence of MaybeSource instances into a single Flowable sequence,
running all MaybeSources at once.
|
static <T> Flowable<T> |
Flowable.merge(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Flattens an Iterable of Publishers into one Publisher, without any transformation.
|
static <T> Flowable<T> |
Flowable.merge(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency)
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the
number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Flowable.merge(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency,
int bufferSize)
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the
number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Single.merge(Iterable<? extends SingleSource<? extends T>> sources)
Merges an Iterable sequence of SingleSource instances into a single Flowable sequence,
running all SingleSources at once.
|
static <T> Flowable<T> |
Maybe.merge(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2)
Flattens two MaybeSources into a single Flowable, without any transformation.
|
static <T> Flowable<T> |
Maybe.merge(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3)
Flattens three MaybeSources into a single Flowable, without any transformation.
|
static <T> Flowable<T> |
Maybe.merge(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3,
MaybeSource<? extends T> source4)
Flattens four MaybeSources into a single Flowable, without any transformation.
|
static Completable |
Completable.merge(org.reactivestreams.Publisher<? extends CompletableSource> sources)
Returns a Completable instance that subscribes to all sources at once and
completes only when all source Completables complete or one of them emits an error.
|
static Completable |
Completable.merge(org.reactivestreams.Publisher<? extends CompletableSource> sources,
int maxConcurrency)
Returns a Completable instance that keeps subscriptions to a limited number of sources at once and
completes only when all source Completables complete or one of them emits an error.
|
static <T> Flowable<T> |
Maybe.merge(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources)
Merges a Flowable sequence of MaybeSource instances into a single Flowable sequence,
running all MaybeSources at once.
|
static <T> Flowable<T> |
Maybe.merge(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources,
int maxConcurrency)
Merges a Flowable sequence of MaybeSource instances into a single Flowable sequence,
running at most maxConcurrency MaybeSources at once.
|
static <T> Flowable<T> |
Flowable.merge(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Flattens a Publisher that emits Publishers into a single Publisher that emits the items emitted by
those Publishers, without any transformation.
|
static <T> Flowable<T> |
Flowable.merge(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency)
Flattens a Publisher that emits Publishers into a single Publisher that emits the items emitted by
those Publishers, without any transformation, while limiting the maximum number of concurrent
subscriptions to these Publishers.
|
static <T> Flowable<T> |
Single.merge(org.reactivestreams.Publisher<? extends SingleSource<? extends T>> sources)
Merges a Flowable sequence of SingleSource instances into a single Flowable sequence,
running all SingleSources at once.
|
static <T> Flowable<T> |
Flowable.merge(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2)
Flattens two Publishers into a single Publisher, without any transformation.
|
static <T> Flowable<T> |
Flowable.merge(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3)
Flattens three Publishers into a single Publisher, without any transformation.
|
static <T> Flowable<T> |
Flowable.merge(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3,
org.reactivestreams.Publisher<? extends T> source4)
Flattens four Publishers into a single Publisher, without any transformation.
|
static <T> Flowable<T> |
Single.merge(SingleSource<? extends T> source1,
SingleSource<? extends T> source2)
Flattens two Singles into a single Flowable, without any transformation.
|
static <T> Flowable<T> |
Single.merge(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3)
Flattens three Singles into a single Flowable, without any transformation.
|
static <T> Flowable<T> |
Single.merge(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3,
SingleSource<? extends T> source4)
Flattens four Singles into a single Flowable, without any transformation.
|
static <T> Flowable<T> |
Flowable.mergeArray(int maxConcurrency,
int bufferSize,
org.reactivestreams.Publisher<? extends T>... sources)
Flattens an Iterable of Publishers into one Publisher, without any transformation, while limiting the
number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Maybe.mergeArray(MaybeSource<? extends T>... sources)
Merges an array sequence of MaybeSource instances into a single Flowable sequence,
running all MaybeSources at once.
|
static <T> Flowable<T> |
Flowable.mergeArray(org.reactivestreams.Publisher<? extends T>... sources)
Flattens an Array of Publishers into one Publisher, without any transformation.
|
static <T> Flowable<T> |
Flowable.mergeArrayDelayError(int maxConcurrency,
int bufferSize,
org.reactivestreams.Publisher<? extends T>... sources)
Flattens an array of Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Maybe.mergeArrayDelayError(MaybeSource<? extends T>... sources)
Flattens an array of MaybeSources into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source MaybeSources without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeArrayDelayError(org.reactivestreams.Publisher<? extends T>... sources)
Flattens an array of Publishers into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(Iterable<? extends MaybeSource<? extends T>> sources)
Flattens an Iterable of MaybeSources into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source MaybeSources without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources)
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency)
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency,
int bufferSize)
Flattens an Iterable of Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them, while limiting the number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Single.mergeDelayError(Iterable<? extends SingleSource<? extends T>> sources)
Merges an Iterable sequence of SingleSource instances into a single Flowable sequence,
running all SingleSources at once and delaying any error(s) until all sources succeed or fail.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2)
Flattens two MaybeSources into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source MaybeSources without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3)
Flattens three MaybeSource into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from all of the source MaybeSources without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(MaybeSource<? extends T> source1,
MaybeSource<? extends T> source2,
MaybeSource<? extends T> source3,
MaybeSource<? extends T> source4)
Flattens four MaybeSources into one Flowable, in a way that allows a Subscriber to receive all
successfully emitted items from all of the source MaybeSources without being interrupted by an error
notification from one of them.
|
static Completable |
Completable.mergeDelayError(org.reactivestreams.Publisher<? extends CompletableSource> sources)
Returns a Completable that subscribes to all Completables in the source sequence and delays
any error emitted by either the sources observable or any of the inner Completables until all of
them terminate in a way or another.
|
static Completable |
Completable.mergeDelayError(org.reactivestreams.Publisher<? extends CompletableSource> sources,
int maxConcurrency)
Returns a Completable that subscribes to a limited number of inner Completables at once in
the source sequence and delays any error emitted by either the sources
observable or any of the inner Completables until all of
them terminate in a way or another.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources)
Flattens a Publisher that emits MaybeSources into one Publisher, in a way that allows a Subscriber to
receive all successfully emitted items from all of the source MaybeSources without being interrupted by
an error notification from one of them or even the main Publisher.
|
static <T> Flowable<T> |
Maybe.mergeDelayError(org.reactivestreams.Publisher<? extends MaybeSource<? extends T>> sources,
int maxConcurrency)
Flattens a Publisher that emits MaybeSources into one Publisher, in a way that allows a Subscriber to
receive all successfully emitted items from all of the source MaybeSources without being interrupted by
an error notification from one of them or even the main Publisher as well as limiting the total number of active MaybeSources.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Flattens a Publisher that emits Publishers into one Publisher, in a way that allows a Subscriber to
receive all successfully emitted items from all of the source Publishers without being interrupted by
an error notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int maxConcurrency)
Flattens a Publisher that emits Publishers into one Publisher, in a way that allows a Subscriber to
receive all successfully emitted items from all of the source Publishers without being interrupted by
an error notification from one of them, while limiting the
number of concurrent subscriptions to these Publishers.
|
static <T> Flowable<T> |
Single.mergeDelayError(org.reactivestreams.Publisher<? extends SingleSource<? extends T>> sources)
Merges a Flowable sequence of SingleSource instances into a single Flowable sequence,
running all SingleSources at once and delaying any error(s) until all sources succeed or fail.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2)
Flattens two Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from each of the source Publishers without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3)
Flattens three Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from all of the source Publishers without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Flowable.mergeDelayError(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
org.reactivestreams.Publisher<? extends T> source3,
org.reactivestreams.Publisher<? extends T> source4)
Flattens four Publishers into one Publisher, in a way that allows a Subscriber to receive all
successfully emitted items from all of the source Publishers without being interrupted by an error
notification from one of them.
|
static <T> Flowable<T> |
Single.mergeDelayError(SingleSource<? extends T> source1,
SingleSource<? extends T> source2)
Flattens two Singles into a single Flowable, without any transformation, delaying
any error(s) until all sources succeed or fail.
|
static <T> Flowable<T> |
Single.mergeDelayError(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3)
Flattens three Singles into a single Flowable, without any transformation, delaying
any error(s) until all sources succeed or fail.
|
static <T> Flowable<T> |
Single.mergeDelayError(SingleSource<? extends T> source1,
SingleSource<? extends T> source2,
SingleSource<? extends T> source3,
SingleSource<? extends T> source4)
Flattens four Singles into a single Flowable, without any transformation, delaying
any error(s) until all sources succeed or fail.
|
Flowable<T> |
Flowable.mergeWith(CompletableSource other)
Relays the items of this Flowable and completes only when the other CompletableSource completes
as well.
|
Flowable<T> |
Maybe.mergeWith(MaybeSource<? extends T> other)
Flattens this and another Maybe into a single Flowable, without any transformation.
|
Flowable<T> |
Flowable.mergeWith(MaybeSource<? extends T> other)
Merges the sequence of items of this Flowable with the success value of the other MaybeSource
or waits for both to complete normally if the MaybeSource is empty.
|
Flowable<T> |
Flowable.mergeWith(org.reactivestreams.Publisher<? extends T> other)
Flattens this and another Publisher into a single Publisher, without any transformation.
|
Flowable<T> |
Single.mergeWith(SingleSource<? extends T> other)
Flattens this and another Single into a single Flowable, without any transformation.
|
Flowable<T> |
Flowable.mergeWith(SingleSource<? extends T> other)
Merges the sequence of items of this Flowable with the success value of the other SingleSource.
|
static <T> Flowable<T> |
Flowable.never()
Returns a Flowable that never sends any items or notifications to a
Subscriber . |
Flowable<T> |
Flowable.observeOn(Scheduler scheduler)
Modifies a Publisher to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with a bounded buffer of Flowable.bufferSize() slots. |
Flowable<T> |
Flowable.observeOn(Scheduler scheduler,
boolean delayError)
Modifies a Publisher to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with a bounded buffer and optionally delays onError notifications. |
Flowable<T> |
Flowable.observeOn(Scheduler scheduler,
boolean delayError,
int bufferSize)
Modifies a Publisher to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with a bounded buffer of configurable size and optionally delays onError notifications. |
<U> Flowable<U> |
Flowable.ofType(Class<U> clazz)
Filters the items emitted by a Publisher, only emitting those of the specified type.
|
Flowable<T> |
Flowable.onBackpressureBuffer()
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer these
items indefinitely until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(boolean delayError)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer these
items indefinitely until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
Action onOverflow)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
boolean delayError)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
boolean delayError,
boolean unbounded)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(int capacity,
boolean delayError,
boolean unbounded,
Action onOverflow)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureBuffer(long capacity,
Action onOverflow,
BackpressureOverflowStrategy overflowStrategy)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to buffer up to
a given amount of items until they can be emitted.
|
Flowable<T> |
Flowable.onBackpressureDrop()
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to discard,
rather than emit, those items that its Subscriber is not prepared to observe.
|
Flowable<T> |
Flowable.onBackpressureDrop(Consumer<? super T> onDrop)
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to discard,
rather than emit, those items that its Subscriber is not prepared to observe.
|
Flowable<T> |
Flowable.onBackpressureLatest()
Instructs a Publisher that is emitting items faster than its Subscriber can consume them to
hold onto the latest value and emit that on request.
|
Flowable<T> |
Flowable.onErrorResumeNext(Function<? super Throwable,? extends org.reactivestreams.Publisher<? extends T>> resumeFunction)
Instructs a Publisher to pass control to another Publisher rather than invoking
onError if it encounters an error. |
Flowable<T> |
Flowable.onErrorResumeNext(org.reactivestreams.Publisher<? extends T> next)
Instructs a Publisher to pass control to another Publisher rather than invoking
onError if it encounters an error. |
Flowable<T> |
Flowable.onErrorReturn(Function<? super Throwable,? extends T> valueSupplier)
Instructs a Publisher to emit an item (returned by a specified function) rather than invoking
onError if it encounters an error. |
Flowable<T> |
Flowable.onErrorReturnItem(T item)
Instructs a Publisher to emit an item (returned by a specified function) rather than invoking
onError if it encounters an error. |
Flowable<T> |
Flowable.onExceptionResumeNext(org.reactivestreams.Publisher<? extends T> next)
Instructs a Publisher to pass control to another Publisher rather than invoking
onError if it encounters an Exception . |
Flowable<T> |
Flowable.onTerminateDetach()
Nulls out references to the upstream producer and downstream Subscriber if
the sequence is terminated or downstream cancels.
|
ParallelFlowable<T> |
Flowable.parallel()
Parallelizes the flow by creating multiple 'rails' (equal to the number of CPUs)
and dispatches the upstream items to them in a round-robin fashion.
|
ParallelFlowable<T> |
Flowable.parallel(int parallelism)
Parallelizes the flow by creating the specified number of 'rails'
and dispatches the upstream items to them in a round-robin fashion.
|
ParallelFlowable<T> |
Flowable.parallel(int parallelism,
int prefetch)
Parallelizes the flow by creating the specified number of 'rails'
and dispatches the upstream items to them in a round-robin fashion and
uses the defined per-'rail' prefetch amount.
|
ConnectableFlowable<T> |
Flowable.publish()
Returns a
ConnectableFlowable , which is a variety of Publisher that waits until its
connect method is called before it begins emitting items to those
Subscriber s that have subscribed to it. |
<R> Flowable<R> |
Flowable.publish(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<? extends R>> selector,
int prefetch)
Returns a Flowable that emits the results of invoking a specified selector on items emitted by a
ConnectableFlowable that shares a single subscription to the underlying sequence. |
<R> Flowable<R> |
Flowable.publish(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector)
Returns a Flowable that emits the results of invoking a specified selector on items emitted by a
ConnectableFlowable that shares a single subscription to the underlying sequence. |
ConnectableFlowable<T> |
Flowable.publish(int bufferSize)
Returns a
ConnectableFlowable , which is a variety of Publisher that waits until its
connect method is called before it begins emitting items to those
Subscriber s that have subscribed to it. |
static Flowable<Integer> |
Flowable.range(int start,
int count)
Returns a Flowable that emits a sequence of Integers within a specified range.
|
static Flowable<Long> |
Flowable.rangeLong(long start,
long count)
Returns a Flowable that emits a sequence of Longs within a specified range.
|
Flowable<T> |
Flowable.rebatchRequests(int n)
Requests
n initially from the upstream and then 75% of n subsequently
after 75% of n values have been emitted to the downstream. |
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> |
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> |
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.
|
Flowable<T> |
Single.repeat()
Repeatedly re-subscribes to the current Single and emits each success value.
|
Flowable<T> |
Maybe.repeat()
Returns a Flowable that repeats the sequence of items emitted by the source Maybe indefinitely.
|
Flowable<T> |
Flowable.repeat()
Returns a Flowable that repeats the sequence of items emitted by the source Publisher indefinitely.
|
Flowable<T> |
Single.repeat(long times)
Re-subscribes to the current Single at most the given number of times and emits each success value.
|
Flowable<T> |
Maybe.repeat(long times)
Returns a Flowable that repeats the sequence of items emitted by the source Maybe at most
count times. |
Flowable<T> |
Flowable.repeat(long times)
Returns a Flowable that repeats the sequence of items emitted by the source Publisher at most
count times. |
Flowable<T> |
Single.repeatUntil(BooleanSupplier stop)
Re-subscribes to the current Single until the given BooleanSupplier returns true.
|
Flowable<T> |
Maybe.repeatUntil(BooleanSupplier stop)
Returns a Flowable that repeats the sequence of items emitted by the source Maybe until
the provided stop function returns true.
|
Flowable<T> |
Flowable.repeatUntil(BooleanSupplier stop)
Returns a Flowable that repeats the sequence of items emitted by the source Publisher until
the provided stop function returns true.
|
Flowable<T> |
Single.repeatWhen(Function<? super Flowable<Object>,? extends org.reactivestreams.Publisher<?>> handler)
Re-subscribes to the current Single if
the Publisher returned by the handler function signals a value in response to a
value signalled through the Flowable the handle receives.
|
Flowable<T> |
Maybe.repeatWhen(Function<? super Flowable<Object>,? extends org.reactivestreams.Publisher<?>> handler)
Returns a Flowable that emits the same values as the source Publisher with the exception of an
onComplete . |
Flowable<T> |
Flowable.repeatWhen(Function<? super Flowable<Object>,? extends org.reactivestreams.Publisher<?>> handler)
Returns a Flowable that emits the same values as the source Publisher with the exception of an
onComplete . |
ConnectableFlowable<T> |
Flowable.replay()
Returns a
ConnectableFlowable that shares a single subscription to the underlying Publisher
that will replay all of its items and notifications to any future Subscriber . |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector)
Returns a Flowable that emits items that are the results of invoking a specified selector on the items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
int bufferSize)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying bufferSize notifications. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
int bufferSize,
long time,
TimeUnit unit)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying no more than bufferSize items that were emitted within a specified time window. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying no more than bufferSize items that were emitted within a specified time window. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
int bufferSize,
Scheduler scheduler)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying a maximum of bufferSize items. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
long time,
TimeUnit unit)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying all items that were emitted within a specified time window. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher,
replaying all items that were emitted within a specified time window. |
<R> Flowable<R> |
Flowable.replay(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
Scheduler scheduler)
Returns a Flowable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableFlowable that shares a single subscription to the source Publisher. |
ConnectableFlowable<T> |
Flowable.replay(int bufferSize)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher that
replays at most bufferSize items emitted by that Publisher. |
ConnectableFlowable<T> |
Flowable.replay(int bufferSize,
long time,
TimeUnit unit)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher and
replays at most bufferSize items that were emitted during a specified time window. |
ConnectableFlowable<T> |
Flowable.replay(int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher and
that replays a maximum of bufferSize items that are emitted within a specified time window. |
ConnectableFlowable<T> |
Flowable.replay(int bufferSize,
Scheduler scheduler)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher and
replays at most bufferSize items emitted by that Publisher. |
ConnectableFlowable<T> |
Flowable.replay(long time,
TimeUnit unit)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher and
replays all items emitted by that Publisher within a specified time window. |
ConnectableFlowable<T> |
Flowable.replay(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher and
replays all items emitted by that Publisher within a specified time window. |
ConnectableFlowable<T> |
Flowable.replay(Scheduler scheduler)
Returns a
ConnectableFlowable that shares a single subscription to the source Publisher that
will replay all of its items and notifications to any future Subscriber on the given
Scheduler . |
Flowable<T> |
Flowable.retry()
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls
onError
(infinite retry count). |
Flowable<T> |
Flowable.retry(BiPredicate<? super Integer,? super Throwable> predicate)
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls
onError
and the predicate returns true for that specific exception and retry count. |
Flowable<T> |
Flowable.retry(long count)
Returns a Flowable that mirrors the source Publisher, resubscribing to it if it calls
onError
up to a specified number of retries. |
Flowable<T> |
Flowable.retry(long times,
Predicate<? super Throwable> predicate)
Retries at most times or until the predicate returns false, whichever happens first.
|
Flowable<T> |
Flowable.retry(Predicate<? super Throwable> predicate)
Retries the current Flowable if the predicate returns true.
|
Flowable<T> |
Flowable.retryUntil(BooleanSupplier stop)
Retries until the given stop function returns true.
|
Flowable<T> |
Flowable.retryWhen(Function<? super Flowable<Throwable>,? extends org.reactivestreams.Publisher<?>> handler)
Returns a Flowable that emits the same values as the source Publisher with the exception of an
onError . |
void |
Flowable.safeSubscribe(org.reactivestreams.Subscriber<? super T> s)
Subscribes to the current Flowable and wraps the given Subscriber into a SafeSubscriber
(if not already a SafeSubscriber) that
deals with exceptions thrown by a misbehaving Subscriber (that doesn't follow the
Reactive-Streams specification).
|
Flowable<T> |
Flowable.sample(long period,
TimeUnit unit)
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher
within periodic time intervals.
|
Flowable<T> |
Flowable.sample(long period,
TimeUnit unit,
boolean emitLast)
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher
within periodic time intervals and optionally emit the very last upstream item when the upstream completes.
|
Flowable<T> |
Flowable.sample(long period,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher
within periodic time intervals, where the intervals are defined on a particular Scheduler.
|
Flowable<T> |
Flowable.sample(long period,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast)
Returns a Flowable that emits the most recently emitted item (if any) emitted by the source Publisher
within periodic time intervals, where the intervals are defined on a particular Scheduler
and optionally emit the very last upstream item when the upstream completes.
|
<U> Flowable<T> |
Flowable.sample(org.reactivestreams.Publisher<U> sampler)
Returns a Flowable that, when the specified
sampler Publisher emits an item or completes,
emits the most recently emitted item (if any) emitted by the source Publisher since the previous
emission from the sampler Publisher. |
<U> Flowable<T> |
Flowable.sample(org.reactivestreams.Publisher<U> sampler,
boolean emitLast)
Returns a Flowable that, when the specified
sampler Publisher emits an item or completes,
emits the most recently emitted item (if any) emitted by the source Publisher since the previous
emission from the sampler Publisher
and optionally emit the very last upstream item when the upstream or other Publisher complete. |
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> 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> 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.
|
static <T> Single<Boolean> |
Flowable.sequenceEqual(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2)
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the
same by comparing the items emitted by each Publisher pairwise.
|
static <T> Single<Boolean> |
Flowable.sequenceEqual(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
BiPredicate<? super T,? super T> isEqual)
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the
same by comparing the items emitted by each Publisher pairwise based on the results of a specified
equality function.
|
static <T> Single<Boolean> |
Flowable.sequenceEqual(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
BiPredicate<? super T,? super T> isEqual,
int bufferSize)
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the
same by comparing the items emitted by each Publisher pairwise based on the results of a specified
equality function.
|
static <T> Single<Boolean> |
Flowable.sequenceEqual(org.reactivestreams.Publisher<? extends T> source1,
org.reactivestreams.Publisher<? extends T> source2,
int bufferSize)
Returns a Single that emits a Boolean value that indicates whether two Publisher sequences are the
same by comparing the items emitted by each Publisher pairwise.
|
Flowable<T> |
Flowable.serialize()
Forces a Publisher's emissions and notifications to be serialized and for it to obey
the Publisher contract in other ways.
|
Flowable<T> |
Flowable.share()
Returns a new
Publisher that multicasts (and shares a single subscription to) the original Publisher . |
Single<T> |
Flowable.single(T defaultItem)
Returns a Single that emits the single item emitted by the source Publisher, if that Publisher
emits only a single item, or a default item if the source Publisher emits no items.
|
Maybe<T> |
Flowable.singleElement()
Returns a Maybe that completes if this Flowable is empty, signals one item if this Flowable
signals exactly one item or signals an
IllegalArgumentException if this Flowable signals
more than one item. |
Single<T> |
Flowable.singleOrError()
Returns a Single that emits the single item emitted by this Flowable, if this Flowable
emits only a single item, otherwise
if this Flowable completes without emitting any items a
NoSuchElementException will be signaled and
if this Flowable emits more than one item, an IllegalArgumentException will be signaled. |
Flowable<T> |
Flowable.skip(long count)
Returns a Flowable that skips the first
count items emitted by the source Publisher and emits
the remainder. |
Flowable<T> |
Flowable.skip(long time,
TimeUnit unit)
Returns a Flowable that skips values emitted by the source Publisher before a specified time window
elapses.
|
Flowable<T> |
Flowable.skip(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that skips values emitted by the source Publisher before a specified time window
on a specified
Scheduler elapses. |
Flowable<T> |
Flowable.skipLast(int count)
Returns a Flowable that drops a specified number of items from the end of the sequence emitted by the
source Publisher.
|
Flowable<T> |
Flowable.skipLast(long time,
TimeUnit unit)
Returns a Flowable that drops items emitted by the source Publisher during a specified time window
before the source completes.
|
Flowable<T> |
Flowable.skipLast(long time,
TimeUnit unit,
boolean delayError)
Returns a Flowable that drops items emitted by the source Publisher during a specified time window
before the source completes.
|
Flowable<T> |
Flowable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that drops items emitted by the source Publisher during a specified time window
(defined on a specified scheduler) before the source completes.
|
Flowable<T> |
Flowable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns a Flowable that drops items emitted by the source Publisher during a specified time window
(defined on a specified scheduler) before the source completes.
|
Flowable<T> |
Flowable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns a Flowable that drops items emitted by the source Publisher during a specified time window
(defined on a specified scheduler) before the source completes.
|
<U> Flowable<T> |
Flowable.skipUntil(org.reactivestreams.Publisher<U> other)
Returns a Flowable that skips items emitted by the source Publisher until a second Publisher emits
an item.
|
Flowable<T> |
Flowable.skipWhile(Predicate<? super T> predicate)
Returns a Flowable that skips all items emitted by the source Publisher as long as a specified
condition holds true, but emits all further source items as soon as the condition becomes false.
|
Flowable<T> |
Flowable.sorted()
Returns a Flowable that emits the events emitted by source Publisher, in a
sorted order.
|
Flowable<T> |
Flowable.sorted(Comparator<? super T> sortFunction)
Returns a Flowable that emits the events emitted by source Publisher, in a
sorted order based on a specified comparison function.
|
Flowable<T> |
Flowable.startWith(Iterable<? extends T> items)
Returns a Flowable that emits the items in a specified
Iterable before it begins to emit items
emitted by the source Publisher. |
Flowable<T> |
Flowable.startWith(org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that emits the items in a specified
Publisher before it begins to emit
items emitted by the source Publisher. |
<T> Flowable<T> |
Completable.startWith(org.reactivestreams.Publisher<T> other)
Returns a Flowable which first delivers the events
of the other Publisher then runs this Completable.
|
Flowable<T> |
Flowable.startWith(T value)
Returns a Flowable that emits a specified item before it begins to emit items emitted by the source
Publisher.
|
Flowable<T> |
Flowable.startWithArray(T... items)
Returns a Flowable that emits the specified items before it begins to emit items emitted by the source
Publisher.
|
Disposable |
Flowable.subscribe()
Subscribes to a Publisher and ignores
onNext and onComplete emissions. |
Disposable |
Flowable.subscribe(Consumer<? super T> onNext)
Subscribes to a Publisher and provides a callback to handle the items it emits.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error
notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Disposable |
Flowable.subscribe(Consumer<? super T> onNext,
Consumer<? super Throwable> onError,
Action onComplete,
Consumer<? super org.reactivestreams.Subscription> onSubscribe)
Subscribes to a Publisher and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
void |
Flowable.subscribe(FlowableSubscriber<? super T> s)
Establish a connection between this Flowable and the given FlowableSubscriber and
start streaming events based on the demand of the FlowableSubscriber.
|
void |
Flowable.subscribe(org.reactivestreams.Subscriber<? super T> s) |
Flowable<T> |
Flowable.subscribeOn(Scheduler scheduler)
Asynchronously subscribes Subscribers to this Publisher on the specified
Scheduler . |
Flowable<T> |
Flowable.subscribeOn(Scheduler scheduler,
boolean requestOn)
|
<E extends org.reactivestreams.Subscriber<? super T>> |
Flowable.subscribeWith(E subscriber)
Subscribes a given Subscriber (subclass) to this Flowable and returns the given
Subscriber as is.
|
Flowable<T> |
Flowable.switchIfEmpty(org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that emits the items emitted by the source Publisher or the items of an alternate
Publisher if the source Publisher is empty.
|
<R> Flowable<R> |
Flowable.switchMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a new Publisher by applying a function that you supply to each item emitted by the source
Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted
of these Publishers.
|
<R> Flowable<R> |
Flowable.switchMap(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int bufferSize)
Returns a new Publisher by applying a function that you supply to each item emitted by the source
Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted
of these Publishers.
|
Completable |
Flowable.switchMapCompletable(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running. |
Completable |
Flowable.switchMapCompletableDelayError(Function<? super T,? extends CompletableSource> mapper)
Maps the upstream values into
CompletableSource s, subscribes to the newer one while
disposing the subscription to the previous CompletableSource , thus keeping at most one
active CompletableSource running and delaying any main or inner errors until all
of them terminate. |
<R> Flowable<R> |
Flowable.switchMapDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper)
Returns a new Publisher by applying a function that you supply to each item emitted by the source
Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted
of these Publishers and delays any error until all Publishers terminate.
|
<R> Flowable<R> |
Flowable.switchMapDelayError(Function<? super T,? extends org.reactivestreams.Publisher<? extends R>> mapper,
int bufferSize)
Returns a new Publisher by applying a function that you supply to each item emitted by the source
Publisher that returns a Publisher, and then emitting the items emitted by the most recently emitted
of these Publishers and delays any error until all Publishers terminate.
|
<R> Flowable<R> |
Flowable.switchMapMaybe(Function<? super T,? extends MaybeSource<? extends R>> mapper)
Maps the upstream items into
MaybeSource s and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available while failing immediately if this Flowable or any of the
active inner MaybeSource s fail. |
<R> Flowable<R> |
Flowable.switchMapMaybeDelayError(Function<? super T,? extends MaybeSource<? extends R>> mapper)
Maps the upstream items into
MaybeSource s and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available, delaying errors from this Flowable or the inner MaybeSource s until all terminate. |
<R> Flowable<R> |
Flowable.switchMapSingle(Function<? super T,? extends SingleSource<? extends R>> mapper)
Maps the upstream items into
SingleSource s and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one
while failing immediately if this Flowable or any of the
active inner SingleSource s fail. |
<R> Flowable<R> |
Flowable.switchMapSingleDelayError(Function<? super T,? extends SingleSource<? extends R>> mapper)
Maps the upstream items into
SingleSource s and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one,
delaying errors from this Flowable or the inner SingleSource s until all terminate. |
static <T> Flowable<T> |
Flowable.switchOnNext(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the
most recently emitted of those Publishers.
|
static <T> Flowable<T> |
Flowable.switchOnNext(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int bufferSize)
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the
most recently emitted of those Publishers.
|
static <T> Flowable<T> |
Flowable.switchOnNextDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources)
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the
most recently emitted of those Publishers and delays any exception until all Publishers terminate.
|
static <T> Flowable<T> |
Flowable.switchOnNextDelayError(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
int prefetch)
Converts a Publisher that emits Publishers into a Publisher that emits the items emitted by the
most recently emitted of those Publishers and delays any exception until all Publishers terminate.
|
Flowable<T> |
Flowable.take(long count)
Returns a Flowable that emits only the first
count items emitted by the source Publisher. |
Flowable<T> |
Flowable.take(long time,
TimeUnit unit)
Returns a Flowable that emits those items emitted by source Publisher before a specified time runs
out.
|
Flowable<T> |
Flowable.take(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits those items emitted by source Publisher before a specified time (on a
specified Scheduler) runs out.
|
Flowable<T> |
Flowable.takeLast(int count)
Returns a Flowable that emits at most the last
count items emitted by the source Publisher. |
Flowable<T> |
Flowable.takeLast(long count,
long time,
TimeUnit unit)
Returns a Flowable that emits at most a specified number of items from the source Publisher that were
emitted in a specified window of time before the Publisher completed.
|
Flowable<T> |
Flowable.takeLast(long count,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits at most a specified number of items from the source Publisher that were
emitted in a specified window of time before the Publisher completed, where the timing information is
provided by a given Scheduler.
|
Flowable<T> |
Flowable.takeLast(long count,
long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns a Flowable that emits at most a specified number of items from the source Publisher that were
emitted in a specified window of time before the Publisher completed, where the timing information is
provided by a given Scheduler.
|
Flowable<T> |
Flowable.takeLast(long time,
TimeUnit unit)
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified
window of time before the Publisher completed.
|
Flowable<T> |
Flowable.takeLast(long time,
TimeUnit unit,
boolean delayError)
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified
window of time before the Publisher completed.
|
Flowable<T> |
Flowable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified
window of time before the Publisher completed, where the timing information is provided by a specified
Scheduler.
|
Flowable<T> |
Flowable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified
window of time before the Publisher completed, where the timing information is provided by a specified
Scheduler.
|
Flowable<T> |
Flowable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns a Flowable that emits the items from the source Publisher that were emitted in a specified
window of time before the Publisher completed, where the timing information is provided by a specified
Scheduler.
|
Flowable<T> |
Flowable.takeUntil(Predicate<? super T> stopPredicate)
Returns a Flowable that emits items emitted by the source Publisher, checks the specified predicate
for each item, and then completes when the condition is satisfied.
|
<E> Single<T> |
Single.takeUntil(org.reactivestreams.Publisher<E> other)
Returns a Single that emits the item emitted by the source Single until a Publisher emits an item.
|
<U> Maybe<T> |
Maybe.takeUntil(org.reactivestreams.Publisher<U> other)
Returns a Maybe that emits the item emitted by the source Maybe until a second Publisher
emits an item.
|
<U> Flowable<T> |
Flowable.takeUntil(org.reactivestreams.Publisher<U> other)
Returns a Flowable that emits the items emitted by the source Publisher until a second Publisher
emits an item.
|
Flowable<T> |
Flowable.takeWhile(Predicate<? super T> predicate)
Returns a Flowable that emits items emitted by the source Publisher so long as each item satisfied a
specified condition, and then completes as soon as this condition is not satisfied.
|
TestSubscriber<T> |
Flowable.test()
Creates a TestSubscriber that requests Long.MAX_VALUE and subscribes
it to this Flowable.
|
TestSubscriber<T> |
Flowable.test(long initialRequest)
Creates a TestSubscriber with the given initial request amount and subscribes
it to this Flowable.
|
TestSubscriber<T> |
Flowable.test(long initialRequest,
boolean cancel)
Creates a TestSubscriber with the given initial request amount,
optionally cancels it before the subscription and subscribes
it to this Flowable.
|
Flowable<T> |
Flowable.throttleFirst(long windowDuration,
TimeUnit unit)
Returns a Flowable that emits only the first item emitted by the source Publisher during sequential
time windows of a specified duration.
|
Flowable<T> |
Flowable.throttleFirst(long skipDuration,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits only the first item emitted by the source Publisher during sequential
time windows of a specified duration, where the windows are managed by a specified Scheduler.
|
Flowable<T> |
Flowable.throttleLast(long intervalDuration,
TimeUnit unit)
Returns a Flowable that emits only the last item emitted by the source Publisher during sequential
time windows of a specified duration.
|
Flowable<T> |
Flowable.throttleLast(long intervalDuration,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits only the last item emitted by the source Publisher during sequential
time windows of a specified duration, where the duration is governed by a specified Scheduler.
|
Flowable<T> |
Flowable.throttleLatest(long timeout,
TimeUnit unit)
Throttles items from the upstream
Flowable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them. |
Flowable<T> |
Flowable.throttleLatest(long timeout,
TimeUnit unit,
boolean emitLast)
Throttles items from the upstream
Flowable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them. |
Flowable<T> |
Flowable.throttleLatest(long timeout,
TimeUnit unit,
Scheduler scheduler)
Throttles items from the upstream
Flowable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them. |
Flowable<T> |
Flowable.throttleLatest(long timeout,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast)
Throttles items from the upstream
Flowable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them. |
Flowable<T> |
Flowable.throttleWithTimeout(long timeout,
TimeUnit unit)
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the
source Publisher that are followed by newer items before a timeout value expires.
|
Flowable<T> |
Flowable.throttleWithTimeout(long timeout,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that mirrors the source Publisher, except that it drops items emitted by the
source Publisher that are followed by newer items before a timeout value expires on a specified
Scheduler.
|
Flowable<Timed<T>> |
Flowable.timeInterval()
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
source Publisher.
|
Flowable<Timed<T>> |
Flowable.timeInterval(Scheduler scheduler)
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
source Publisher, where this interval is computed on a specified Scheduler.
|
Flowable<Timed<T>> |
Flowable.timeInterval(TimeUnit unit)
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
source Publisher.
|
Flowable<Timed<T>> |
Flowable.timeInterval(TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
source Publisher, where this interval is computed on a specified Scheduler.
|
<V> Flowable<T> |
Flowable.timeout(Function<? super T,? extends org.reactivestreams.Publisher<V>> itemTimeoutIndicator)
Returns a Flowable that mirrors the source Publisher, but notifies Subscribers of a
TimeoutException if an item emitted by the source Publisher doesn't arrive within a window of
time after the emission of the previous item, where that period of time is measured by a Publisher that
is a function of the previous item. |
<V> Flowable<T> |
Flowable.timeout(Function<? super T,? extends org.reactivestreams.Publisher<V>> itemTimeoutIndicator,
Flowable<? extends T> other)
Returns a Flowable that mirrors the source Publisher, but that switches to a fallback Publisher if
an item emitted by the source Publisher doesn't arrive within a window of time after the emission of the
previous item, where that period of time is measured by a Publisher that is a function of the previous
item.
|
Flowable<T> |
Flowable.timeout(long timeout,
TimeUnit timeUnit)
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted
item.
|
Flowable<T> |
Flowable.timeout(long timeout,
TimeUnit timeUnit,
org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted
item.
|
Flowable<T> |
Flowable.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler)
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted
item, where this policy is governed by a specified Scheduler.
|
Flowable<T> |
Flowable.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler,
org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that mirrors the source Publisher but applies a timeout policy for each emitted
item using a specified Scheduler.
|
<U> Maybe<T> |
Maybe.timeout(org.reactivestreams.Publisher<U> timeoutIndicator)
If the current
Maybe source didn't signal an event before the timeoutIndicator Publisher signals, a
TimeoutException is signaled instead. |
<U,V> Flowable<T> |
Flowable.timeout(org.reactivestreams.Publisher<U> firstTimeoutIndicator,
Function<? super T,? extends org.reactivestreams.Publisher<V>> itemTimeoutIndicator)
Returns a Flowable that mirrors the source Publisher, but notifies Subscribers of a
TimeoutException if either the first item emitted by the source Publisher or any subsequent item
doesn't arrive within time windows defined by other Publishers. |
<U,V> Flowable<T> |
Flowable.timeout(org.reactivestreams.Publisher<U> firstTimeoutIndicator,
Function<? super T,? extends org.reactivestreams.Publisher<V>> itemTimeoutIndicator,
org.reactivestreams.Publisher<? extends T> other)
Returns a Flowable that mirrors the source Publisher, but switches to a fallback Publisher if either
the first item emitted by the source Publisher or any subsequent item doesn't arrive within time windows
defined by other Publishers.
|
<U> Maybe<T> |
Maybe.timeout(org.reactivestreams.Publisher<U> timeoutIndicator,
MaybeSource<? extends T> fallback)
If the current
Maybe didn't signal an event before the timeoutIndicator Publisher signals,
the current Maybe is disposed and the fallback MaybeSource subscribed to
as a continuation. |
static Flowable<Long> |
Flowable.timer(long delay,
TimeUnit unit)
Returns a Flowable that emits
0L after a specified delay, and then completes. |
static Flowable<Long> |
Flowable.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits
0L after a specified delay, on a specified Scheduler, and then
completes. |
Flowable<Timed<T>> |
Flowable.timestamp()
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a
Timed object. |
Flowable<Timed<T>> |
Flowable.timestamp(Scheduler scheduler)
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a
Timed object whose timestamps are provided by a specified Scheduler. |
Flowable<Timed<T>> |
Flowable.timestamp(TimeUnit unit)
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a
Timed object. |
Flowable<Timed<T>> |
Flowable.timestamp(TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits each item emitted by the source Publisher, wrapped in a
Timed object whose timestamps are provided by a specified Scheduler. |
<R> R |
Flowable.to(Function<? super Flowable<T>,R> converter)
Calls the specified converter function during assembly time and returns its resulting value.
|
Flowable<T> |
Single.toFlowable()
Converts this Single into a
Flowable . |
Flowable<T> |
Maybe.toFlowable()
Converts this Maybe into a backpressure-aware Flowable instance composing cancellation
through.
|
<T> Flowable<T> |
Completable.toFlowable()
Returns a Flowable which when subscribed to subscribes to this Completable and
relays the terminal events to the subscriber.
|
Flowable<T> |
Observable.toFlowable(BackpressureStrategy strategy)
Converts the current Observable into a Flowable by applying the specified backpressure strategy.
|
Future<T> |
Flowable.toFuture()
Returns a
Future representing the only value emitted by this Flowable . |
Single<List<T>> |
Flowable.toList()
Returns a Single that emits a single item, a list composed of all the items emitted by the
finite upstream source Publisher.
|
<U extends Collection<? super T>> |
Flowable.toList(Callable<U> collectionSupplier)
Returns a Single that emits a single item, a list composed of all the items emitted by the
finite source Publisher.
|
Single<List<T>> |
Flowable.toList(int capacityHint)
Returns a Single that emits a single item, a list composed of all the items emitted by the
finite source Publisher.
|
<K> Single<Map<K,T>> |
Flowable.toMap(Function<? super T,? extends K> keySelector)
Returns a Single that emits a single HashMap containing all items emitted by the finite source Publisher,
mapped by the keys returned by a specified
keySelector function. |
<K,V> Single<Map<K,V>> |
Flowable.toMap(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector)
Returns a Single that emits a single HashMap containing values corresponding to items emitted by the
finite source Publisher, mapped by the keys returned by a specified
keySelector function. |
<K,V> Single<Map<K,V>> |
Flowable.toMap(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
Callable<? extends Map<K,V>> mapSupplier)
Returns a Single that emits a single Map, returned by a specified
mapFactory function, that
contains keys and values extracted from the items emitted by the finite source Publisher. |
<K> Single<Map<K,Collection<T>>> |
Flowable.toMultimap(Function<? super T,? extends K> keySelector)
Returns a Single that emits a single HashMap that contains an ArrayList of items emitted by the
finite source Publisher keyed by a specified
keySelector function. |
<K,V> Single<Map<K,Collection<V>>> |
Flowable.toMultimap(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector)
Returns a Single that emits a single HashMap that contains an ArrayList of values extracted by a
specified
valueSelector function from items emitted by the finite source Publisher, keyed by a
specified keySelector function. |
<K,V> Single<Map<K,Collection<V>>> |
Flowable.toMultimap(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
Callable<? extends Map<K,Collection<V>>> mapSupplier,
Function<? super K,? extends Collection<? super V>> collectionFactory)
Returns a Single that emits a single Map, returned by a specified
mapFactory function, that
contains a custom collection of values, extracted by a specified valueSelector function from
items emitted by the finite source Publisher, and keyed by the keySelector function. |
<K,V> Single<Map<K,Collection<V>>> |
Flowable.toMultimap(Function<? super T,? extends K> keySelector,
Function<? super T,? extends V> valueSelector,
Callable<Map<K,Collection<V>>> mapSupplier)
Returns a Single that emits a single Map, returned by a specified
mapFactory function, that
contains an ArrayList of values, extracted by a specified valueSelector function from items
emitted by the finite source Publisher and keyed by the keySelector function. |
Observable<T> |
Flowable.toObservable()
Converts the current Flowable into a non-backpressured
Observable . |
Single<List<T>> |
Flowable.toSortedList()
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a
sorted order.
|
Single<List<T>> |
Flowable.toSortedList(Comparator<? super T> comparator)
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a
sorted order based on a specified comparison function.
|
Single<List<T>> |
Flowable.toSortedList(Comparator<? super T> comparator,
int capacityHint)
Returns a Single that emits a list that contains the items emitted by the finite source Publisher, in a
sorted order based on a specified comparison function.
|
Single<List<T>> |
Flowable.toSortedList(int capacityHint)
Returns a Flowable that emits a list that contains the items emitted by the finite source Publisher, in a
sorted order.
|
static <T> Flowable<T> |
Flowable.unsafeCreate(org.reactivestreams.Publisher<T> onSubscribe)
Create a Flowable by wrapping a Publisher which has to be implemented according
to the Reactive-Streams specification by handling backpressure and
cancellation correctly; no safeguards are provided by the Flowable itself.
|
Flowable<T> |
Flowable.unsubscribeOn(Scheduler scheduler)
Modifies the source Publisher so that subscribers will cancel it on a specified
Scheduler . |
static <T,D> Flowable<T> |
Flowable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer)
Constructs a Publisher that creates a dependent resource object which is disposed of on cancellation.
|
static <T,D> Flowable<T> |
Flowable.using(Callable<? extends D> resourceSupplier,
Function<? super D,? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier,
Consumer<? super D> resourceDisposer,
boolean eager)
Constructs a Publisher that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and cancellation does not occur
before termination. |
<B> Flowable<Flowable<T>> |
Flowable.window(Callable<? extends org.reactivestreams.Publisher<B>> boundaryIndicatorSupplier)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
<B> Flowable<Flowable<T>> |
Flowable.window(Callable<? extends org.reactivestreams.Publisher<B>> boundaryIndicatorSupplier,
int bufferSize)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long count)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long count,
long skip)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long count,
long skip,
int bufferSize)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
long timeskip,
TimeUnit unit)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
int bufferSize)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
long count)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
long count,
boolean restart)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
Scheduler scheduler)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count,
boolean restart)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
Flowable<Flowable<T>> |
Flowable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count,
boolean restart,
int bufferSize)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
<B> Flowable<Flowable<T>> |
Flowable.window(org.reactivestreams.Publisher<B> boundaryIndicator)
Returns a Flowable that emits non-overlapping windows of items it collects from the source Publisher
where the boundary of each window is determined by the items emitted from a specified boundary-governing
Publisher.
|
<B> Flowable<Flowable<T>> |
Flowable.window(org.reactivestreams.Publisher<B> boundaryIndicator,
int bufferSize)
Returns a Flowable that emits non-overlapping windows of items it collects from the source Publisher
where the boundary of each window is determined by the items emitted from a specified boundary-governing
Publisher.
|
<U,V> Flowable<Flowable<T>> |
Flowable.window(org.reactivestreams.Publisher<U> openingIndicator,
Function<? super U,? extends org.reactivestreams.Publisher<V>> closingIndicator)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
<U,V> Flowable<Flowable<T>> |
Flowable.window(org.reactivestreams.Publisher<U> openingIndicator,
Function<? super U,? extends org.reactivestreams.Publisher<V>> closingIndicator,
int bufferSize)
Returns a Flowable that emits windows of items it collects from the source Publisher.
|
<R> Flowable<R> |
Flowable.withLatestFrom(Iterable<? extends org.reactivestreams.Publisher<?>> others,
Function<? super Object[],R> combiner)
Combines the value emission from this Publisher with the latest emissions from the
other Publishers via a function to produce the output item.
|
<R> Flowable<R> |
Flowable.withLatestFrom(org.reactivestreams.Publisher<?>[] others,
Function<? super Object[],R> combiner)
Combines the value emission from this Publisher with the latest emissions from the
other Publishers via a function to produce the output 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. |
<T1,T2,R> Flowable<R> |
Flowable.withLatestFrom(org.reactivestreams.Publisher<T1> source1,
org.reactivestreams.Publisher<T2> source2,
Function3<? super T,? super T1,? super T2,R> combiner)
Combines the value emission from this Publisher with the latest emissions from the
other Publishers via a function to produce the output item.
|
<T1,T2,T3,R> |
Flowable.withLatestFrom(org.reactivestreams.Publisher<T1> source1,
org.reactivestreams.Publisher<T2> source2,
org.reactivestreams.Publisher<T3> source3,
Function4<? super T,? super T1,? super T2,? super T3,R> combiner)
Combines the value emission from this Publisher with the latest emissions from the
other Publishers via a function to produce the output item.
|
<T1,T2,T3,T4,R> |
Flowable.withLatestFrom(org.reactivestreams.Publisher<T1> source1,
org.reactivestreams.Publisher<T2> source2,
org.reactivestreams.Publisher<T3> source3,
org.reactivestreams.Publisher<T4> source4,
Function5<? super T,? super T1,? super T2,? super T3,? super T4,R> combiner)
Combines the value emission from this Publisher with the latest emissions from the
other Publishers via a function to produce the output item.
|
static <T,R> Flowable<R> |
Flowable.zip(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
items emitted, in sequence, by an Iterable of other Publishers.
|
static <T,R> Flowable<R> |
Flowable.zip(org.reactivestreams.Publisher<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
n items emitted, in sequence, by the n Publishers emitted by a specified Publisher.
|
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,T3,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
Function3<? super T1,? super T2,? super T3,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
three items emitted, in sequence, by three other Publishers.
|
static <T1,T2,T3,T4,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
Function4<? super T1,? super T2,? super T3,? super T4,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
four items emitted, in sequence, by four other Publishers.
|
static <T1,T2,T3,T4,T5,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
Function5<? super T1,? super T2,? super T3,? super T4,? super T5,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
five items emitted, in sequence, by five other Publishers.
|
static <T1,T2,T3,T4,T5,T6,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
Function6<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
six items emitted, in sequence, by six other Publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
Function7<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
seven items emitted, in sequence, by seven other Publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
Function8<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
eight items emitted, in sequence, by eight other Publishers.
|
static <T1,T2,T3,T4,T5,T6,T7,T8,T9,R> |
Flowable.zip(org.reactivestreams.Publisher<? extends T1> source1,
org.reactivestreams.Publisher<? extends T2> source2,
org.reactivestreams.Publisher<? extends T3> source3,
org.reactivestreams.Publisher<? extends T4> source4,
org.reactivestreams.Publisher<? extends T5> source5,
org.reactivestreams.Publisher<? extends T6> source6,
org.reactivestreams.Publisher<? extends T7> source7,
org.reactivestreams.Publisher<? extends T8> source8,
org.reactivestreams.Publisher<? extends T9> source9,
Function9<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? super T9,? extends R> zipper)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
nine items emitted, in sequence, by nine other Publishers.
|
static <T,R> Flowable<R> |
Flowable.zipArray(Function<? super Object[],? extends R> zipper,
boolean delayError,
int bufferSize,
org.reactivestreams.Publisher<? extends T>... sources)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
items emitted, in sequence, by an array of other Publishers.
|
static <T,R> Flowable<R> |
Flowable.zipIterable(Iterable<? extends org.reactivestreams.Publisher<? extends T>> sources,
Function<? super Object[],? extends R> zipper,
boolean delayError,
int bufferSize)
Returns a Flowable that emits the results of a specified combiner function applied to combinations of
items emitted, in sequence, by an Iterable of other Publishers.
|
<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> 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.
|
Modifier and Type | Method and Description |
---|---|
Flowable<T> |
ConnectableFlowable.refCount()
Returns a
Flowable that stays connected to this ConnectableFlowable as long as there
is at least one subscription to this ConnectableFlowable . |
Flowable<T> |
ConnectableFlowable.refCount(int subscriberCount)
Connects to the upstream
ConnectableFlowable if the number of subscribed
subscriber reaches the specified count and disconnect if all subscribers have unsubscribed. |
Flowable<T> |
ConnectableFlowable.refCount(int subscriberCount,
long timeout,
TimeUnit unit)
Connects to the upstream
ConnectableFlowable if the number of subscribed
subscriber reaches the specified count and disconnect after the specified
timeout if all subscribers have unsubscribed. |
Flowable<T> |
ConnectableFlowable.refCount(int subscriberCount,
long timeout,
TimeUnit unit,
Scheduler scheduler)
Connects to the upstream
ConnectableFlowable if the number of subscribed
subscriber reaches the specified count and disconnect after the specified
timeout if all subscribers have unsubscribed. |
Flowable<T> |
ConnectableFlowable.refCount(long timeout,
TimeUnit unit)
Connects to the upstream
ConnectableFlowable if the number of subscribed
subscriber reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed. |
Flowable<T> |
ConnectableFlowable.refCount(long timeout,
TimeUnit unit,
Scheduler scheduler)
Connects to the upstream
ConnectableFlowable if the number of subscribed
subscriber reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed. |
Modifier and Type | Method and Description |
---|---|
Flowable<T> |
ParallelFlowable.sequential()
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular Publisher sequence, running with a default prefetch value
for the rails.
|
Flowable<T> |
ParallelFlowable.sequential(int prefetch)
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular Publisher sequence, running with a give prefetch value
for the rails.
|
Flowable<T> |
ParallelFlowable.sequentialDelayError()
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular Flowable sequence, running with a default prefetch value
for the rails and delaying errors from all rails till all terminate.
|
Flowable<T> |
ParallelFlowable.sequentialDelayError(int prefetch)
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular Publisher sequence, running with a give prefetch value
for the rails and delaying errors from all rails till all terminate.
|
Modifier and Type | Class and Description |
---|---|
class |
MulticastProcessor<T>
A
FlowableProcessor implementation that coordinates downstream requests through
a front-buffer and stable-prefetching, optionally canceling the upstream if all
subscribers have cancelled. |
Copyright © 2019. All rights reserved.