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.internal.functions | |
io.reactivex.internal.operators.completable | |
io.reactivex.internal.operators.flowable | |
io.reactivex.internal.operators.maybe | |
io.reactivex.internal.operators.observable | |
io.reactivex.internal.operators.parallel | |
io.reactivex.internal.operators.single | |
io.reactivex.internal.schedulers | |
io.reactivex.observables |
Classes supporting the Observable base reactive class:
ConnectableObservable and
GroupedObservable . |
io.reactivex.parallel |
Contains the base type
ParallelFlowable ,
a sub-DSL for working with Flowable sequences in parallel. |
io.reactivex.plugins |
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers. |
io.reactivex.processors |
Classes extending the Flowable base reactive class and implementing
the Subscriber interface at the same time (aka hot Flowables).
|
io.reactivex.schedulers |
Scheduler implementations, value+time record class and the standard factory class to
return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.
|
io.reactivex.subjects |
Classes representing so-called hot sources, aka subjects, that implement a base reactive class and
the respective consumer type at once to allow forms of multicasting events to multiple
consumers as well as consuming another base reactive type of their kind.
|
Modifier and Type | Method and Description |
---|---|
<S extends Scheduler & Disposable> |
Scheduler.when(Function<Flowable<Flowable<Completable>>,Completable> combine)
Allows the use of operators for controlling the timing around when
actions scheduled on workers are actually done.
|
Modifier and Type | Method and Description |
---|---|
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.
|
Observable<List<T>> |
Observable.buffer(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
|
<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.
|
<U extends Collection<? super T>> |
Observable.buffer(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
Callable<U> bufferSupplier)
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
|
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.
|
Observable<List<T>> |
Observable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
|
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.
|
Observable<List<T>> |
Observable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler,
int count)
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
|
<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.
|
<U extends Collection<? super T>> |
Observable.buffer(long timespan,
TimeUnit unit,
Scheduler scheduler,
int count,
Callable<U> bufferSupplier,
boolean restartTimerOnMaxSize)
Returns an Observable that emits buffers of items it collects from the source ObservableSource.
|
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.
|
Observable<T> |
Observable.debounce(long timeout,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the
source ObservableSource that are followed by newer items before a timeout value expires on a specified
Scheduler.
|
Completable |
Completable.delay(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable which delays the emission of the completion event by the given time while
running on the specified scheduler.
|
Maybe<T> |
Maybe.delay(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Maybe that signals the events emitted by the source Maybe shifted forward in time by a
specified delay running on the specified Scheduler.
|
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.
|
Single<T> |
Single.delay(long time,
TimeUnit unit,
Scheduler scheduler)
Delays the emission of the success signal from the current Single by the specified amount.
|
Observable<T> |
Observable.delay(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a
specified delay.
|
Completable |
Completable.delay(long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns a Completable which delays the emission of the completion event, and optionally the error as well, by the given time while
running on the specified scheduler.
|
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.
|
Single<T> |
Single.delay(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Delays the emission of the success or error signal from the current Single by the specified amount.
|
Observable<T> |
Observable.delay(long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns an Observable that emits the items emitted by the source ObservableSource shifted forward in time by a
specified delay.
|
Maybe<T> |
Maybe.delaySubscription(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Maybe that delays the subscription to the source Maybe by a given amount of time,
both waiting and subscribing on a given Scheduler.
|
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.
|
Single<T> |
Single.delaySubscription(long time,
TimeUnit unit,
Scheduler scheduler)
Delays the actual subscription to the current Single until the given time delay elapsed.
|
Observable<T> |
Observable.delaySubscription(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that delays the subscription to the source ObservableSource by a given amount of time,
both waiting and subscribing on a given Scheduler.
|
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> Single<T> |
Single.fromFuture(Future<? extends T> future,
long timeout,
TimeUnit unit,
Scheduler scheduler)
Converts a
Future into a Single , with a timeout on the Future. |
static <T> Observable<T> |
Observable.fromFuture(Future<? extends T> future,
long timeout,
TimeUnit unit,
Scheduler scheduler)
Converts a
Future into an ObservableSource, with a timeout on the Future. |
static <T> Flowable<T> |
Flowable.fromFuture(Future<? extends T> future,
Scheduler scheduler)
|
static <T> Single<T> |
Single.fromFuture(Future<? extends T> future,
Scheduler scheduler)
|
static <T> Observable<T> |
Observable.fromFuture(Future<? extends T> future,
Scheduler scheduler)
|
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 Observable<Long> |
Observable.interval(long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable 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,
Scheduler scheduler)
Returns a Flowable that emits a sequential number every specified interval of time, on a
specified Scheduler.
|
static Observable<Long> |
Observable.interval(long period,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable 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,
Scheduler scheduler)
Signals a range of long values, the first after some initial delay and the rest periodically after.
|
static Observable<Long> |
Observable.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.
|
Completable |
Completable.observeOn(Scheduler scheduler)
Returns a Completable which emits the terminal events from the thread of the specified scheduler.
|
Maybe<T> |
Maybe.observeOn(Scheduler scheduler)
Wraps a Maybe to emit its item (or notify of its error) on a specified
Scheduler ,
asynchronously. |
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. |
Single<T> |
Single.observeOn(Scheduler scheduler)
Modifies a Single to emit its item (or notify of its error) on a specified
Scheduler ,
asynchronously. |
Observable<T> |
Observable.observeOn(Scheduler scheduler)
Modifies an ObservableSource to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with an unbounded buffer with Flowable.bufferSize() "island size". |
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. |
Observable<T> |
Observable.observeOn(Scheduler scheduler,
boolean delayError)
Modifies an ObservableSource to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with an unbounded buffer with Flowable.bufferSize() "island size" 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. |
Observable<T> |
Observable.observeOn(Scheduler scheduler,
boolean delayError,
int bufferSize)
Modifies an ObservableSource to perform its emissions and notifications on a specified
Scheduler ,
asynchronously with an unbounded buffer of configurable "island size" and optionally delays onError notifications. |
<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,
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. |
<R> Observable<R> |
Observable.replay(Function<? super Observable<T>,? extends ObservableSource<R>> selector,
int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableObservable that shares a single subscription to the source ObservableSource,
replaying no more than bufferSize items that were emitted within a specified time window. |
<R> Observable<R> |
Observable.replay(Function<? super Observable<T>,? extends ObservableSource<R>> selector,
int bufferSize,
Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableObservable that shares a single subscription to the source ObservableSource,
replaying a maximum of bufferSize items. |
<R> Observable<R> |
Observable.replay(Function<? super Observable<T>,? extends ObservableSource<R>> selector,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableObservable that shares a single subscription to the source ObservableSource,
replaying all items that were emitted within a specified time window. |
<R> Observable<R> |
Observable.replay(Function<? super Observable<T>,? extends ObservableSource<R>> selector,
Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items
emitted by a
ConnectableObservable that shares a single subscription to the source ObservableSource. |
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. |
ConnectableObservable<T> |
Observable.replay(int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns a
ConnectableObservable that shares a single subscription to the source ObservableSource 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. |
ConnectableObservable<T> |
Observable.replay(int bufferSize,
Scheduler scheduler)
Returns a
ConnectableObservable that shares a single subscription to the source ObservableSource and
replays at most bufferSize items emitted by that ObservableSource. |
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. |
ConnectableObservable<T> |
Observable.replay(long time,
TimeUnit unit,
Scheduler scheduler)
Returns a
ConnectableObservable that shares a single subscription to the source ObservableSource and
replays all items emitted by that ObservableSource 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 . |
ConnectableObservable<T> |
Observable.replay(Scheduler scheduler)
Returns a
ConnectableObservable that shares a single subscription to the source ObservableSource that
will replay all of its items and notifications to any future Observer on the given
Scheduler . |
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.
|
Observable<T> |
Observable.sample(long period,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource
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.
|
Observable<T> |
Observable.sample(long period,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast)
Returns an Observable that emits the most recently emitted item (if any) emitted by the source ObservableSource
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.
|
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. |
Observable<T> |
Observable.skip(long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that skips values emitted by the source ObservableSource before a specified time window
on a specified
Scheduler elapses. |
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.
|
Observable<T> |
Observable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that drops items emitted by the source ObservableSource 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.
|
Observable<T> |
Observable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns an Observable that drops items emitted by the source ObservableSource 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.
|
Observable<T> |
Observable.skipLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns an Observable that drops items emitted by the source ObservableSource during a specified time window
(defined on a specified scheduler) before the source completes.
|
Completable |
Completable.subscribeOn(Scheduler scheduler)
Returns a Completable which subscribes the child subscriber on the specified scheduler, making
sure the subscription side-effects happen on that specific thread of the scheduler.
|
Maybe<T> |
Maybe.subscribeOn(Scheduler scheduler)
Asynchronously subscribes subscribers to this Maybe on the specified
Scheduler . |
Flowable<T> |
Flowable.subscribeOn(Scheduler scheduler)
Asynchronously subscribes Subscribers to this Publisher on the specified
Scheduler . |
Single<T> |
Single.subscribeOn(Scheduler scheduler)
Asynchronously subscribes subscribers to this Single on the specified
Scheduler . |
Observable<T> |
Observable.subscribeOn(Scheduler scheduler)
Asynchronously subscribes Observers to this ObservableSource on the specified
Scheduler . |
Flowable<T> |
Flowable.subscribeOn(Scheduler scheduler,
boolean requestOn)
|
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.
|
Observable<T> |
Observable.take(long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits those items emitted by source ObservableSource before a specified time (on a
specified Scheduler) runs out.
|
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.
|
Observable<T> |
Observable.takeLast(long count,
long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits at most a specified number of items from the source ObservableSource that were
emitted in a specified window of time before the ObservableSource 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.
|
Observable<T> |
Observable.takeLast(long count,
long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns an Observable that emits at most a specified number of items from the source ObservableSource that were
emitted in a specified window of time before the ObservableSource completed, where the timing information is
provided by a given Scheduler.
|
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.
|
Observable<T> |
Observable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified
window of time before the ObservableSource 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.
|
Observable<T> |
Observable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError)
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified
window of time before the ObservableSource 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.
|
Observable<T> |
Observable.takeLast(long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError,
int bufferSize)
Returns an Observable that emits the items from the source ObservableSource that were emitted in a specified
window of time before the ObservableSource completed, where the timing information is provided by a specified
Scheduler.
|
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.
|
Observable<T> |
Observable.throttleFirst(long skipDuration,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits only the first item emitted by the source ObservableSource 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,
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.
|
Observable<T> |
Observable.throttleLast(long intervalDuration,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits only the last item emitted by the source ObservableSource 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,
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. |
Observable<T> |
Observable.throttleLatest(long timeout,
TimeUnit unit,
Scheduler scheduler)
Throttles items from the upstream
Observable 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. |
Observable<T> |
Observable.throttleLatest(long timeout,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast)
Throttles items from the upstream
Observable 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,
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.
|
Observable<T> |
Observable.throttleWithTimeout(long timeout,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that mirrors the source ObservableSource, except that it drops items emitted by the
source ObservableSource that are followed by newer items before a timeout value expires on a specified
Scheduler.
|
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.
|
Observable<Timed<T>> |
Observable.timeInterval(Scheduler scheduler)
Returns an Observable that emits records of the time interval between consecutive items emitted by the
source ObservableSource, where this interval is computed on a specified Scheduler.
|
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.
|
Observable<Timed<T>> |
Observable.timeInterval(TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits records of the time interval between consecutive items emitted by the
source ObservableSource, where this interval is computed on a specified Scheduler.
|
Completable |
Completable.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable that runs this Completable and emits a TimeoutException in case
this Completable doesn't complete within the given time while "waiting" on the specified
Scheduler.
|
Maybe<T> |
Maybe.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler)
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted
item, where this policy is governed on a specified Scheduler.
|
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.
|
Single<T> |
Single.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler)
Signals a TimeoutException if the current Single doesn't signal a success value within the
specified timeout window.
|
Observable<T> |
Observable.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler)
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted
item, where this policy is governed on a specified Scheduler.
|
Completable |
Completable.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler,
CompletableSource other)
Returns a Completable that runs this Completable and switches to the other Completable
in case this Completable doesn't complete within the given time while "waiting" on
the specified scheduler.
|
Maybe<T> |
Maybe.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler,
MaybeSource<? extends T> fallback)
Returns a Maybe that mirrors the source Maybe but applies a timeout policy for each emitted
item using a specified Scheduler.
|
Observable<T> |
Observable.timeout(long timeout,
TimeUnit timeUnit,
Scheduler scheduler,
ObservableSource<? extends T> other)
Returns an Observable that mirrors the source ObservableSource but applies a timeout policy for each emitted
item using 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.
|
Single<T> |
Single.timeout(long timeout,
TimeUnit unit,
Scheduler scheduler,
SingleSource<? extends T> other)
Runs the current Single and if it doesn't signal within the specified timeout window, it is
cancelled and the other SingleSource subscribed to.
|
static Completable |
Completable.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Completable instance that fires its onComplete event after the given delay elapsed
by using the supplied scheduler.
|
static Maybe<Long> |
Maybe.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns a Maybe that emits
0L after a specified delay on a specified Scheduler. |
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. |
static Single<Long> |
Single.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Signals success with 0L value after the given delay for each SingleObserver.
|
static Observable<Long> |
Observable.timer(long delay,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits
0L after a specified delay, on a specified Scheduler, and then
completes. |
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. |
Observable<Timed<T>> |
Observable.timestamp(Scheduler scheduler)
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a
Timed object whose timestamps are provided by a specified Scheduler. |
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. |
Observable<Timed<T>> |
Observable.timestamp(TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits each item emitted by the source ObservableSource, wrapped in a
Timed object whose timestamps are provided by a specified Scheduler. |
Completable |
Completable.unsubscribeOn(Scheduler scheduler)
Returns a Completable which makes sure when a subscriber cancels the subscription, the
dispose is called on the specified scheduler.
|
Maybe<T> |
Maybe.unsubscribeOn(Scheduler scheduler)
Returns a Maybe which makes sure when a MaybeObserver disposes the Disposable,
that call is propagated up on the specified scheduler.
|
Flowable<T> |
Flowable.unsubscribeOn(Scheduler scheduler)
Modifies the source Publisher so that subscribers will cancel it on a specified
Scheduler . |
Single<T> |
Single.unsubscribeOn(Scheduler scheduler)
Returns a Single which makes sure when a SingleObserver disposes the Disposable,
that call is propagated up on the specified scheduler.
|
Observable<T> |
Observable.unsubscribeOn(Scheduler scheduler)
Modifies the source ObservableSource so that subscribers will dispose it on a specified
Scheduler . |
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
int bufferSize)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
TimeUnit unit,
Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count,
boolean restart)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
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.
|
Observable<Observable<T>> |
Observable.window(long timespan,
TimeUnit unit,
Scheduler scheduler,
long count,
boolean restart,
int bufferSize)
Returns an Observable that emits windows of items it collects from the source ObservableSource.
|
Modifier and Type | Method and Description |
---|---|
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,
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 |
---|---|
static <T> Function<T,Timed<T>> |
Functions.timestampWith(TimeUnit unit,
Scheduler scheduler) |
Constructor and Description |
---|
CompletableDelay(CompletableSource source,
long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError) |
CompletableDisposeOn(CompletableSource source,
Scheduler scheduler) |
CompletableObserveOn(CompletableSource source,
Scheduler scheduler) |
CompletableSubscribeOn(CompletableSource source,
Scheduler scheduler) |
CompletableTimeout(CompletableSource source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
CompletableSource other) |
CompletableTimer(long delay,
TimeUnit unit,
Scheduler scheduler) |
Modifier and Type | Method and Description |
---|---|
static <T> ConnectableFlowable<T> |
FlowableReplay.create(Flowable<T> source,
long maxAge,
TimeUnit unit,
Scheduler scheduler)
Creates a replaying ConnectableObservable with a time bound buffer.
|
static <T> ConnectableFlowable<T> |
FlowableReplay.create(Flowable<T> source,
long maxAge,
TimeUnit unit,
Scheduler scheduler,
int bufferSize)
Creates a replaying ConnectableObservable with a size and time bound buffer.
|
static <T> ConnectableFlowable<T> |
FlowableReplay.observeOn(ConnectableFlowable<T> cf,
Scheduler scheduler)
Child Subscribers will observe the events of the ConnectableObservable on the
specified scheduler.
|
static <T> Callable<ConnectableFlowable<T>> |
FlowableInternalHelper.replayCallable(Flowable<T> parent,
int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler) |
static <T> Callable<ConnectableFlowable<T>> |
FlowableInternalHelper.replayCallable(Flowable<T> parent,
long time,
TimeUnit unit,
Scheduler scheduler) |
static <T,R> Function<Flowable<T>,org.reactivestreams.Publisher<R>> |
FlowableInternalHelper.replayFunction(Function<? super Flowable<T>,? extends org.reactivestreams.Publisher<R>> selector,
Scheduler scheduler) |
Constructor and Description |
---|
FlowableBufferTimed(Flowable<T> source,
long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
Callable<U> bufferSupplier,
int maxSize,
boolean restartTimerOnMaxSize) |
FlowableDebounceTimed(Flowable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
FlowableDelay(Flowable<T> source,
long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError) |
FlowableInterval(long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler) |
FlowableIntervalRange(long start,
long end,
long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler) |
FlowableObserveOn(Flowable<T> source,
Scheduler scheduler,
boolean delayError,
int prefetch) |
FlowableRefCount(ConnectableFlowable<T> source,
int n,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
FlowableSampleTimed(Flowable<T> source,
long period,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast) |
FlowableSkipLastTimed(Flowable<T> source,
long time,
TimeUnit unit,
Scheduler scheduler,
int bufferSize,
boolean delayError) |
FlowableSubscribeOn(Flowable<T> source,
Scheduler scheduler,
boolean nonScheduledRequests) |
FlowableTakeLastTimed(Flowable<T> source,
long count,
long time,
TimeUnit unit,
Scheduler scheduler,
int bufferSize,
boolean delayError) |
FlowableThrottleFirstTimed(Flowable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
FlowableThrottleLatest(Flowable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast) |
FlowableTimeInterval(Flowable<T> source,
TimeUnit unit,
Scheduler scheduler) |
FlowableTimeoutTimed(Flowable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
org.reactivestreams.Publisher<? extends T> other) |
FlowableTimer(long delay,
TimeUnit unit,
Scheduler scheduler) |
FlowableUnsubscribeOn(Flowable<T> source,
Scheduler scheduler) |
FlowableWindowTimed(Flowable<T> source,
long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
long maxSize,
int bufferSize,
boolean restartTimerOnMaxSize) |
Constructor and Description |
---|
MaybeDelay(MaybeSource<T> source,
long delay,
TimeUnit unit,
Scheduler scheduler) |
MaybeObserveOn(MaybeSource<T> source,
Scheduler scheduler) |
MaybeSubscribeOn(MaybeSource<T> source,
Scheduler scheduler) |
MaybeTimer(long delay,
TimeUnit unit,
Scheduler scheduler) |
MaybeUnsubscribeOn(MaybeSource<T> source,
Scheduler scheduler) |
Modifier and Type | Method and Description |
---|---|
static <T> ConnectableObservable<T> |
ObservableReplay.create(ObservableSource<T> source,
long maxAge,
TimeUnit unit,
Scheduler scheduler)
Creates a replaying ConnectableObservable with a time bound buffer.
|
static <T> ConnectableObservable<T> |
ObservableReplay.create(ObservableSource<T> source,
long maxAge,
TimeUnit unit,
Scheduler scheduler,
int bufferSize)
Creates a replaying ConnectableObservable with a size and time bound buffer.
|
static <T> ConnectableObservable<T> |
ObservableReplay.observeOn(ConnectableObservable<T> co,
Scheduler scheduler)
Child Observers will observe the events of the ConnectableObservable on the
specified scheduler.
|
static <T> Callable<ConnectableObservable<T>> |
ObservableInternalHelper.replayCallable(Observable<T> parent,
int bufferSize,
long time,
TimeUnit unit,
Scheduler scheduler) |
static <T> Callable<ConnectableObservable<T>> |
ObservableInternalHelper.replayCallable(Observable<T> parent,
long time,
TimeUnit unit,
Scheduler scheduler) |
static <T,R> Function<Observable<T>,ObservableSource<R>> |
ObservableInternalHelper.replayFunction(Function<? super Observable<T>,? extends ObservableSource<R>> selector,
Scheduler scheduler) |
Constructor and Description |
---|
ObservableBufferTimed(ObservableSource<T> source,
long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
Callable<U> bufferSupplier,
int maxSize,
boolean restartTimerOnMaxSize) |
ObservableDebounceTimed(ObservableSource<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
ObservableDelay(ObservableSource<T> source,
long delay,
TimeUnit unit,
Scheduler scheduler,
boolean delayError) |
ObservableInterval(long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler) |
ObservableIntervalRange(long start,
long end,
long initialDelay,
long period,
TimeUnit unit,
Scheduler scheduler) |
ObservableObserveOn(ObservableSource<T> source,
Scheduler scheduler,
boolean delayError,
int bufferSize) |
ObservableRefCount(ConnectableObservable<T> source,
int n,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
ObservableSampleTimed(ObservableSource<T> source,
long period,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast) |
ObservableSkipLastTimed(ObservableSource<T> source,
long time,
TimeUnit unit,
Scheduler scheduler,
int bufferSize,
boolean delayError) |
ObservableSubscribeOn(ObservableSource<T> source,
Scheduler scheduler) |
ObservableTakeLastTimed(ObservableSource<T> source,
long count,
long time,
TimeUnit unit,
Scheduler scheduler,
int bufferSize,
boolean delayError) |
ObservableThrottleFirstTimed(ObservableSource<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler) |
ObservableThrottleLatest(Observable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
boolean emitLast) |
ObservableTimeInterval(ObservableSource<T> source,
TimeUnit unit,
Scheduler scheduler) |
ObservableTimeoutTimed(Observable<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
ObservableSource<? extends T> other) |
ObservableTimer(long delay,
TimeUnit unit,
Scheduler scheduler) |
ObservableUnsubscribeOn(ObservableSource<T> source,
Scheduler scheduler) |
ObservableWindowTimed(ObservableSource<T> source,
long timespan,
long timeskip,
TimeUnit unit,
Scheduler scheduler,
long maxSize,
int bufferSize,
boolean restartTimerOnMaxSize) |
Constructor and Description |
---|
ParallelRunOn(ParallelFlowable<? extends T> parent,
Scheduler scheduler,
int prefetch) |
Constructor and Description |
---|
SingleDelay(SingleSource<? extends T> source,
long time,
TimeUnit unit,
Scheduler scheduler,
boolean delayError) |
SingleObserveOn(SingleSource<T> source,
Scheduler scheduler) |
SingleSubscribeOn(SingleSource<? extends T> source,
Scheduler scheduler) |
SingleTimeout(SingleSource<T> source,
long timeout,
TimeUnit unit,
Scheduler scheduler,
SingleSource<? extends T> other) |
SingleTimer(long delay,
TimeUnit unit,
Scheduler scheduler) |
SingleUnsubscribeOn(SingleSource<T> source,
Scheduler scheduler) |
Modifier and Type | Class and Description |
---|---|
class |
ComputationScheduler
Holds a fixed pool of worker threads and assigns them
to requested Scheduler.Workers in a round-robin fashion.
|
class |
ExecutorScheduler
Wraps an Executor and provides the Scheduler API over it.
|
class |
ImmediateThinScheduler
A Scheduler partially implementing the API by allowing only non-delayed, non-periodic
task execution on the current thread immediately.
|
class |
IoScheduler
Scheduler that creates and caches a set of thread pools and reuses them if possible.
|
class |
NewThreadScheduler
Schedules work on a new thread.
|
class |
SchedulerWhen
Allows the use of operators for controlling the timing around when actions
scheduled on workers are actually done.
|
class |
SingleScheduler
A scheduler with a shared, single threaded underlying ScheduledExecutorService.
|
class |
TrampolineScheduler
Schedules work on the current thread but does not execute immediately.
|
Modifier and Type | Field and Description |
---|---|
static Scheduler |
ImmediateThinScheduler.INSTANCE
The singleton instance of the immediate (thin) scheduler.
|
Constructor and Description |
---|
SchedulerWhen(Function<Flowable<Flowable<Completable>>,Completable> combine,
Scheduler actualScheduler) |
Modifier and Type | Method and Description |
---|---|
Observable<T> |
ConnectableObservable.refCount(int subscriberCount,
long timeout,
TimeUnit unit,
Scheduler scheduler)
Connects to the upstream
ConnectableObservable if the number of subscribed
subscriber reaches the specified count and disconnect after the specified
timeout if all subscribers have unsubscribed. |
Observable<T> |
ConnectableObservable.refCount(long timeout,
TimeUnit unit,
Scheduler scheduler)
Connects to the upstream
ConnectableObservable 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 |
---|---|
ParallelFlowable<T> |
ParallelFlowable.runOn(Scheduler scheduler)
Specifies where each 'rail' will observe its incoming values with
no work-stealing and default prefetch amount.
|
ParallelFlowable<T> |
ParallelFlowable.runOn(Scheduler scheduler,
int prefetch)
Specifies where each 'rail' will observe its incoming values with
possibly work-stealing and a given prefetch amount.
|
Modifier and Type | Method and Description |
---|---|
static Scheduler |
RxJavaPlugins.createComputationScheduler(ThreadFactory threadFactory)
Create an instance of the default
Scheduler used for Schedulers.computation()
except using threadFactory for thread creation. |
static Scheduler |
RxJavaPlugins.createIoScheduler(ThreadFactory threadFactory)
Create an instance of the default
Scheduler used for Schedulers.io()
except using threadFactory for thread creation. |
static Scheduler |
RxJavaPlugins.createNewThreadScheduler(ThreadFactory threadFactory)
Create an instance of the default
Scheduler used for Schedulers.newThread()
except using threadFactory for thread creation. |
static Scheduler |
RxJavaPlugins.createSingleScheduler(ThreadFactory threadFactory)
Create an instance of the default
Scheduler used for Schedulers.single()
except using threadFactory for thread creation. |
static Scheduler |
RxJavaPlugins.initComputationScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initIoScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initNewThreadScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initSingleScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onComputationScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onIoScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onNewThreadScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onSingleScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
Modifier and Type | Method and Description |
---|---|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getComputationSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getComputationSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitComputationSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitComputationSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitIoSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitIoSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitNewThreadSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitNewThreadSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitSingleSchedulerHandler()
Returns the current hook function.
|
static Function<? super Callable<Scheduler>,? extends Scheduler> |
RxJavaPlugins.getInitSingleSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getIoSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getIoSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getNewThreadSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getNewThreadSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getSingleSchedulerHandler()
Returns the current hook function.
|
static Function<? super Scheduler,? extends Scheduler> |
RxJavaPlugins.getSingleSchedulerHandler()
Returns the current hook function.
|
Modifier and Type | Method and Description |
---|---|
static Scheduler |
RxJavaPlugins.onComputationScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onIoScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onNewThreadScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.onSingleScheduler(Scheduler defaultScheduler)
Calls the associated hook function.
|
Modifier and Type | Method and Description |
---|---|
static Scheduler |
RxJavaPlugins.initComputationScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initIoScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initNewThreadScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static Scheduler |
RxJavaPlugins.initSingleScheduler(Callable<Scheduler> defaultScheduler)
Calls the associated hook function.
|
static void |
RxJavaPlugins.setComputationSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setComputationSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitComputationSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitComputationSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitIoSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitIoSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitNewThreadSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitNewThreadSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitSingleSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setInitSingleSchedulerHandler(Function<? super Callable<Scheduler>,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setIoSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setIoSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setNewThreadSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setNewThreadSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setSingleSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
static void |
RxJavaPlugins.setSingleSchedulerHandler(Function<? super Scheduler,? extends Scheduler> handler)
Sets the specific hook function.
|
Modifier and Type | Method and Description |
---|---|
static <T> ReplayProcessor<T> |
ReplayProcessor.createWithTime(long maxAge,
TimeUnit unit,
Scheduler scheduler)
Creates a time-bounded ReplayProcessor.
|
static <T> ReplayProcessor<T> |
ReplayProcessor.createWithTimeAndSize(long maxAge,
TimeUnit unit,
Scheduler scheduler,
int maxSize)
Creates a time- and size-bounded ReplayProcessor.
|
Modifier and Type | Class and Description |
---|---|
class |
TestScheduler
A special, non thread-safe scheduler for testing operators that require
a scheduler without introducing real concurrency and allows manually advancing
a virtual time.
|
Modifier and Type | Method and Description |
---|---|
static Scheduler |
Schedulers.computation()
Returns a default, shared
Scheduler instance intended for computational work. |
static Scheduler |
Schedulers.from(Executor executor)
Wraps an
Executor into a new Scheduler instance and delegates schedule()
calls to it. |
static Scheduler |
Schedulers.io()
Returns a default, shared
Scheduler instance intended for IO-bound work. |
static Scheduler |
Schedulers.newThread()
|
static Scheduler |
Schedulers.single()
Returns a default, shared, single-thread-backed
Scheduler instance for work
requiring strongly-sequential execution on the same background thread. |
static Scheduler |
Schedulers.trampoline()
Returns a default, shared
Scheduler instance whose Scheduler.Worker
instances queue work and execute them in a FIFO manner on one of the participating threads. |
Modifier and Type | Method and Description |
---|---|
static <T> ReplaySubject<T> |
ReplaySubject.createWithTime(long maxAge,
TimeUnit unit,
Scheduler scheduler)
Creates a time-bounded replay subject.
|
static <T> ReplaySubject<T> |
ReplaySubject.createWithTimeAndSize(long maxAge,
TimeUnit unit,
Scheduler scheduler,
int maxSize)
Creates a time- and size-bounded replay subject.
|
Copyright © 2018 JBoss by Red Hat. All rights reserved.