Uses of Interface
io.reactivex.rxjava3.functions.Supplier
Packages that use Supplier
Package
Description
Base reactive classes:
Flowable
, Observable
,
Single
, Maybe
and
Completable
; base reactive consumers;
other common base interfaces.Classes and interfaces for writing advanced operators within and outside RxJava.
Contains the base type
ParallelFlowable
,
a sub-DSL for working with Flowable
sequences in parallel.Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers.Contains notably the factory class of
Schedulers
providing methods for
retrieving the standard scheduler instances, the TestScheduler
for testing flows
with scheduling in a controlled manner and the class Timed
that can hold
a value and a timestamp associated with it.-
Uses of Supplier in io.reactivex.rxjava3.core
Methods in io.reactivex.rxjava3.core with parameters of type SupplierModifier and TypeMethodDescriptionReturns aFlowable
that emits buffers of items it collects from the currentFlowable
.Returns aFlowable
that emits buffers of items it collects from the currentFlowable
.Flowable.buffer
(long timespan, long timeskip, @NonNull TimeUnit unit, @NonNull Scheduler scheduler, @NonNull Supplier<@NonNull U> bufferSupplier) Returns aFlowable
that emits buffers of items it collects from the currentFlowable
.Flowable.buffer
(long timespan, @NonNull TimeUnit unit, @NonNull Scheduler scheduler, int count, @NonNull Supplier<@NonNull U> bufferSupplier, boolean restartTimerOnMaxSize) Returns aFlowable
that emits buffers of items it collects from the currentFlowable
.final <@NonNull TOpening,
@NonNull TClosing, @NonNull U extends Collection<? super @NonNull T>>
@NonNull Flowable<U> Flowable.buffer
(@NonNull org.reactivestreams.Publisher<? extends @NonNull TOpening> openingIndicator, @NonNull Function<? super @NonNull TOpening, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull TClosing>> closingIndicator, @NonNull Supplier<@NonNull U> bufferSupplier) Returns aFlowable
that emits buffers of items it collects from the currentFlowable
.Flowable.buffer
(@NonNull org.reactivestreams.Publisher<@NonNull B> boundaryIndicator, @NonNull Supplier<@NonNull U> bufferSupplier) Returns aFlowable
that emits non-overlapping buffered items from the currentFlowable
each time the specified boundaryPublisher
emits an item.final <@NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Returns anObservable
that emits buffers of items it collects from the currentObservable
.final <@NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Returns anObservable
that emits buffers of items it collects from the currentObservable
.final <@NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Observable.buffer
(long timespan, long timeskip, @NonNull TimeUnit unit, @NonNull Scheduler scheduler, @NonNull Supplier<@NonNull U> bufferSupplier) Returns anObservable
that emits buffers of items it collects from the currentObservable
.final <@NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Observable.buffer
(long timespan, @NonNull TimeUnit unit, @NonNull Scheduler scheduler, int count, @NonNull Supplier<@NonNull U> bufferSupplier, boolean restartTimerOnMaxSize) Returns anObservable
that emits buffers of items it collects from the currentObservable
.final <@NonNull TOpening,
@NonNull TClosing, @NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Observable.buffer
(@NonNull ObservableSource<? extends @NonNull TOpening> openingIndicator, @NonNull Function<? super @NonNull TOpening, ? extends ObservableSource<? extends @NonNull TClosing>> closingIndicator, @NonNull Supplier<@NonNull U> bufferSupplier) Returns anObservable
that emits buffers of items it collects from the currentObservable
.final <@NonNull B,
@NonNull U extends Collection<? super @NonNull T>>
@NonNull Observable<U> Observable.buffer
(@NonNull ObservableSource<@NonNull B> boundaryIndicator, @NonNull Supplier<@NonNull U> bufferSupplier) Returns anObservable
that emits non-overlapping buffered items from the currentObservable
each time the specified boundaryObservableSource
emits an item.Flowable.collect
(@NonNull Supplier<? extends @NonNull U> initialItemSupplier, @NonNull BiConsumer<? super @NonNull U, ? super @NonNull T> collector) Collects items emitted by the finite sourcePublisher
into a single mutable data structure and returns aSingle
that emits this structure.Observable.collect
(@NonNull Supplier<? extends @NonNull U> initialItemSupplier, @NonNull BiConsumer<? super @NonNull U, ? super @NonNull T> collector) Collects items emitted by the finite sourceObservable
into a single mutable data structure and returns aSingle
that emits this structure.static @NonNull Completable
Completable.defer
(@NonNull Supplier<? extends @NonNull CompletableSource> supplier) Defers the subscription to aCompletable
instance returned by a supplier.Flowable.defer
(@NonNull Supplier<? extends @NonNull org.reactivestreams.Publisher<? extends @NonNull T>> supplier) Returns aFlowable
that calls aPublisher
factory to create aPublisher
for each newSubscriber
that subscribes.Calls aSupplier
for each individualMaybeObserver
to return the actualMaybeSource
source to be subscribed to.static <@NonNull T>
@NonNull Observable<T> Observable.defer
(@NonNull Supplier<? extends @NonNull ObservableSource<? extends @NonNull T>> supplier) Returns anObservable
that calls anObservableSource
factory to create anObservableSource
for each newObserver
that subscribes.Calls aSupplier
for each individualSingleObserver
to return the actualSingleSource
to be subscribed to.Flowable.distinct
(@NonNull Function<? super @NonNull T, @NonNull K> keySelector, @NonNull Supplier<? extends Collection<? super @NonNull K>> collectionSupplier) Returns aFlowable
that emits all items emitted by the currentFlowable
that are distinct according to a key selector function and based onObject.equals(Object)
comparison of the objects returned by the key selector function.final <@NonNull K>
@NonNull Observable<T> Observable.distinct
(@NonNull Function<? super @NonNull T, @NonNull K> keySelector, @NonNull Supplier<? extends Collection<? super @NonNull K>> collectionSupplier) Returns anObservable
that emits all items emitted by the currentObservable
that are distinct according to a key selector function and based onObject.equals(Object)
comparison of the objects returned by the key selector function.static @NonNull Completable
Creates aCompletable
which calls the given error supplier for each subscriber and emits its returnedThrowable
.Returns aFlowable
that invokes aSubscriber
'sonError
method when theSubscriber
subscribes to it.Returns aMaybe
that invokes aMaybeObserver
'sonError
method when theMaybeObserver
subscribes to it.static <@NonNull T>
@NonNull Observable<T> Signals aThrowable
returned by the callback function for each individualSingleObserver
.Flowable.flatMap
(@NonNull Function<? super @NonNull T, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull R>> onNextMapper, @NonNull Function<? super Throwable, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull R>> onErrorMapper, @NonNull Supplier<? extends org.reactivestreams.Publisher<? extends @NonNull R>> onCompleteSupplier) Returns aFlowable
that applies a function to each item emitted or notification raised by the currentFlowable
and then flattens thePublisher
s returned from these functions and emits the resulting items.Flowable.flatMap
(@NonNull Function<? super @NonNull T, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull R>> onNextMapper, @NonNull Function<Throwable, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull R>> onErrorMapper, @NonNull Supplier<? extends org.reactivestreams.Publisher<? extends @NonNull R>> onCompleteSupplier, int maxConcurrency) Returns aFlowable
that applies a function to each item emitted or notification raised by the currentFlowable
and then flattens thePublisher
s returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to thesePublisher
s.Maybe.flatMap
(@NonNull Function<? super @NonNull T, ? extends MaybeSource<? extends @NonNull R>> onSuccessMapper, @NonNull Function<? super Throwable, ? extends MaybeSource<? extends @NonNull R>> onErrorMapper, @NonNull Supplier<? extends MaybeSource<? extends @NonNull R>> onCompleteSupplier) Maps theonSuccess
,onError
oronComplete
signals of the currentMaybe
into aMaybeSource
and emits thatMaybeSource
's signals.final <@NonNull R>
@NonNull Observable<R> Observable.flatMap
(@NonNull Function<? super @NonNull T, ? extends ObservableSource<? extends @NonNull R>> onNextMapper, @NonNull Function<? super Throwable, ? extends ObservableSource<? extends @NonNull R>> onErrorMapper, @NonNull Supplier<? extends ObservableSource<? extends @NonNull R>> onCompleteSupplier) Returns anObservable
that applies a function to each item emitted or notification raised by the currentObservable
and then flattens theObservableSource
s returned from these functions and emits the resulting items.final <@NonNull R>
@NonNull Observable<R> Observable.flatMap
(@NonNull Function<? super @NonNull T, ? extends ObservableSource<? extends @NonNull R>> onNextMapper, @NonNull Function<Throwable, ? extends ObservableSource<? extends @NonNull R>> onErrorMapper, @NonNull Supplier<? extends ObservableSource<? extends @NonNull R>> onCompleteSupplier, int maxConcurrency) Returns anObservable
that applies a function to each item emitted or notification raised by the currentObservable
and then flattens theObservableSource
s returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to theseObservableSource
s.static @NonNull Completable
Completable.fromSupplier
(@NonNull Supplier<?> supplier) Returns aCompletable
which when subscribed, executes theSupplier
function, ignores its normal result and emitsonError
oronComplete
only.Flowable.fromSupplier
(@NonNull Supplier<? extends @NonNull T> supplier) Returns aFlowable
that, when aSubscriber
subscribes to it, invokes a supplier function you specify and then emits the value returned from that function.Maybe.fromSupplier
(@NonNull Supplier<? extends @Nullable T> supplier) Returns aMaybe
that invokes the givenSupplier
for each individualMaybeObserver
that subscribes and emits the resulting non-null
item viaonSuccess
while considering anull
result from theSupplier
as indication for valueless completion viaonComplete
.static <@NonNull T>
@NonNull Observable<T> Observable.fromSupplier
(@NonNull Supplier<? extends @NonNull T> supplier) Returns anObservable
that, when an observer subscribes to it, invokes a supplier function you specify and then emits the value returned from that function.Single.fromSupplier
(@NonNull Supplier<? extends @NonNull T> supplier) Returns aSingle
that invokes passed supplier and emits its result for each individualSingleObserver
that subscribes.Flowable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiConsumer<@NonNull S, Emitter<@NonNull T>> generator) Returns a cold, synchronous, stateful and backpressure-aware generator of values.Flowable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiConsumer<@NonNull S, Emitter<@NonNull T>> generator, @NonNull Consumer<? super @NonNull S> disposeState) Returns a cold, synchronous, stateful and backpressure-aware generator of values.Flowable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiFunction<@NonNull S, @NonNull Emitter<@NonNull T>, @NonNull S> generator) Returns a cold, synchronous, stateful and backpressure-aware generator of values.Flowable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiFunction<@NonNull S, @NonNull Emitter<@NonNull T>, @NonNull S> generator, @NonNull Consumer<? super @NonNull S> disposeState) Returns a cold, synchronous, stateful and backpressure-aware generator of values.static <@NonNull T,
@NonNull S>
@NonNull Observable<T> Observable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiConsumer<@NonNull S, Emitter<@NonNull T>> generator) Returns a cold, synchronous and stateful generator of values.static <@NonNull T,
@NonNull S>
@NonNull Observable<T> Observable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiConsumer<@NonNull S, Emitter<@NonNull T>> generator, @NonNull Consumer<? super @NonNull S> disposeState) Returns a cold, synchronous and stateful generator of values.static <@NonNull T,
@NonNull S>
@NonNull Observable<T> Observable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiFunction<@NonNull S, Emitter<@NonNull T>, @NonNull S> generator) Returns a cold, synchronous and stateful generator of values.static <@NonNull T,
@NonNull S>
@NonNull Observable<T> Observable.generate
(@NonNull Supplier<@NonNull S> initialState, @NonNull BiFunction<@NonNull S, Emitter<@NonNull T>, @NonNull S> generator, @NonNull Consumer<? super @NonNull S> disposeState) Returns a cold, synchronous and stateful generator of values.Flowable.onBackpressureReduce
(@NonNull Supplier<@NonNull R> supplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> reducer) Reduces upstream values into an aggregate value, provided by a supplier and combined via a reducer function, while the downstream is not ready to receive items, then emits this aggregate value when the downstream becomes ready.Flowable.reduceWith
(@NonNull Supplier<@NonNull R> seedSupplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> reducer) Returns aSingle
that applies a specified accumulator function to the first item emitted by the currentFlowable
and a seed value derived from calling a specifiedseedSupplier
, then feeds the result of that function along with the second item emitted by the currentFlowable
into the same function, and so on until all items have been emitted by the current and finiteFlowable
, emitting the final result from the final call to your function as its sole item.Observable.reduceWith
(@NonNull Supplier<@NonNull R> seedSupplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> reducer) Returns aSingle
that applies a specified accumulator function to the first item emitted by the currentObservable
and a seed value derived from calling a specifiedseedSupplier
, then feeds the result of that function along with the second item emitted by the currentObservable
into the same function, and so on until all items have been emitted by the current and finiteObservable
, emitting the final result from the final call to your function as its sole item.Flowable.scanWith
(@NonNull Supplier<@NonNull R> seedSupplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> accumulator) Returns aFlowable
that emits the provided initial (seed) value, then emits one value for each value emitted by the currentFlowable
.final <@NonNull R>
@NonNull Observable<R> Observable.scanWith
(@NonNull Supplier<@NonNull R> seedSupplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> accumulator) Returns anObservable
that emits the provided initial (seed) value, then emits one value for each value emitted by the currentObservable
.Returns aSingle
that emits a single item, a list composed of all the items emitted by the finite sourcePublisher
.Returns aSingle
that emits a single item, aCollection
(subclass) composed of all the items emitted by the finite upstreamObservable
.Flowable.toMap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<? extends Map<@NonNull K, @NonNull V>> mapSupplier) Observable.toMap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<? extends Map<@NonNull K, @NonNull V>> mapSupplier) Flowable.toMultimap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<? extends Map<@NonNull K, Collection<@NonNull V>>> mapSupplier, @NonNull Function<? super @NonNull K, ? extends Collection<? super @NonNull V>> collectionFactory) Flowable.toMultimap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<Map<@NonNull K, Collection<@NonNull V>>> mapSupplier) Observable.toMultimap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<? extends Map<@NonNull K, Collection<@NonNull V>>> mapSupplier, @NonNull Function<? super @NonNull K, ? extends Collection<? super @NonNull V>> collectionFactory) Returns aSingle
that emits a singleMap
(subclass), returned by a specifiedmapFactory
function, that contains a customCollection
of values, extracted by a specifiedvalueSelector
function from items emitted by the current and finiteObservable
, and keyed by thekeySelector
function.Observable.toMultimap
(@NonNull Function<? super @NonNull T, ? extends @NonNull K> keySelector, @NonNull Function<? super @NonNull T, ? extends @NonNull V> valueSelector, @NonNull Supplier<Map<@NonNull K, Collection<@NonNull V>>> mapSupplier) static <@NonNull R>
@NonNull CompletableCompletable.using
(@NonNull Supplier<@NonNull R> resourceSupplier, @NonNull Function<? super @NonNull R, ? extends CompletableSource> sourceSupplier, @NonNull Consumer<? super @NonNull R> resourceCleanup) Returns aCompletable
instance which manages a resource along with a customCompletableSource
instance while the subscription is active.static <@NonNull R>
@NonNull CompletableCompletable.using
(@NonNull Supplier<@NonNull R> resourceSupplier, @NonNull Function<? super @NonNull R, ? extends CompletableSource> sourceSupplier, @NonNull Consumer<? super @NonNull R> resourceCleanup, boolean eager) Returns aCompletable
instance which manages a resource along with a customCompletableSource
instance while the subscription is active and performs eager or lazy resource disposition.Flowable.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup) Constructs aFlowable
that creates a dependent resource object, aPublisher
with that resource and calls the providedresourceDisposer
function if this inner source terminates or the downstream cancels the flow.Flowable.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, @NonNull ? extends org.reactivestreams.Publisher<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup, boolean eager) Constructs aFlowable
that creates a dependent resource object, aPublisher
with that resource and calls the providedresourceDisposer
function if this inner source terminates or the downstream disposes the flow; doing it before these end-states have been reached ifeager == true
, after otherwise.Maybe.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, ? extends MaybeSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup) Constructs aMaybe
that creates a dependent resource object which is disposed of when the generatedMaybeSource
terminates or the downstream calls dispose().Maybe.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, ? extends MaybeSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup, boolean eager) Constructs aMaybe
that creates a dependent resource object which is disposed first ({code eager == true}) when the generatedMaybeSource
terminates or the downstream disposes; or after ({code eager == false}).static <@NonNull T,
@NonNull D>
@NonNull Observable<T> Observable.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, ? extends ObservableSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup) Constructs anObservable
that creates a dependent resource object, anObservableSource
with that resource and calls the providedresourceDisposer
function if this inner source terminates or the downstream disposes the flow.static <@NonNull T,
@NonNull D>
@NonNull Observable<T> Observable.using
(@NonNull Supplier<? extends @NonNull D> resourceSupplier, @NonNull Function<? super @NonNull D, ? extends ObservableSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull D> resourceCleanup, boolean eager) Constructs anObservable
that creates a dependent resource object, anObservableSource
with that resource and calls the provideddisposer
function if this inner source terminates or the downstream disposes the flow; doing it before these end-states have been reached ifeager == true
, after otherwise.Single.using
(@NonNull Supplier<@NonNull U> resourceSupplier, @NonNull Function<? super @NonNull U, ? extends SingleSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull U> resourceCleanup) Allows using and disposing a resource while running aSingleSource
instance generated from that resource (similar to a try-with-resources).Single.using
(@NonNull Supplier<@NonNull U> resourceSupplier, @NonNull Function<? super @NonNull U, ? extends SingleSource<? extends @NonNull T>> sourceSupplier, @NonNull Consumer<? super @NonNull U> resourceCleanup, boolean eager) Allows using and disposing a resource while running aSingleSource
instance generated from that resource (similar to a try-with-resources). -
Uses of Supplier in io.reactivex.rxjava3.internal.functions
Classes in io.reactivex.rxjava3.internal.functions that implement SupplierModifier and TypeClassDescription(package private) static final class
(package private) static enum
(package private) static final class
Functions.JustValue<T,
U> (package private) static final class
Fields in io.reactivex.rxjava3.internal.functions declared as SupplierMethods in io.reactivex.rxjava3.internal.functions that return SupplierModifier and TypeMethodDescriptionFunctions.createArrayList
(int capacity) Functions.createHashSet()
Functions.justSupplier
(T value) Returns a Supplier that returns the given value.Functions.nullSupplier()
-
Uses of Supplier in io.reactivex.rxjava3.internal.operators.completable
Fields in io.reactivex.rxjava3.internal.operators.completable declared as SupplierModifier and TypeFieldDescription(package private) final Supplier
<? extends CompletableSource> CompletableDefer.completableSupplier
CompletableToSingle.completionValueSupplier
CompletableErrorSupplier.errorSupplier
CompletableUsing.resourceSupplier
(package private) final Supplier
<?> CompletableFromSupplier.supplier
Constructors in io.reactivex.rxjava3.internal.operators.completable with parameters of type SupplierModifierConstructorDescriptionCompletableDefer
(Supplier<? extends CompletableSource> completableSupplier) CompletableErrorSupplier
(Supplier<? extends Throwable> errorSupplier) CompletableFromSupplier
(Supplier<?> supplier) CompletableToSingle
(CompletableSource source, Supplier<? extends T> completionValueSupplier, T completionValue) CompletableUsing
(Supplier<R> resourceSupplier, Function<? super R, ? extends CompletableSource> completableFunction, Consumer<? super R> disposer, boolean eager) -
Uses of Supplier in io.reactivex.rxjava3.internal.operators.flowable
Classes in io.reactivex.rxjava3.internal.operators.flowable that implement SupplierModifier and TypeClassDescriptionfinal class
A source Flowable that signals an onSubscribe() + onComplete() only.final class
Executes anAction
and signals its exception or completes normally.final class
final class
Executes anRunnable
and signals its exception or completes normally.final class
Call a Supplier for each incoming Subscriber and signal the returned value or the thrown exception.(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
final class
FlowableJust<T>
Represents a constant scalar value.(package private) static final class
(package private) static final class
(package private) static final class
Fields in io.reactivex.rxjava3.internal.operators.flowable declared as SupplierModifier and TypeFieldDescription(package private) final Supplier
<? extends FlowableReplay.ReplayBuffer<T>> FlowableReplay.bufferFactory
A factory that creates the appropriate buffer for the ReplaySubscriber.private final Supplier
<? extends FlowableReplay.ReplayBuffer<T>> FlowableReplay.ReplayPublisher.bufferFactory
FlowableBuffer.bufferSupplier
FlowableBuffer.PublisherBufferExactSubscriber.bufferSupplier
FlowableBuffer.PublisherBufferOverlappingSubscriber.bufferSupplier
FlowableBuffer.PublisherBufferSkipSubscriber.bufferSupplier
FlowableBufferBoundary.BufferBoundarySubscriber.bufferSupplier
FlowableBufferBoundary.bufferSupplier
FlowableBufferExactBoundary.BufferExactBoundarySubscriber.bufferSupplier
FlowableBufferExactBoundary.bufferSupplier
FlowableBufferTimed.BufferExactBoundedSubscriber.bufferSupplier
FlowableBufferTimed.BufferExactUnboundedSubscriber.bufferSupplier
FlowableBufferTimed.BufferSkipBoundedSubscriber.bufferSupplier
FlowableBufferTimed.bufferSupplier
(package private) final Supplier
<? extends Collection<? super K>> FlowableDistinct.collectionSupplier
FlowableToList.collectionSupplier
FlowableToListSingle.collectionSupplier
private final Supplier
<? extends ConnectableFlowable<U>> FlowableReplay.MulticastFlowable.connectableFactory
(package private) static final Supplier
FlowableReplay.DEFAULT_UNBOUNDED_FACTORY
FlowableError.errorSupplier
FlowableCollect.initialSupplier
FlowableCollectSingle.initialSupplier
FlowableMapNotification.MapNotificationSubscriber.onCompleteSupplier
FlowableMapNotification.onCompleteSupplier
FlowableUsing.resourceSupplier
FlowableReduceWithSingle.seedSupplier
FlowableScanSeed.seedSupplier
FlowableGenerate.stateSupplier
FlowableDefer.supplier
FlowableFromSupplier.supplier
FlowableOnBackpressureReduceWith.BackpressureReduceWithSubscriber.supplier
FlowableOnBackpressureReduceWith.supplier
Methods in io.reactivex.rxjava3.internal.operators.flowable that return SupplierModifier and TypeMethodDescriptionstatic <T> Supplier
<ConnectableFlowable<T>> FlowableInternalHelper.replaySupplier
(Flowable<T> parent) static <T> Supplier
<ConnectableFlowable<T>> FlowableInternalHelper.replaySupplier
(Flowable<T> parent, int bufferSize, boolean eagerTruncate) static <T> Supplier
<ConnectableFlowable<T>> FlowableInternalHelper.replaySupplier
(Flowable<T> parent, int bufferSize, long time, TimeUnit unit, Scheduler scheduler, boolean eagerTruncate) static <T> Supplier
<ConnectableFlowable<T>> FlowableInternalHelper.replaySupplier
(Flowable<T> parent, long time, TimeUnit unit, Scheduler scheduler, boolean eagerTruncate) Methods in io.reactivex.rxjava3.internal.operators.flowable with parameters of type SupplierModifier and TypeMethodDescription(package private) static <T> ConnectableFlowable
<T> FlowableReplay.create
(Flowable<T> source, Supplier<? extends FlowableReplay.ReplayBuffer<T>> bufferFactory) Creates a OperatorReplay instance to replay values of the given sourceFlowable
.static <U,
R> Flowable <R> FlowableReplay.multicastSelector
(Supplier<? extends ConnectableFlowable<U>> connectableFactory, Function<? super Flowable<U>, ? extends org.reactivestreams.Publisher<R>> selector) Given a connectable observable factory, it multicasts over the generated ConnectableObservable via a selector function.Constructors in io.reactivex.rxjava3.internal.operators.flowable with parameters of type SupplierModifierConstructorDescription(package private)
BackpressureReduceWithSubscriber
(@NonNull org.reactivestreams.Subscriber<? super R> downstream, @NonNull Supplier<R> supplier, @NonNull BiFunction<R, ? super T, R> reducer) (package private)
BufferBoundarySubscriber
(org.reactivestreams.Subscriber<? super C> actual, org.reactivestreams.Publisher<? extends Open> bufferOpen, Function<? super Open, ? extends org.reactivestreams.Publisher<? extends Close>> bufferClose, Supplier<C> bufferSupplier) (package private)
BufferExactBoundarySubscriber
(org.reactivestreams.Subscriber<? super U> actual, Supplier<U> bufferSupplier, org.reactivestreams.Publisher<B> boundary) (package private)
BufferExactBoundedSubscriber
(org.reactivestreams.Subscriber<? super U> actual, Supplier<U> bufferSupplier, long timespan, TimeUnit unit, int maxSize, boolean restartOnMaxSize, Scheduler.Worker w) (package private)
BufferExactUnboundedSubscriber
(org.reactivestreams.Subscriber<? super U> actual, Supplier<U> bufferSupplier, long timespan, TimeUnit unit, Scheduler scheduler) (package private)
BufferSkipBoundedSubscriber
(org.reactivestreams.Subscriber<? super U> actual, Supplier<U> bufferSupplier, long timespan, long timeskip, TimeUnit unit, Scheduler.Worker w) FlowableBuffer
(Flowable<T> source, int size, int skip, Supplier<C> bufferSupplier) FlowableBufferBoundary
(Flowable<T> source, org.reactivestreams.Publisher<? extends Open> bufferOpen, Function<? super Open, ? extends org.reactivestreams.Publisher<? extends Close>> bufferClose, Supplier<U> bufferSupplier) FlowableBufferExactBoundary
(Flowable<T> source, org.reactivestreams.Publisher<B> boundary, Supplier<U> bufferSupplier) FlowableBufferTimed
(Flowable<T> source, long timespan, long timeskip, TimeUnit unit, Scheduler scheduler, Supplier<U> bufferSupplier, int maxSize, boolean restartTimerOnMaxSize) FlowableCollect
(Flowable<T> source, Supplier<? extends U> initialSupplier, BiConsumer<? super U, ? super T> collector) FlowableCollectSingle
(Flowable<T> source, Supplier<? extends U> initialSupplier, BiConsumer<? super U, ? super T> collector) FlowableDefer
(Supplier<? extends org.reactivestreams.Publisher<? extends T>> supplier) FlowableDistinct
(Flowable<T> source, Function<? super T, K> keySelector, Supplier<? extends Collection<? super K>> collectionSupplier) FlowableError
(Supplier<? extends Throwable> errorSupplier) FlowableFromSupplier
(Supplier<? extends T> supplier) FlowableGenerate
(Supplier<S> stateSupplier, BiFunction<S, Emitter<T>, S> generator, Consumer<? super S> disposeState) FlowableMapNotification
(Flowable<T> source, Function<? super T, ? extends R> onNextMapper, Function<? super Throwable, ? extends R> onErrorMapper, Supplier<? extends R> onCompleteSupplier) FlowableOnBackpressureReduceWith
(@NonNull Flowable<T> source, @NonNull Supplier<R> supplier, @NonNull BiFunction<R, ? super T, R> reducer) FlowableReduceWithSingle
(org.reactivestreams.Publisher<T> source, Supplier<R> seedSupplier, BiFunction<R, ? super T, R> reducer) private
FlowableReplay
(org.reactivestreams.Publisher<T> onSubscribe, Flowable<T> source, AtomicReference<FlowableReplay.ReplaySubscriber<T>> current, Supplier<? extends FlowableReplay.ReplayBuffer<T>> bufferFactory) FlowableScanSeed
(Flowable<T> source, Supplier<R> seedSupplier, BiFunction<R, ? super T, R> accumulator) FlowableToList
(Flowable<T> source, Supplier<U> collectionSupplier) FlowableToListSingle
(Flowable<T> source, Supplier<U> collectionSupplier) FlowableUsing
(Supplier<? extends D> resourceSupplier, Function<? super D, ? extends org.reactivestreams.Publisher<? extends T>> sourceSupplier, Consumer<? super D> disposer, boolean eager) (package private)
MapNotificationSubscriber
(org.reactivestreams.Subscriber<? super R> actual, Function<? super T, ? extends R> onNextMapper, Function<? super Throwable, ? extends R> onErrorMapper, Supplier<? extends R> onCompleteSupplier) (package private)
MulticastFlowable
(Supplier<? extends ConnectableFlowable<U>> connectableFactory, Function<? super Flowable<U>, ? extends org.reactivestreams.Publisher<R>> selector) (package private)
PublisherBufferExactSubscriber
(org.reactivestreams.Subscriber<? super C> actual, int size, Supplier<C> bufferSupplier) (package private)
PublisherBufferOverlappingSubscriber
(org.reactivestreams.Subscriber<? super C> actual, int size, int skip, Supplier<C> bufferSupplier) (package private)
PublisherBufferSkipSubscriber
(org.reactivestreams.Subscriber<? super C> actual, int size, int skip, Supplier<C> bufferSupplier) (package private)
ReplayPublisher
(AtomicReference<FlowableReplay.ReplaySubscriber<T>> curr, Supplier<? extends FlowableReplay.ReplayBuffer<T>> bufferFactory) -
Uses of Supplier in io.reactivex.rxjava3.internal.operators.maybe
Classes in io.reactivex.rxjava3.internal.operators.maybe that implement SupplierModifier and TypeClassDescriptionfinal class
Signals an onComplete.final class
Executes an Action and signals its exception or completes normally.final class
Executes a callable and signals its value as success or signals an exception.final class
Executes an Runnable and signals its exception or completes normally.final class
Executes a supplier and signals its value as success or signals an exception.final class
MaybeJust<T>
Signals a constant value.Fields in io.reactivex.rxjava3.internal.operators.maybe declared as SupplierModifier and TypeFieldDescriptionMaybeErrorCallable.errorSupplier
(package private) final Supplier
<? extends MaybeSource<? extends T>> MaybeDefer.maybeSupplier
(package private) final Supplier
<? extends MaybeSource<? extends R>> MaybeFlatMapNotification.FlatMapMaybeObserver.onCompleteSupplier
(package private) final Supplier
<? extends MaybeSource<? extends R>> MaybeFlatMapNotification.onCompleteSupplier
MaybeUsing.resourceSupplier
MaybeFromSupplier.supplier
Constructors in io.reactivex.rxjava3.internal.operators.maybe with parameters of type SupplierModifierConstructorDescription(package private)
FlatMapMaybeObserver
(MaybeObserver<? super R> actual, Function<? super T, ? extends MaybeSource<? extends R>> onSuccessMapper, Function<? super Throwable, ? extends MaybeSource<? extends R>> onErrorMapper, Supplier<? extends MaybeSource<? extends R>> onCompleteSupplier) MaybeDefer
(Supplier<? extends MaybeSource<? extends T>> maybeSupplier) MaybeErrorCallable
(Supplier<? extends Throwable> errorSupplier) MaybeFlatMapNotification
(MaybeSource<T> source, Function<? super T, ? extends MaybeSource<? extends R>> onSuccessMapper, Function<? super Throwable, ? extends MaybeSource<? extends R>> onErrorMapper, Supplier<? extends MaybeSource<? extends R>> onCompleteSupplier) MaybeFromSupplier
(Supplier<? extends T> supplier) MaybeUsing
(Supplier<? extends D> resourceSupplier, Function<? super D, ? extends MaybeSource<? extends T>> sourceSupplier, Consumer<? super D> resourceDisposer, boolean eager) -
Uses of Supplier in io.reactivex.rxjava3.internal.operators.observable
Classes in io.reactivex.rxjava3.internal.operators.observable that implement SupplierModifier and TypeClassDescriptionfinal class
final class
Executes anAction
and signals its exception or completes normally.final class
Calls a Callable and emits its resulting single value or signals its exception.final class
Executes anRunnable
and signals its exception or completes normally.final class
Calls a Supplier and emits its resulting single value or signals its exception.(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
final class
Represents a constant scalar value.Fields in io.reactivex.rxjava3.internal.operators.observable declared as SupplierModifier and TypeFieldDescriptionObservableBuffer.BufferExactObserver.bufferSupplier
ObservableBuffer.BufferSkipObserver.bufferSupplier
ObservableBuffer.bufferSupplier
ObservableBufferBoundary.BufferBoundaryObserver.bufferSupplier
ObservableBufferBoundary.bufferSupplier
ObservableBufferExactBoundary.BufferExactBoundaryObserver.bufferSupplier
ObservableBufferExactBoundary.bufferSupplier
ObservableBufferTimed.BufferExactBoundedObserver.bufferSupplier
ObservableBufferTimed.BufferExactUnboundedObserver.bufferSupplier
ObservableBufferTimed.BufferSkipBoundedObserver.bufferSupplier
ObservableBufferTimed.bufferSupplier
(package private) final Supplier
<? extends Collection<? super K>> ObservableDistinct.collectionSupplier
ObservableToList.collectionSupplier
ObservableToListSingle.collectionSupplier
private final Supplier
<? extends ConnectableObservable<U>> ObservableReplay.MulticastReplay.connectableFactory
ObservableError.errorSupplier
ObservableCollect.initialSupplier
ObservableCollectSingle.initialSupplier
(package private) final Supplier
<? extends ObservableSource<? extends R>> ObservableMapNotification.MapNotificationObserver.onCompleteSupplier
(package private) final Supplier
<? extends ObservableSource<? extends R>> ObservableMapNotification.onCompleteSupplier
ObservableUsing.resourceSupplier
ObservableReduceWithSingle.seedSupplier
ObservableScanSeed.seedSupplier
ObservableGenerate.stateSupplier
(package private) final Supplier
<? extends ObservableSource<? extends T>> ObservableDefer.supplier
ObservableFromSupplier.supplier
Methods in io.reactivex.rxjava3.internal.operators.observable that return SupplierModifier and TypeMethodDescriptionstatic <T> Supplier
<ConnectableObservable<T>> ObservableInternalHelper.replaySupplier
(Observable<T> parent) static <T> Supplier
<ConnectableObservable<T>> ObservableInternalHelper.replaySupplier
(Observable<T> parent, int bufferSize, boolean eagerTruncate) static <T> Supplier
<ConnectableObservable<T>> ObservableInternalHelper.replaySupplier
(Observable<T> parent, int bufferSize, long time, TimeUnit unit, Scheduler scheduler, boolean eagerTruncate) static <T> Supplier
<ConnectableObservable<T>> ObservableInternalHelper.replaySupplier
(Observable<T> parent, long time, TimeUnit unit, Scheduler scheduler, boolean eagerTruncate) Methods in io.reactivex.rxjava3.internal.operators.observable with parameters of type SupplierModifier and TypeMethodDescriptionstatic <U,
R> Observable <R> ObservableReplay.multicastSelector
(Supplier<? extends ConnectableObservable<U>> connectableFactory, Function<? super Observable<U>, ? extends ObservableSource<R>> selector) Given a connectable observable factory, it multicasts over the generated ConnectableObservable via a selector function.(package private) boolean
ObservableFlatMap.MergeObserver.tryEmitScalar
(Supplier<? extends U> value) Constructors in io.reactivex.rxjava3.internal.operators.observable with parameters of type SupplierModifierConstructorDescription(package private)
BufferBoundaryObserver
(Observer<? super C> actual, ObservableSource<? extends Open> bufferOpen, Function<? super Open, ? extends ObservableSource<? extends Close>> bufferClose, Supplier<C> bufferSupplier) (package private)
BufferExactBoundaryObserver
(Observer<? super U> actual, Supplier<U> bufferSupplier, ObservableSource<B> boundary) (package private)
BufferExactBoundedObserver
(Observer<? super U> actual, Supplier<U> bufferSupplier, long timespan, TimeUnit unit, int maxSize, boolean restartOnMaxSize, Scheduler.Worker w) (package private)
BufferExactObserver
(Observer<? super U> actual, int count, Supplier<U> bufferSupplier) (package private)
BufferExactUnboundedObserver
(Observer<? super U> actual, Supplier<U> bufferSupplier, long timespan, TimeUnit unit, Scheduler scheduler) (package private)
BufferSkipBoundedObserver
(Observer<? super U> actual, Supplier<U> bufferSupplier, long timespan, long timeskip, TimeUnit unit, Scheduler.Worker w) (package private)
BufferSkipObserver
(Observer<? super U> actual, int count, int skip, Supplier<U> bufferSupplier) (package private)
MapNotificationObserver
(Observer<? super ObservableSource<? extends R>> actual, Function<? super T, ? extends ObservableSource<? extends R>> onNextMapper, Function<? super Throwable, ? extends ObservableSource<? extends R>> onErrorMapper, Supplier<? extends ObservableSource<? extends R>> onCompleteSupplier) (package private)
MulticastReplay
(Supplier<? extends ConnectableObservable<U>> connectableFactory, Function<? super Observable<U>, ? extends ObservableSource<R>> selector) ObservableBuffer
(ObservableSource<T> source, int count, int skip, Supplier<U> bufferSupplier) ObservableBufferBoundary
(ObservableSource<T> source, ObservableSource<? extends Open> bufferOpen, Function<? super Open, ? extends ObservableSource<? extends Close>> bufferClose, Supplier<U> bufferSupplier) ObservableBufferExactBoundary
(ObservableSource<T> source, ObservableSource<B> boundary, Supplier<U> bufferSupplier) ObservableBufferTimed
(ObservableSource<T> source, long timespan, long timeskip, TimeUnit unit, Scheduler scheduler, Supplier<U> bufferSupplier, int maxSize, boolean restartTimerOnMaxSize) ObservableCollect
(ObservableSource<T> source, Supplier<? extends U> initialSupplier, BiConsumer<? super U, ? super T> collector) ObservableCollectSingle
(ObservableSource<T> source, Supplier<? extends U> initialSupplier, BiConsumer<? super U, ? super T> collector) ObservableDefer
(Supplier<? extends ObservableSource<? extends T>> supplier) ObservableDistinct
(ObservableSource<T> source, Function<? super T, K> keySelector, Supplier<? extends Collection<? super K>> collectionSupplier) ObservableError
(Supplier<? extends Throwable> errorSupplier) ObservableFromSupplier
(Supplier<? extends T> supplier) ObservableGenerate
(Supplier<S> stateSupplier, BiFunction<S, Emitter<T>, S> generator, Consumer<? super S> disposeState) ObservableMapNotification
(ObservableSource<T> source, Function<? super T, ? extends ObservableSource<? extends R>> onNextMapper, Function<? super Throwable, ? extends ObservableSource<? extends R>> onErrorMapper, Supplier<? extends ObservableSource<? extends R>> onCompleteSupplier) ObservableReduceWithSingle
(ObservableSource<T> source, Supplier<R> seedSupplier, BiFunction<R, ? super T, R> reducer) ObservableScanSeed
(ObservableSource<T> source, Supplier<R> seedSupplier, BiFunction<R, ? super T, R> accumulator) ObservableToList
(ObservableSource<T> source, Supplier<U> collectionSupplier) ObservableToListSingle
(ObservableSource<T> source, Supplier<U> collectionSupplier) ObservableUsing
(Supplier<? extends D> resourceSupplier, Function<? super D, ? extends ObservableSource<? extends T>> sourceSupplier, Consumer<? super D> disposer, boolean eager) -
Uses of Supplier in io.reactivex.rxjava3.internal.operators.parallel
Fields in io.reactivex.rxjava3.internal.operators.parallel declared as SupplierModifier and TypeFieldDescriptionParallelCollect.initialCollection
ParallelReduce.initialSupplier
Constructors in io.reactivex.rxjava3.internal.operators.parallel with parameters of type SupplierModifierConstructorDescriptionParallelCollect
(ParallelFlowable<? extends T> source, Supplier<? extends C> initialCollection, BiConsumer<? super C, ? super T> collector) ParallelReduce
(ParallelFlowable<? extends T> source, Supplier<R> initialSupplier, BiFunction<R, ? super T, R> reducer) -
Uses of Supplier in io.reactivex.rxjava3.internal.operators.single
Classes in io.reactivex.rxjava3.internal.operators.single that implement SupplierModifier and TypeClassDescription(package private) static enum
Fields in io.reactivex.rxjava3.internal.operators.single declared as SupplierModifier and TypeFieldDescriptionSingleError.errorSupplier
SingleUsing.resourceSupplier
(package private) final Supplier
<? extends SingleSource<? extends T>> SingleDefer.singleSupplier
SingleFromSupplier.supplier
Methods in io.reactivex.rxjava3.internal.operators.single that return SupplierModifier and TypeMethodDescriptionstatic Supplier
<NoSuchElementException> SingleInternalHelper.emptyThrower()
Constructors in io.reactivex.rxjava3.internal.operators.single with parameters of type SupplierModifierConstructorDescriptionSingleDefer
(Supplier<? extends SingleSource<? extends T>> singleSupplier) SingleError
(Supplier<? extends Throwable> errorSupplier) SingleFromSupplier
(Supplier<? extends T> supplier) SingleUsing
(Supplier<U> resourceSupplier, Function<? super U, ? extends SingleSource<? extends T>> singleFunction, Consumer<? super U> disposer, boolean eager) -
Uses of Supplier in io.reactivex.rxjava3.internal.util
Classes in io.reactivex.rxjava3.internal.util that implement SupplierMethods in io.reactivex.rxjava3.internal.util that return Supplier -
Uses of Supplier in io.reactivex.rxjava3.operators
Subinterfaces of Supplier in io.reactivex.rxjava3.operatorsModifier and TypeInterfaceDescriptioninterface
A marker interface indicating that a scalar, constant value is held by the implementing reactive type which can be safely extracted during assembly time can be used for optimization. -
Uses of Supplier in io.reactivex.rxjava3.parallel
Methods in io.reactivex.rxjava3.parallel with parameters of type SupplierModifier and TypeMethodDescriptionfinal <@NonNull C>
@NonNull ParallelFlowable<C> ParallelFlowable.collect
(@NonNull Supplier<? extends @NonNull C> collectionSupplier, @NonNull BiConsumer<? super @NonNull C, ? super @NonNull T> collector) Collect the elements in each rail into a collection supplied via acollectionSupplier
and collected into with a collector action, emitting the collection at the end.final <@NonNull R>
@NonNull ParallelFlowable<R> ParallelFlowable.reduce
(@NonNull Supplier<@NonNull R> initialSupplier, @NonNull BiFunction<@NonNull R, ? super @NonNull T, @NonNull R> reducer) Reduces all values within a 'rail' to a single value (with a possibly different type) via a reducer function that is initialized on each rail from aninitialSupplier
value. -
Uses of Supplier in io.reactivex.rxjava3.plugins
Fields in io.reactivex.rxjava3.plugins with type parameters of type SupplierModifier and TypeFieldDescriptionRxJavaPlugins.onInitComputationHandler
RxJavaPlugins.onInitIoHandler
RxJavaPlugins.onInitNewThreadHandler
RxJavaPlugins.onInitSingleHandler
Methods in io.reactivex.rxjava3.plugins that return types with arguments of type SupplierModifier and TypeMethodDescriptionRxJavaPlugins.getInitComputationSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitIoSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitNewThreadSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitSingleSchedulerHandler()
Returns the current hook function.Methods in io.reactivex.rxjava3.plugins with parameters of type SupplierModifier and TypeMethodDescriptionRxJavaPlugins.applyRequireNonNull
(@NonNull Function<? super Supplier<Scheduler>, ? extends Scheduler> f, Supplier<Scheduler> s) Wraps the call to the Scheduler creation function in try-catch and propagates thrown checked exceptions as RuntimeException and enforces that result is not null.RxJavaPlugins.callRequireNonNull
(@NonNull Supplier<Scheduler> s) Wraps the call to the Scheduler creation supplier in try-catch and propagates thrown checked exceptions as RuntimeException and enforces that result is not null.RxJavaPlugins.initComputationScheduler
(@NonNull Supplier<Scheduler> defaultScheduler) Calls the associated hook function.RxJavaPlugins.initIoScheduler
(@NonNull Supplier<Scheduler> defaultScheduler) Calls the associated hook function.RxJavaPlugins.initNewThreadScheduler
(@NonNull Supplier<Scheduler> defaultScheduler) Calls the associated hook function.RxJavaPlugins.initSingleScheduler
(@NonNull Supplier<Scheduler> defaultScheduler) Calls the associated hook function.Method parameters in io.reactivex.rxjava3.plugins with type arguments of type SupplierModifier and TypeMethodDescriptionRxJavaPlugins.applyRequireNonNull
(@NonNull Function<? super Supplier<Scheduler>, ? extends Scheduler> f, Supplier<Scheduler> s) Wraps the call to the Scheduler creation function in try-catch and propagates thrown checked exceptions as RuntimeException and enforces that result is not null.static void
RxJavaPlugins.setInitComputationSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitIoSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitNewThreadSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitSingleSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function. -
Uses of Supplier in io.reactivex.rxjava3.schedulers
Classes in io.reactivex.rxjava3.schedulers that implement SupplierModifier and TypeClassDescription(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class