Uses of Class
rx.Scheduler
-
Packages that use Scheduler Package Description rx Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.rx.internal.operators Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.rx.internal.schedulers rx.internal.util rx.plugins Callback types and a central plugin handler class to hook into the lifecycle of the base reactive types and schedulers.rx.schedulers Scheduler implementations, value+time record classes and the standard factory class to return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.rx.subjects Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables). -
-
Uses of Scheduler in rx
Methods in rx with type parameters of type Scheduler Modifier and Type Method Description <S extends Scheduler & Subscription>
SScheduler. when(Func1<Observable<Observable<Completable>>,Completable> combine)
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.Methods in rx with parameters of type Scheduler Modifier and Type Method Description Observable<java.util.List<T>>
Observable. buffer(long timespan, long timeshift, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits buffers of items it collects from the source Observable.Observable<java.util.List<T>>
Observable. buffer(long timespan, java.util.concurrent.TimeUnit unit, int count, Scheduler scheduler)
Returns an Observable that emits buffers of items it collects from the source Observable.Observable<java.util.List<T>>
Observable. buffer(long timespan, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits buffers of items it collects from the source Observable.Observable<T>
Observable. debounce(long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by newer items before a timeout value expires on a specified Scheduler.Completable
Completable. delay(long delay, java.util.concurrent.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.Completable
Completable. delay(long delay, java.util.concurrent.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.Observable<T>
Observable. delay(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits the items emitted by the source Observable shifted forward in time by a specified delay.Single<T>
Single. delay(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay.Observable<T>
Observable. delaySubscription(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that delays the subscription to the source Observable by a given amount of time, both waiting and subscribing on a given Scheduler.static <T> Observable<T>
Observable. from(java.util.concurrent.Future<? extends T> future, Scheduler scheduler)
Converts aFuture
, operating on a specifiedScheduler
, into an Observable.static <T> Single<T>
Single. from(java.util.concurrent.Future<? extends T> future, Scheduler scheduler)
static Observable<java.lang.Long>
Observable. interval(long initialDelay, long period, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits a0L
after theinitialDelay
and ever increasing numbers after eachperiod
of time thereafter, on a specifiedScheduler
.static Observable<java.lang.Long>
Observable. interval(long interval, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits a sequential number every specified interval of time, on a specified Scheduler.Completable
Completable. observeOn(Scheduler scheduler)
Returns a Completable which emits the terminal events from the thread of the specified scheduler.Observable<T>
Observable. observeOn(Scheduler scheduler)
Modifies an Observable to perform its emissions and notifications on a specifiedScheduler
, asynchronously with a bounded buffer ofRxRingBuffer.SIZE
slots.Observable<T>
Observable. observeOn(Scheduler scheduler, boolean delayError)
Modifies an Observable to perform its emissions and notifications on a specifiedScheduler
, asynchronously with a bounded buffer and optionally delays onError notifications.Observable<T>
Observable. observeOn(Scheduler scheduler, boolean delayError, int bufferSize)
Modifies an Observable to perform its emissions and notifications on a specifiedScheduler
, asynchronously with a bounded buffer of configurable size and optionally delays onError notifications.Observable<T>
Observable. observeOn(Scheduler scheduler, int bufferSize)
Modifies an Observable to perform its emissions and notifications on a specifiedScheduler
, asynchronously with a bounded buffer of configurable size.Single<T>
Single. observeOn(Scheduler scheduler)
Modifies a Single to emit its item (or notify of its error) on a specifiedScheduler
, asynchronously.static Observable<java.lang.Integer>
Observable. range(int start, int count, Scheduler scheduler)
Returns an Observable that emits a sequence of Integers within a specified range, on a specified Scheduler.Observable<T>
Observable. repeat(long count, Scheduler scheduler)
Returns an Observable that repeats the sequence of items emitted by the source Observable at mostcount
times, on a particular Scheduler.Observable<T>
Observable. repeat(Scheduler scheduler)
Returns an Observable that repeats the sequence of items emitted by the source Observable indefinitely, on a particular Scheduler.Observable<T>
Observable. repeatWhen(Func1<? super Observable<? extends java.lang.Void>,? extends Observable<?>> notificationHandler, Scheduler scheduler)
Returns an Observable that emits the same values as the source Observable with the exception of anonCompleted
.ConnectableObservable<T>
Observable. replay(int bufferSize, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns aConnectableObservable
that shares a single subscription to the source Observable and that replays a maximum ofbufferSize
items that are emitted within a specified time window.ConnectableObservable<T>
Observable. replay(int bufferSize, Scheduler scheduler)
Returns aConnectableObservable
that shares a single subscription to the source Observable and replays at mostbufferSize
items emitted by that Observable.ConnectableObservable<T>
Observable. replay(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns aConnectableObservable
that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window.<R> Observable<R>
Observable. replay(Func1<? super Observable<T>,? extends Observable<R>> selector, int bufferSize, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by aConnectableObservable
that shares a single subscription to the source Observable, replaying no more thanbufferSize
items that were emitted within a specified time window.<R> Observable<R>
Observable. replay(Func1<? super Observable<T>,? extends Observable<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 aConnectableObservable
that shares a single subscription to the source Observable, replaying a maximum ofbufferSize
items.<R> Observable<R>
Observable. replay(Func1<? super Observable<T>,? extends Observable<R>> selector, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by aConnectableObservable
that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window.<R> Observable<R>
Observable. replay(Func1<? super Observable<T>,? extends Observable<R>> selector, Scheduler scheduler)
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by aConnectableObservable
that shares a single subscription to the source Observable.ConnectableObservable<T>
Observable. replay(Scheduler scheduler)
Returns aConnectableObservable
that shares a single subscription to the source Observable that will replay all of its items and notifications to any futureObserver
on the givenScheduler
.Observable<T>
Observable. retryWhen(Func1<? super Observable<? extends java.lang.Throwable>,? extends Observable<?>> notificationHandler, Scheduler scheduler)
Returns an Observable that emits the same values as the source observable with the exception of anonError
.Observable<T>
Observable. sample(long period, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits the most recently emitted item (if any) emitted by the source Observable within periodic time intervals, where the intervals are defined on a particular Scheduler.Observable<T>
Observable. skip(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that skips values emitted by the source Observable before a specified time window on a specifiedScheduler
elapses.Observable<T>
Observable. skipLast(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that drops items emitted by the source Observable 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.Observable<T>
Observable. subscribeOn(Scheduler scheduler)
Asynchronously subscribes Observers to this Observable on the specifiedScheduler
.Single<T>
Single. subscribeOn(Scheduler scheduler)
Asynchronously subscribes subscribers to this Single on the specifiedScheduler
.Observable<T>
Observable. take(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits those items emitted by source Observable before a specified time (on a specified Scheduler) runs out.Observable<T>
Observable. takeLast(int count, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits at most a specified number of items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a given Scheduler.Observable<T>
Observable. takeLast(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits the items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a specified Scheduler.Observable<java.util.List<T>>
Observable. takeLastBuffer(int count, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits a single List containing at mostcount
items from the source Observable that were emitted during a specified window of time (on a specified Scheduler) before the source Observable completed.Observable<java.util.List<T>>
Observable. takeLastBuffer(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed, where the timing information is provided by the given Scheduler.Observable<T>
Observable. throttleFirst(long skipDuration, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits only the first item emitted by the source Observable during sequential time windows of a specified duration, where the windows are managed by a specified Scheduler.Observable<T>
Observable. throttleLast(long intervalDuration, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits only the last item emitted by the source Observable during sequential time windows of a specified duration, where the duration is governed by a specified Scheduler.Observable<T>
Observable. throttleWithTimeout(long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that only emits those items emitted by the source Observable that are not followed by another emitted item within a specified time window, where the time window is governed by a specified Scheduler.Observable<TimeInterval<T>>
Observable. timeInterval(Scheduler scheduler)
Returns an Observable that emits records of the time interval between consecutive items emitted by the source Observable, where this interval is computed on a specified Scheduler.Completable
Completable. timeout(long timeout, java.util.concurrent.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.Completable
Completable. timeout(long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler, Completable 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.Observable<T>
Observable. timeout(long timeout, java.util.concurrent.TimeUnit timeUnit, Observable<? extends T> other, Scheduler scheduler)
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item using a specified Scheduler.Observable<T>
Observable. timeout(long timeout, java.util.concurrent.TimeUnit timeUnit, Scheduler scheduler)
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item, where this policy is governed on a specified Scheduler.Single<T>
Single. timeout(long timeout, java.util.concurrent.TimeUnit timeUnit, Scheduler scheduler)
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, where this policy is governed on a specified Scheduler.Single<T>
Single. timeout(long timeout, java.util.concurrent.TimeUnit timeUnit, Single<? extends T> other, Scheduler scheduler)
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, using a specified Scheduler.Completable
Completable. timeout0(long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler, Completable other)
Returns a Completable that runs this Completable and optionally switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.static Completable
Completable. timer(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns a Completable instance that fires its onCompleted event after the given delay elapsed by using the supplied scheduler.static Observable<java.lang.Long>
Observable. timer(long initialDelay, long period, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Deprecated.static Observable<java.lang.Long>
Observable. timer(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits one item after a specified delay, on a specified Scheduler, and then completes.Observable<Timestamped<T>>
Observable. timestamp(Scheduler scheduler)
Returns an Observable that emits each item emitted by the source Observable, wrapped in aTimestamped
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 schedulerObservable<T>
Observable. unsubscribeOn(Scheduler scheduler)
Modifies the source Observable so that subscribers will unsubscribe from it on a specifiedScheduler
.Observable<Observable<T>>
Observable. window(long timespan, long timeshift, java.util.concurrent.TimeUnit unit, int count, Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source Observable.Observable<Observable<T>>
Observable. window(long timespan, long timeshift, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source Observable.Observable<Observable<T>>
Observable. window(long timespan, java.util.concurrent.TimeUnit unit, int count, Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source Observable.Observable<Observable<T>>
Observable. window(long timespan, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns an Observable that emits windows of items it collects from the source Observable. -
Uses of Scheduler in rx.internal.operators
Fields in rx.internal.operators declared as Scheduler Modifier and Type Field Description (package private) Scheduler
CompletableOnSubscribeTimeout. scheduler
(package private) Scheduler
OnSubscribeDelaySubscription. scheduler
private Scheduler
OnSubscribeRedo. scheduler
(package private) Scheduler
OnSubscribeTimerOnce. scheduler
(package private) Scheduler
OnSubscribeTimerPeriodically. scheduler
(package private) Scheduler
OperatorBufferWithTime. scheduler
(package private) Scheduler
OperatorDebounceWithTime. scheduler
(package private) Scheduler
OperatorDelay. scheduler
private Scheduler
OperatorObserveOn. scheduler
(package private) Scheduler
OperatorReplay.SizeAndTimeBoundReplayBuffer. scheduler
(package private) Scheduler
OperatorSampleWithTime. scheduler
(package private) Scheduler
OperatorSkipLastTimed. scheduler
(package private) Scheduler
OperatorSkipTimed. scheduler
(package private) Scheduler
OperatorSubscribeOn. scheduler
(package private) Scheduler
OperatorTakeLastTimed. scheduler
(package private) Scheduler
OperatorTakeLastTimed.TakeLastTimedSubscriber. scheduler
(package private) Scheduler
OperatorTakeTimed. scheduler
(package private) Scheduler
OperatorThrottleFirst. scheduler
(package private) Scheduler
OperatorTimeInterval. scheduler
(package private) Scheduler
OperatorTimeoutBase. scheduler
(package private) Scheduler
OperatorTimestamp. scheduler
(package private) Scheduler
OperatorUnsubscribeOn. scheduler
(package private) Scheduler
OperatorWindowWithTime. scheduler
Methods in rx.internal.operators with parameters of type Scheduler Modifier and Type Method Description static <T> ConnectableObservable<T>
OperatorReplay. create(Observable<? extends T> source, long maxAge, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Creates a replaying ConnectableObservable with a time bound buffer.static <T> ConnectableObservable<T>
OperatorReplay. create(Observable<? extends T> source, long maxAge, java.util.concurrent.TimeUnit unit, Scheduler scheduler, int bufferSize)
Creates a replaying ConnectableObservable with a size and time bound buffer.static <T> ConnectableObservable<T>
OperatorReplay. observeOn(ConnectableObservable<T> co, Scheduler scheduler)
Child Subscribers will observe the events of the ConnectableObservable on the specified scheduler.static <T> Observable<T>
OnSubscribeRedo. redo(Observable<T> source, Func1<? super Observable<? extends Notification<?>>,? extends Observable<?>> notificationHandler, Scheduler scheduler)
static <T> Observable<T>
OnSubscribeRedo. repeat(Observable<T> source, long count, Scheduler scheduler)
static <T> Observable<T>
OnSubscribeRedo. repeat(Observable<T> source, Func1<? super Observable<? extends Notification<?>>,? extends Observable<?>> notificationHandler, Scheduler scheduler)
static <T> Observable<T>
OnSubscribeRedo. repeat(Observable<T> source, Scheduler scheduler)
static <T> Observable<T>
OnSubscribeRedo. retry(Observable<T> source, Func1<? super Observable<? extends Notification<?>>,? extends Observable<?>> notificationHandler, Scheduler scheduler)
Constructors in rx.internal.operators with parameters of type Scheduler Constructor Description CompletableOnSubscribeTimeout(Completable source, long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler, Completable other)
ObserveOnSubscriber(Scheduler scheduler, Subscriber<? super T> child, boolean delayError, int bufferSize)
OnSubscribeDelaySubscription(Observable<? extends T> source, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OnSubscribeRedo(Observable<T> source, Func1<? super Observable<? extends Notification<?>>,? extends Observable<?>> f, boolean stopOnComplete, boolean stopOnError, Scheduler scheduler)
OnSubscribeTimerOnce(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OnSubscribeTimerPeriodically(long initialDelay, long period, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorBufferWithTime(long timespan, long timeshift, java.util.concurrent.TimeUnit unit, int count, Scheduler scheduler)
OperatorDebounceWithTime(long timeout, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorDelay(long delay, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorObserveOn(Scheduler scheduler, boolean delayError)
OperatorObserveOn(Scheduler scheduler, boolean delayError, int bufferSize)
OperatorSampleWithTime(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorSkipLastTimed(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorSkipTimed(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorSubscribeOn(Observable<T> source, Scheduler scheduler)
OperatorTakeLastTimed(int count, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorTakeLastTimed(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorTakeTimed(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorThrottleFirst(long windowDuration, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
OperatorTimeInterval(Scheduler scheduler)
OperatorTimeout(long timeout, java.util.concurrent.TimeUnit timeUnit, Observable<? extends T> other, Scheduler scheduler)
OperatorTimeoutBase(OperatorTimeoutBase.FirstTimeoutStub<T> firstTimeoutStub, OperatorTimeoutBase.TimeoutStub<T> timeoutStub, Observable<? extends T> other, Scheduler scheduler)
OperatorTimestamp(Scheduler scheduler)
OperatorUnsubscribeOn(Scheduler scheduler)
OperatorWindowWithTime(long timespan, long timeshift, java.util.concurrent.TimeUnit unit, int size, Scheduler scheduler)
SizeAndTimeBoundReplayBuffer(int limit, long maxAgeInMillis, Scheduler scheduler)
TakeLastTimedSubscriber(Subscriber<? super T> actual, int count, long ageMillis, Scheduler scheduler)
-
Uses of Scheduler in rx.internal.schedulers
Subclasses of Scheduler in rx.internal.schedulers Modifier and Type Class Description class
CachedThreadScheduler
class
EventLoopsScheduler
class
ExecutorScheduler
Scheduler that wraps an Executor instance and establishes the Scheduler contract upon it.class
ImmediateScheduler
Executes work immediately on the current thread.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
TrampolineScheduler
Schedules work on the current thread but does not execute immediately.Fields in rx.internal.schedulers declared as Scheduler Modifier and Type Field Description private Scheduler
SchedulerWhen. actualScheduler
Constructors in rx.internal.schedulers with parameters of type Scheduler Constructor Description SchedulerWhen(Func1<Observable<Observable<Completable>>,Completable> combine, Scheduler actualScheduler)
-
Uses of Scheduler in rx.internal.util
Fields in rx.internal.util declared as Scheduler Modifier and Type Field Description private Scheduler
InternalObservableUtils.ReplaySupplierBufferTime. scheduler
private Scheduler
InternalObservableUtils.ReplaySupplierTime. scheduler
(package private) Scheduler
InternalObservableUtils.SelectorAndObserveOn. scheduler
private Scheduler
ScalarSynchronousSingle.NormalScheduledEmission. scheduler
Methods in rx.internal.util with parameters of type Scheduler Modifier and Type Method Description static <T,R>
Func1<Observable<T>,Observable<R>>InternalObservableUtils. createReplaySelectorAndObserveOn(Func1<? super Observable<T>,? extends Observable<R>> selector, Scheduler scheduler)
Creates a Func1 which calls the selector function with the received argument, applies an observeOn on the result and returns the resulting Observable.static <T> Func0<ConnectableObservable<T>>
InternalObservableUtils. createReplaySupplier(Observable<T> source, int bufferSize, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns a Func0 that supplies the ConnectableObservable returned by calling a parameterized replay() on the source.static <T> Func0<ConnectableObservable<T>>
InternalObservableUtils. createReplaySupplier(Observable<T> source, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Returns a Func0 that supplies the ConnectableObservable returned by calling a parameterized replay() on the source.Observable<T>
ScalarSynchronousObservable. scalarScheduleOn(Scheduler scheduler)
Customized observeOn/subscribeOn implementation which emits the scalar value directly or with less overhead on the specified scheduler.Single<T>
ScalarSynchronousSingle. scalarScheduleOn(Scheduler scheduler)
Customized observeOn/subscribeOn implementation which emits the scalar value directly or with less overhead on the specified scheduler.Constructors in rx.internal.util with parameters of type Scheduler Constructor Description NormalScheduledEmission(Scheduler scheduler, T value)
ReplaySupplierBufferTime(Observable<T> source, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
ReplaySupplierTime(Observable<T> source, int bufferSize, long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
SelectorAndObserveOn(Func1<? super Observable<T>,? extends Observable<R>> selector, Scheduler scheduler)
-
Uses of Scheduler in rx.plugins
Fields in rx.plugins with type parameters of type Scheduler Modifier and Type Field Description (package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onComputationScheduler
(package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onComputationScheduler
(package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onIOScheduler
(package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onIOScheduler
(package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onNewThreadScheduler
(package private) static Func1<Scheduler,Scheduler>
RxJavaHooks. onNewThreadScheduler
Methods in rx.plugins that return Scheduler Modifier and Type Method Description static Scheduler
RxJavaSchedulersHook. createComputationScheduler()
Create an instance of the defaultScheduler
used forSchedulers.computation()
.static Scheduler
RxJavaSchedulersHook. createComputationScheduler(java.util.concurrent.ThreadFactory threadFactory)
Create an instance of the defaultScheduler
used forSchedulers.computation()
except usingthreadFactory
for thread creation.static Scheduler
RxJavaSchedulersHook. createIoScheduler()
Create an instance of the defaultScheduler
used forSchedulers.io()
.static Scheduler
RxJavaSchedulersHook. createIoScheduler(java.util.concurrent.ThreadFactory threadFactory)
Create an instance of the defaultScheduler
used forSchedulers.io()
except usingthreadFactory
for thread creation.static Scheduler
RxJavaSchedulersHook. createNewThreadScheduler()
Create an instance of the defaultScheduler
used forSchedulers.newThread()
.static Scheduler
RxJavaSchedulersHook. createNewThreadScheduler(java.util.concurrent.ThreadFactory threadFactory)
Create an instance of the defaultScheduler
used forSchedulers.newThread()
except usingthreadFactory
for thread creation.Scheduler
RxJavaSchedulersHook. getComputationScheduler()
Scheduler to return fromSchedulers.computation()
or null if default should be used.Scheduler
RxJavaSchedulersHook. getIOScheduler()
Scheduler to return fromSchedulers.io()
or null if default should be used.Scheduler
RxJavaSchedulersHook. getNewThreadScheduler()
Scheduler to return fromSchedulers.newThread()
or null if default should be used.static Scheduler
RxJavaHooks. onComputationScheduler(Scheduler scheduler)
Hook to call when the Schedulers.computation() is called.static Scheduler
RxJavaHooks. onIOScheduler(Scheduler scheduler)
Hook to call when the Schedulers.io() is called.static Scheduler
RxJavaHooks. onNewThreadScheduler(Scheduler scheduler)
Hook to call when the Schedulers.newThread() is called.Methods in rx.plugins that return types with arguments of type Scheduler Modifier and Type Method Description static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnComputationScheduler()
Returns the current computation scheduler hook function or null if it is set to the default pass-through.static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnComputationScheduler()
Returns the current computation scheduler hook function or null if it is set to the default pass-through.static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnIOScheduler()
Returns the current io scheduler hook function or null if it is set to the default pass-through.static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnIOScheduler()
Returns the current io scheduler hook function or null if it is set to the default pass-through.static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnNewThreadScheduler()
Returns the current new thread scheduler hook function or null if it is set to the default pass-through.static Func1<Scheduler,Scheduler>
RxJavaHooks. getOnNewThreadScheduler()
Returns the current new thread scheduler hook function or null if it is set to the default pass-through.Methods in rx.plugins with parameters of type Scheduler Modifier and Type Method Description static Scheduler
RxJavaHooks. onComputationScheduler(Scheduler scheduler)
Hook to call when the Schedulers.computation() is called.static Scheduler
RxJavaHooks. onIOScheduler(Scheduler scheduler)
Hook to call when the Schedulers.io() is called.static Scheduler
RxJavaHooks. onNewThreadScheduler(Scheduler scheduler)
Hook to call when the Schedulers.newThread() is called.Method parameters in rx.plugins with type arguments of type Scheduler Modifier and Type Method Description static void
RxJavaHooks. setOnComputationScheduler(Func1<Scheduler,Scheduler> onComputationScheduler)
Sets the hook function for returning a scheduler when the Schedulers.computation() is called unless a lockdown is in effect.static void
RxJavaHooks. setOnComputationScheduler(Func1<Scheduler,Scheduler> onComputationScheduler)
Sets the hook function for returning a scheduler when the Schedulers.computation() is called unless a lockdown is in effect.static void
RxJavaHooks. setOnIOScheduler(Func1<Scheduler,Scheduler> onIOScheduler)
Sets the hook function for returning a scheduler when the Schedulers.io() is called unless a lockdown is in effect.static void
RxJavaHooks. setOnIOScheduler(Func1<Scheduler,Scheduler> onIOScheduler)
Sets the hook function for returning a scheduler when the Schedulers.io() is called unless a lockdown is in effect.static void
RxJavaHooks. setOnNewThreadScheduler(Func1<Scheduler,Scheduler> onNewThreadScheduler)
Sets the hook function for returning a scheduler when the Schedulers.newThread() is called unless a lockdown is in effect.static void
RxJavaHooks. setOnNewThreadScheduler(Func1<Scheduler,Scheduler> onNewThreadScheduler)
Sets the hook function for returning a scheduler when the Schedulers.newThread() is called unless a lockdown is in effect. -
Uses of Scheduler in rx.schedulers
Subclasses of Scheduler in rx.schedulers Modifier and Type Class Description class
ImmediateScheduler
Deprecated.This type was never publicly instantiable.class
NewThreadScheduler
Deprecated.This type was never publicly instantiable.class
TestScheduler
TheTestScheduler
is useful for debugging.class
TrampolineScheduler
Deprecated.This type was never publicly instantiable.Fields in rx.schedulers declared as Scheduler Modifier and Type Field Description private Scheduler
Schedulers. computationScheduler
private Scheduler
Schedulers. ioScheduler
private Scheduler
Schedulers. newThreadScheduler
Methods in rx.schedulers that return Scheduler Modifier and Type Method Description static Scheduler
Schedulers. computation()
Creates and returns aScheduler
intended for computational work.static Scheduler
Schedulers. from(java.util.concurrent.Executor executor)
Converts anExecutor
into a new Scheduler instance.static Scheduler
Schedulers. immediate()
Creates and returns aScheduler
that executes work immediately on the current thread.static Scheduler
Schedulers. io()
Creates and returns aScheduler
intended for IO-bound work.static Scheduler
Schedulers. newThread()
Creates and returns aScheduler
that creates a newThread
for each unit of work.static Scheduler
Schedulers. trampoline()
Creates and returns aScheduler
that queues work on the current thread to be executed after the current work completes. -
Uses of Scheduler in rx.subjects
Fields in rx.subjects declared as Scheduler Modifier and Type Field Description (package private) Scheduler
ReplaySubject.ReplaySizeAndTimeBoundBuffer. scheduler
Methods in rx.subjects with parameters of type Scheduler Modifier and Type Method Description static <T> ReplaySubject<T>
ReplaySubject. createWithTime(long time, java.util.concurrent.TimeUnit unit, Scheduler scheduler)
Creates a time-bounded replay subject.static <T> ReplaySubject<T>
ReplaySubject. createWithTimeAndSize(long time, java.util.concurrent.TimeUnit unit, int size, Scheduler scheduler)
Creates a time- and size-bounded replay subject.Constructors in rx.subjects with parameters of type Scheduler Constructor Description ReplaySizeAndTimeBoundBuffer(int limit, long maxAgeMillis, Scheduler scheduler)
-