- accept(T1, T2) - Method in interface io.reactivex.rxjava3.functions.BiConsumer
-
Performs an operation on the given values.
- accept(T) - Method in interface io.reactivex.rxjava3.functions.Consumer
-
Consume the given value.
- accept(long) - Method in interface io.reactivex.rxjava3.functions.LongConsumer
-
Consume a primitive long input.
- Action - Interface in io.reactivex.rxjava3.functions
-
A functional interface similar to Runnable but allows throwing a checked exception.
- add(Disposable) - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Adds a
Disposable to this container or disposes it if the
container has been disposed.
- add(Disposable) - Method in interface io.reactivex.rxjava3.disposables.DisposableContainer
-
Adds a disposable to this container or disposes it if the
container has been disposed.
- add(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
Adds a resource to this ResourceCompletableObserver.
- add(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
Adds a resource to this ResourceMaybeObserver.
- add(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceObserver
-
Adds a resource to this ResourceObserver.
- add(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
Adds a resource to this ResourceSingleObserver.
- add(Disposable) - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
Adds a resource to this ResourceSubscriber.
- addAll(Disposable...) - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Atomically adds the given array of
Disposables to the container or
disposes them all if the container has been disposed.
- advanceTimeBy(long, TimeUnit) - Method in class io.reactivex.rxjava3.schedulers.TestScheduler
-
Moves the Scheduler's clock forward by a specified amount of time.
- advanceTimeTo(long, TimeUnit) - Method in class io.reactivex.rxjava3.schedulers.TestScheduler
-
Moves the Scheduler's clock to a particular moment in time.
- all(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean that indicates whether all of the items emitted by the current
Flowable satisfy a condition.
- all(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean that indicates whether all of the items emitted by the current
Observable satisfy a condition.
- amb(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which terminates as soon as one of the source
Completables in the
Iterable sequence
terminates (normally or with an error) and disposes all other
Completables.
- amb(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Mirrors the one
Publisher in an
Iterable of several
Publishers that first either emits an item or sends
a termination notification.
- amb(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Runs multiple
MaybeSources provided by an
Iterable sequence and
signals the events of the first one that signals (disposing the rest).
- amb(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Mirrors the one
ObservableSource in an
Iterable of several
ObservableSources that first either emits an item or sends
a termination notification.
- amb(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Runs multiple
SingleSources and signals the events of the first one that signals (disposing
the rest).
- ambArray(CompletableSource...) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which terminates as soon as one of the source Completables
terminates (normally or with an error) and disposes all other Completables.
- ambArray(Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Mirrors the one
Publisher in an array of several
Publishers that first either emits an item or sends
a termination notification.
- ambArray(MaybeSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Runs multiple
MaybeSources and signals the events of the first one that signals (disposing
the rest).
- ambArray(ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Mirrors the one
ObservableSource in an array of several
ObservableSources that first either emits an item or sends
a termination notification.
- ambArray(SingleSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Single
-
Runs multiple
SingleSources and signals the events of the first one that signals (disposing
the rest).
- ambWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that emits the a terminated event of either this
Completable
or the other
CompletableSource, whichever fires first.
- ambWith(Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Mirrors the
Publisher (current or provided) that first either emits an item or sends a termination
notification.
- ambWith(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Mirrors the
MaybeSource (current or provided) that first signals an event.
- ambWith(ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Mirrors the current
Observable or the other
ObservableSource provided of which the first either emits an item or sends a termination
notification.
- ambWith(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Signals the event of this or the other
SingleSource whichever signals first.
- andThen(ObservableSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns an
Observable which will subscribe to this
Completable and once that is completed then
will subscribe to the
next ObservableSource.
- andThen(Publisher<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Flowable which will subscribe to this
Completable and once that is completed then
will subscribe to the
next Publisher.
- andThen(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Single which will subscribe to this
Completable and once that is completed then
will subscribe to the
next SingleSource.
- andThen(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Maybe which will subscribe to this
Completable and once that is completed then
will subscribe to the
next MaybeSource.
- andThen(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that first runs this
Completable
and then the other
CompletableSource.
- any(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits
true if any item emitted by the current
Flowable satisfies a
specified condition, otherwise
false.
- any(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits
true if any item emitted by the current
Observable satisfies a
specified condition, otherwise
false.
- apply(Completable) - Method in interface io.reactivex.rxjava3.core.CompletableConverter
-
Applies a function to the upstream Completable and returns a converted value of type R.
- apply(CompletableObserver) - Method in interface io.reactivex.rxjava3.core.CompletableOperator
-
Applies a function to the child
CompletableObserver and returns a new parent
CompletableObserver.
- apply(Completable) - Method in interface io.reactivex.rxjava3.core.CompletableTransformer
-
- apply(Flowable<T>) - Method in interface io.reactivex.rxjava3.core.FlowableConverter
-
Applies a function to the upstream
Flowable and returns a converted value of type
R.
- apply(Subscriber<? super Downstream>) - Method in interface io.reactivex.rxjava3.core.FlowableOperator
-
Applies a function to the child
Subscriber and returns a new parent
Subscriber.
- apply(Flowable<Upstream>) - Method in interface io.reactivex.rxjava3.core.FlowableTransformer
-
Applies a function to the upstream
Flowable and returns a
Publisher with
optionally different element type.
- apply(Maybe<T>) - Method in interface io.reactivex.rxjava3.core.MaybeConverter
-
Applies a function to the upstream
Maybe and returns a converted value of type
R.
- apply(MaybeObserver<? super Downstream>) - Method in interface io.reactivex.rxjava3.core.MaybeOperator
-
Applies a function to the child
MaybeObserver and returns a new parent
MaybeObserver.
- apply(Maybe<Upstream>) - Method in interface io.reactivex.rxjava3.core.MaybeTransformer
-
Applies a function to the upstream
Maybe and returns a
MaybeSource with
optionally different element type.
- apply(Observable<T>) - Method in interface io.reactivex.rxjava3.core.ObservableConverter
-
Applies a function to the upstream
Observable and returns a converted value of type
R.
- apply(Observer<? super Downstream>) - Method in interface io.reactivex.rxjava3.core.ObservableOperator
-
Applies a function to the child
Observer and returns a new parent
Observer.
- apply(Observable<Upstream>) - Method in interface io.reactivex.rxjava3.core.ObservableTransformer
-
- apply(Single<T>) - Method in interface io.reactivex.rxjava3.core.SingleConverter
-
Applies a function to the upstream
Single and returns a converted value of type
R.
- apply(SingleObserver<? super Downstream>) - Method in interface io.reactivex.rxjava3.core.SingleOperator
-
Applies a function to the child
SingleObserver and returns a new parent
SingleObserver.
- apply(Single<Upstream>) - Method in interface io.reactivex.rxjava3.core.SingleTransformer
-
Applies a function to the upstream
Single and returns a
SingleSource with
optionally different element type.
- apply(T1, T2) - Method in interface io.reactivex.rxjava3.functions.BiFunction
-
Calculate a value based on the input values.
- apply(T) - Method in interface io.reactivex.rxjava3.functions.Function
-
Apply some calculation to the input value and return some other value.
- apply(T1, T2, T3) - Method in interface io.reactivex.rxjava3.functions.Function3
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4) - Method in interface io.reactivex.rxjava3.functions.Function4
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4, T5) - Method in interface io.reactivex.rxjava3.functions.Function5
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4, T5, T6) - Method in interface io.reactivex.rxjava3.functions.Function6
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4, T5, T6, T7) - Method in interface io.reactivex.rxjava3.functions.Function7
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface io.reactivex.rxjava3.functions.Function8
-
Calculate a value based on the input values.
- apply(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface io.reactivex.rxjava3.functions.Function9
-
Calculate a value based on the input values.
- apply(int) - Method in interface io.reactivex.rxjava3.functions.IntFunction
-
Calculates a value based on a primitive integer input.
- apply(Long, Throwable) - Method in enum io.reactivex.rxjava3.parallel.ParallelFailureHandling
-
- apply(ParallelFlowable<T>) - Method in interface io.reactivex.rxjava3.parallel.ParallelFlowableConverter
-
Applies a function to the upstream ParallelFlowable and returns a converted value of type R.
- apply(ParallelFlowable<Upstream>) - Method in interface io.reactivex.rxjava3.parallel.ParallelTransformer
-
Applies a function to the upstream ParallelFlowable and returns a ParallelFlowable with
optionally different element type.
- assertComplete() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber received exactly one onComplete event.
- assertEmpty() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the
TestObserver/
TestSubscriber has received a
Disposable/
Subscription
via
onSubscribe but no other events.
- assertError(Throwable) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber received exactly the specified onError event value.
- assertError(Class<? extends Throwable>) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Asserts that this
TestObserver/
TestSubscriber received exactly one
onError event which is an
instance of the specified
errorClass Class.
- assertError(Predicate<Throwable>) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Asserts that this TestObserver/TestSubscriber received exactly one onError event for which
the provided predicate returns true.
- assertFailure(Class<? extends Throwable>, T...) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the upstream signaled the specified values in order
and then failed with a specific class or subclass of
Throwable.
- assertNoErrors() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber has not received an onError event.
- assertNotComplete() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber has not received an onComplete event.
- assertNoValues() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber has not received any onNext events.
- assertResult(T...) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the upstream signaled the specified values in order and
completed normally.
- assertSubscribed() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the onSubscribe method was called exactly once.
- assertSubscribed() - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- assertSubscribed() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- assertValue(T) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this
TestObserver/
TestSubscriber received exactly one
onNext value which is equal to
the given value with respect to
Objects.equals(Object, Object).
- assertValue(Predicate<T>) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Asserts that this TestObserver/TestSubscriber received exactly one onNext value for which
the provided predicate returns true.
- assertValueAt(int, T) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Asserts that this
TestObserver/
TestSubscriber received an
onNext value at the given index
which is equal to the given value with respect to
null-safe
Objects.equals(Object, Object).
- assertValueAt(int, Predicate<T>) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Asserts that this TestObserver/TestSubscriber received an onNext value at the given index
for the provided predicate returns true.
- assertValueCount(int) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that this TestObserver/TestSubscriber received the specified number onNext events.
- assertValues(T...) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the TestObserver/TestSubscriber received only the specified values in the specified order.
- assertValueSequence(Iterable<? extends T>) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the TestObserver/TestSubscriber received only the specified sequence of values in the same order.
- assertValuesOnly(T...) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Assert that the TestObserver/TestSubscriber received only the specified values in the specified order without terminating.
- AsyncProcessor<T> - Class in io.reactivex.rxjava3.processors
-
Processor that emits the very last value followed by a completion event or the received error
to
Subscribers.
- AsyncSubject<T> - Class in io.reactivex.rxjava3.subjects
-
A Subject that emits the very last value followed by a completion event or the received error to Observers.
- autoConnect() - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable
when the first Subscriber subscribes.
- autoConnect(int) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable
when the specified number of Subscribers subscribe to it.
- autoConnect(int, Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Returns a Flowable that automatically connects (at most once) to this ConnectableFlowable
when the specified number of Subscribers subscribe to it and calls the
specified callback with the Subscription associated with the established connection.
- autoConnect() - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Returns an Observable that automatically connects (at most once) to this ConnectableObservable
when the first Observer subscribes.
- autoConnect(int) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Returns an Observable that automatically connects (at most once) to this ConnectableObservable
when the specified number of Observers subscribe to it.
- autoConnect(int, Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Returns an Observable that automatically connects (at most once) to this ConnectableObservable
when the specified number of Subscribers subscribe to it and calls the
specified callback with the Subscription associated with the established connection.
- await() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Awaits until this TestObserver/TestSubscriber receives an onError or onComplete events.
- await(long, TimeUnit) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Awaits the specified amount of time or until this TestObserver/TestSubscriber
receives an onError or onComplete events, whichever happens first.
- awaitCount(int) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Await until the TestObserver/TestSubscriber receives the given
number of items or terminates by sleeping 10 milliseconds at a time
up to 5000 milliseconds of timeout.
- awaitDone(long, TimeUnit) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Awaits until the internal latch is counted down.
- BackpressureKind - Enum in io.reactivex.rxjava3.annotations
-
Enumeration for various kinds of backpressure support.
- BackpressureOverflowStrategy - Enum in io.reactivex.rxjava3.core
-
Options to deal with buffer overflow when using onBackpressureBuffer.
- BackpressureStrategy - Enum in io.reactivex.rxjava3.core
-
Represents the options for applying backpressure to a source sequence.
- BackpressureSupport - Annotation Type in io.reactivex.rxjava3.annotations
-
Indicates the backpressure support kind of the associated operator or class.
- BaseTestConsumer<T,U extends BaseTestConsumer<T,U>> - Class in io.reactivex.rxjava3.observers
-
- BaseTestConsumer() - Constructor for class io.reactivex.rxjava3.observers.BaseTestConsumer
-
- BehaviorProcessor<T> - Class in io.reactivex.rxjava3.processors
-
Processor that emits the most recent item it has observed and all subsequent observed items to each subscribed
Subscriber.
- BehaviorSubject<T> - Class in io.reactivex.rxjava3.subjects
-
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribed
Observer.
- Beta - Annotation Type in io.reactivex.rxjava3.annotations
-
Indicates the feature is in beta state: it will be most likely stay but
the signature may change between versions without warning.
- BiConsumer<T1,T2> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that accepts two values (of possibly different types).
- BiFunction<T1,T2,R> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that computes a value based on multiple input values.
- BiPredicate<T1,T2> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that returns true or false for the given input values.
- blockingAwait() - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to and awaits the termination of this Completable instance in a blocking manner and
rethrows any exception emitted.
- blockingAwait(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to and awaits the termination of this Completable instance in a blocking manner
with a specific timeout and rethrows any exception emitted within the timeout window.
- blockingFirst() - Method in class io.reactivex.rxjava3.core.Flowable
-
- blockingFirst(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns the first item emitted by this Flowable, or a default value if it emits no
items.
- blockingFirst() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns the first item emitted by the current
Observable, or throws
NoSuchElementException if it emits no items.
- blockingFirst(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns the first item emitted by the current Observable, or a default value if it emits no
items.
- blockingForEach(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Consumes the current
Flowable in a blocking fashion and invokes the given
Consumer with each upstream item on the
current thread until the
upstream terminates.
- blockingForEach(Consumer<? super T>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Consumes the current
Flowable in a blocking fashion and invokes the given
Consumer with each upstream item on the
current thread until the
upstream terminates.
- blockingForEach(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Consumes the current
Observable in a blocking fashion and invokes the given
Consumer with each upstream item on the
current thread until the
upstream terminates.
- blockingForEach(Consumer<? super T>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Consumes the current
Observable in a blocking fashion and invokes the given
Consumer with each upstream item on the
current thread until the
upstream terminates.
- blockingGet() - Method in class io.reactivex.rxjava3.core.Maybe
-
Waits in a blocking fashion until the current Maybe signals a success value (which is returned),
null if completed or an exception (which is propagated).
- blockingGet(T) - Method in class io.reactivex.rxjava3.core.Maybe
-
Waits in a blocking fashion until the current Maybe signals a success value (which is returned),
defaultValue if completed or an exception (which is propagated).
- blockingGet() - Method in class io.reactivex.rxjava3.core.Single
-
Waits in a blocking fashion until the current Single signals a success value (which is returned) or
an exception (which is propagated).
- blockingIterable() - Method in class io.reactivex.rxjava3.core.Flowable
-
Converts this
Flowable into an
Iterable.
- blockingIterable(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Converts this
Flowable into an
Iterable.
- blockingIterable() - Method in class io.reactivex.rxjava3.core.Observable
-
Exposes the current
Observable as an
Iterable which, when iterated,
subscribes to the current
Observable and blocks
until the current
Observable emits items or terminates.
- blockingIterable(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Exposes the current
Observable as an
Iterable which, when iterated,
subscribes to the current
Observable and blocks
until the current
Observable emits items or terminates.
- blockingLast() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns the last item emitted by this
Flowable, or throws
NoSuchElementException if this
Flowable emits no items.
- blockingLast(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns the last item emitted by this Flowable, or a default value if it emits no
items.
- blockingLast() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns the last item emitted by the current
Observable, or throws
NoSuchElementException if the current
Observable emits no items.
- blockingLast(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns the last item emitted by the current Observable, or a default value if it emits no
items.
- blockingLatest() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns an
Iterable that returns the latest item emitted by this
Flowable,
waiting if necessary for one to become available.
- blockingLatest() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Iterable that returns the latest item emitted by the current
Observable,
waiting if necessary for one to become available.
- blockingMostRecent(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns an
Iterable that always returns the item most recently emitted by this
Flowable.
- blockingMostRecent(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Iterable that always returns the item most recently emitted by the current
Observable.
- blockingNext() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns an
Iterable that blocks until this
Flowable emits another item, then
returns that item.
- blockingNext() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Iterable that blocks until the current
Observable emits another item, then
returns that item.
- blockingSingle() - Method in class io.reactivex.rxjava3.core.Flowable
-
If this
Flowable completes after emitting a single item, return that item, otherwise
throw a
NoSuchElementException.
- blockingSingle(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
If this
Flowable completes after emitting a single item, return that item; if it emits
more than one item, throw an
IllegalArgumentException; if it emits no items, return a default
value.
- blockingSingle() - Method in class io.reactivex.rxjava3.core.Observable
-
If the current
Observable completes after emitting a single item, return that item, otherwise
throw a
NoSuchElementException.
- blockingSingle(T) - Method in class io.reactivex.rxjava3.core.Observable
-
If the current
Observable completes after emitting a single item, return that item; if it emits
more than one item, throw an
IllegalArgumentException; if it emits no items, return a default
value.
- blockingStream() - Method in class io.reactivex.rxjava3.core.Flowable
-
Creates a sequential
Stream to consume or process this
Flowable in a blocking manner via
the Java
Stream API.
- blockingStream(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Creates a sequential
Stream to consume or process this
Flowable in a blocking manner via
the Java
Stream API.
- blockingStream() - Method in class io.reactivex.rxjava3.core.Observable
-
Creates a sequential
Stream to consume or process the current
Observable in a blocking manner via
the Java
Stream API.
- blockingStream(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Creates a sequential
Stream to consume or process the current
Observable in a blocking manner via
the Java
Stream API.
- blockingSubscribe() - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to the current Completable and blocks the current thread until it terminates.
- blockingSubscribe(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to the current Completable and calls given onComplete callback on the current thread
when it completes normally.
- blockingSubscribe(Action, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to the current Completable and calls the appropriate callback on the current thread
when it terminates.
- blockingSubscribe(CompletableObserver) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to the current
Completable and calls the appropriate
CompletableObserver method on the
current thread.
- blockingSubscribe() - Method in class io.reactivex.rxjava3.core.Flowable
-
Runs the current Flowable to a terminal event, ignoring any values and rethrowing any exception.
- blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the source and calls the
Subscriber methods
on the current thread.
- blockingSubscribe() - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to the current Maybe and blocks the current thread until it terminates.
- blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to the current Maybe and calls given onSuccess callback on the current thread
when it completes normally.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to the current Maybe and calls the appropriate callback on the current thread
when it terminates.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to the current Maybe and calls the appropriate callback on the current thread
when it terminates.
- blockingSubscribe(MaybeObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to the current
Maybe and calls the appropriate
MaybeObserver method on the
current thread.
- blockingSubscribe() - Method in class io.reactivex.rxjava3.core.Observable
-
Runs the current Observable to a terminal event, ignoring any values and rethrowing any exception.
- blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the source and calls the given callbacks on the current thread.
- blockingSubscribe(Observer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the source and calls the
Observer methods
on the current thread.
- blockingSubscribe() - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to the current Single and blocks the current thread until it terminates.
- blockingSubscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to the current Single and calls given onSuccess callback on the current thread
when it completes normally.
- blockingSubscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to the current Single and calls the appropriate callback on the current thread
when it terminates.
- blockingSubscribe(SingleObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to the current
Single and calls the appropriate
SingleObserver method on the
current thread.
- BooleanSupplier - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that returns a boolean value.
- buffer(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(int, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(int, int, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(int, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, long, TimeUnit, Scheduler, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, TimeUnit, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, TimeUnit, Scheduler, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, TimeUnit, Scheduler, int, Supplier<U>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(Publisher<? extends TOpening>, Function<? super TOpening, ? extends Publisher<? extends TClosing>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(Publisher<? extends TOpening>, Function<? super TOpening, ? extends Publisher<? extends TClosing>>, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits buffers of items it collects from the current Flowable.
- buffer(Publisher<B>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits non-overlapping buffered items from the current
Flowable each time the
specified boundary
Publisher emits an item.
- buffer(Publisher<B>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits non-overlapping buffered items from the current
Flowable each time the
specified boundary
Publisher emits an item.
- buffer(Publisher<B>, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits non-overlapping buffered items from the current
Flowable each time the
specified boundary
Publisher emits an item.
- buffer(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(int, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(int, int, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(int, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, long, TimeUnit, Scheduler, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, TimeUnit, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, TimeUnit, Scheduler, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, TimeUnit, Scheduler, int, Supplier<U>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(ObservableSource<? extends TOpening>, Function<? super TOpening, ? extends ObservableSource<? extends TClosing>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(ObservableSource<? extends TOpening>, Function<? super TOpening, ? extends ObservableSource<? extends TClosing>>, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits buffers of items it collects from the current Observable.
- buffer(ObservableSource<B>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits non-overlapping buffered items from the current
Observable each time the
specified boundary
ObservableSource emits an item.
- buffer(ObservableSource<B>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits non-overlapping buffered items from the current
Observable each time the
specified boundary
ObservableSource emits an item.
- buffer(ObservableSource<B>, Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits non-overlapping buffered items from the current
Observable each time the
specified boundary
ObservableSource emits an item.
- bufferSize() - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns the default internal buffer size used by most async operators.
- bufferSize() - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns the default 'island' size or capacity-increment hint for unbounded buffers.
- cache() - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to this
Completable only once, when the first
CompletableObserver
subscribes to the result
Completable, caches its terminal event
and relays/replays it to observers.
- cache() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that subscribes to this
Publisher lazily, caches all of its events
and replays them, in the same order as received, to all the downstream subscribers.
- cache() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that subscribes to this Maybe lazily, caches its event
and replays it, to all the downstream subscribers.
- cache() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that subscribes to the current Observable lazily, caches all of its events
and replays them, in the same order as received, to all the downstream observers.
- cache() - Method in class io.reactivex.rxjava3.core.Single
-
Stores the success value or exception from the current
Single and replays it to late
SingleObservers.
- cacheWithInitialCapacity(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that subscribes to this
Publisher lazily, caches all of its events
and replays them, in the same order as received, to all the downstream subscribers.
- cacheWithInitialCapacity(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that subscribes to the current Observable lazily, caches all of its events
and replays them, in the same order as received, to all the downstream observers.
- cancel() - Method in interface io.reactivex.rxjava3.functions.Cancellable
-
Cancel the action or free a resource.
- cancel() - Method in class io.reactivex.rxjava3.observers.DefaultObserver
-
Cancels the upstream's disposable.
- cancel() - Method in class io.reactivex.rxjava3.subscribers.DefaultSubscriber
-
- cancel() - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- cancel() - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- cancel() - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- cancel() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- Cancellable - Interface in io.reactivex.rxjava3.functions
-
A functional interface that has a single cancel method
that can throw.
- cast(Class<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable, converted to the specified
type.
- cast(Class<? extends U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Casts the success value of the current
Maybe into the target type or signals a
ClassCastException if not compatible.
- cast(Class<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable, converted to the specified
type.
- cast(Class<? extends U>) - Method in class io.reactivex.rxjava3.core.Single
-
Casts the success value of the current
Single into the target type or signals a
ClassCastException if not compatible.
- CheckReturnValue - Annotation Type in io.reactivex.rxjava3.annotations
-
Marks methods whose return values should be checked.
- checkSubscriptionOnce - Variable in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
- cleanupBuffer() - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Makes sure the item cached by the head node in a bounded
ReplayProcessor is released (as it is never part of a replay).
- cleanupBuffer() - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Makes sure the item cached by the head node in a bounded
ReplaySubject is released (as it is never part of a replay).
- clear() - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Atomically clears the container, then disposes all the previously contained
Disposables.
- clockDriftTolerance() - Static method in class io.reactivex.rxjava3.core.Scheduler
-
Returns the clock drift tolerance in nanoseconds.
- collect(Supplier<? extends U>, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Collects items emitted by the finite source
Publisher into a single mutable data structure and returns
a
Single that emits this structure.
- collect(Collector<T, A, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Collects the finite upstream's values into a container via a
Stream Collector callback set and emits
it as the success result.
- collect(Supplier<? extends U>, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Collects items emitted by the finite source
Observable into a single mutable data structure and returns
a
Single that emits this structure.
- collect(Collector<T, A, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Collects the finite upstream's values into a container via a
Stream Collector callback set and emits
it as the success result as a
Single.
- collect(Supplier<? extends C>, BiConsumer<? super C, ? super T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Collect the elements in each rail into a collection supplied via a collectionSupplier
and collected into with a collector action, emitting the collection at the end.
- collect(Collector<T, A, R>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Reduces all values within a 'rail' and across 'rails' with a callbacks
of the given
Collector into one
Flowable containing a single value.
- collectInto(U, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Collects items emitted by the finite source
Publisher into a single mutable data structure and returns
a
Single that emits this structure.
- collectInto(U, BiConsumer<? super U, ? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Collects items emitted by the finite source
Observable into a single mutable data structure and returns
a
Single that emits this structure.
- combineLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines two source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from either of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines three source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines four source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines five source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines six source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines seven source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines eight source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Publisher<? extends T1>, Publisher<? extends T2>, Publisher<? extends T3>, Publisher<? extends T4>, Publisher<? extends T5>, Publisher<? extends T6>, Publisher<? extends T7>, Publisher<? extends T8>, Publisher<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines nine source
Publishers by emitting an item that aggregates the latest values of each of the
source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatest(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines a collection of source
ObservableSources by emitting an item that aggregates the latest values of each of
the returned
ObservableSources each time an item is received from any of the returned
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an
Iterable of source
ObservableSources by emitting an item that aggregates the latest values of each of
the returned
ObservableSources each time an item is received from any of the returned
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, BiFunction<? super T1, ? super T2, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines two source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from either of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, Function3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines three source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, Function4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines four source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, Function5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines five source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, Function6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines six source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, Function7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines seven source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, Function8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines eight source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatest(ObservableSource<? extends T1>, ObservableSource<? extends T2>, ObservableSource<? extends T3>, ObservableSource<? extends T4>, ObservableSource<? extends T5>, ObservableSource<? extends T6>, ObservableSource<? extends T7>, ObservableSource<? extends T8>, ObservableSource<? extends T9>, Function9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines nine source
ObservableSources by emitting an item that aggregates the latest values of each of the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatestArray(Publisher<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatestArray(Publisher<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatestArray(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an array of source
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the returned
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatestArray(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an array of source
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatestArrayDelayError(Publisher<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function.
- combineLatestArrayDelayError(Publisher<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
Publishers terminate.
- combineLatestArrayDelayError(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an array of
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function.
- combineLatestArrayDelayError(ObservableSource<? extends T>[], Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an array of
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
ObservableSources terminate.
- combineLatestDelayError(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
Publishers terminate.
- combineLatestDelayError(Iterable<? extends Publisher<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Combines a collection of source
Publishers by emitting an item that aggregates the latest values of each of
the source
Publishers each time an item is received from any of the source
Publishers, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
Publishers terminate.
- combineLatestDelayError(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an
Iterable of
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
ObservableSources terminate.
- combineLatestDelayError(Iterable<? extends ObservableSource<? extends T>>, Function<? super Object[], ? extends R>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Combines an
Iterable of
ObservableSources by emitting an item that aggregates the latest values of each of
the
ObservableSources each time an item is received from any of the
ObservableSources, where this
aggregation is defined by a specified function and delays any error from the sources until
all source
ObservableSources terminate.
- Completable - Class in io.reactivex.rxjava3.core
-
The Completable class represents a deferred computation without any value but
only indication for completion or exception.
- Completable() - Constructor for class io.reactivex.rxjava3.core.Completable
-
- CompletableConverter<R> - Interface in io.reactivex.rxjava3.core
-
- CompletableEmitter - Interface in io.reactivex.rxjava3.core
-
- CompletableObserver - Interface in io.reactivex.rxjava3.core
-
Provides a mechanism for receiving push-based notification of a valueless completion or an error.
- CompletableOnSubscribe - Interface in io.reactivex.rxjava3.core
-
A functional interface that has a
subscribe() method that receives
an instance of a
CompletableEmitter instance that allows pushing
an event in a cancellation-safe manner.
- CompletableOperator - Interface in io.reactivex.rxjava3.core
-
Interface to map/wrap a downstream observer to an upstream observer.
- CompletableSource - Interface in io.reactivex.rxjava3.core
-
- CompletableSubject - Class in io.reactivex.rxjava3.subjects
-
Represents a hot Completable-like source and consumer of events similar to Subjects.
- CompletableTransformer - Interface in io.reactivex.rxjava3.core
-
Convenience interface and callback used by the compose operator to turn a
Completable into another
Completable fluently.
- complete() - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable instance that completes immediately when subscribed to.
- completions - Variable in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
The number of completions.
- compose(CompletableTransformer) - Method in class io.reactivex.rxjava3.core.Completable
-
- compose(FlowableTransformer<? super T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
- compose(MaybeTransformer<? super T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- compose(ObservableTransformer<? super T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Observable
-
- compose(SingleTransformer<? super T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Single
-
- compose(ParallelTransformer<T, U>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Allows composing operators, in assembly time, on top of this ParallelFlowable
and returns another ParallelFlowable with composed features.
- CompositeDisposable - Class in io.reactivex.rxjava3.disposables
-
- CompositeDisposable() - Constructor for class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Creates an empty CompositeDisposable.
- CompositeDisposable(Disposable...) - Constructor for class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Creates a
CompositeDisposable with the given array of initial
Disposable elements.
- CompositeDisposable(Iterable<? extends Disposable>) - Constructor for class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Creates a
CompositeDisposable with the given
Iterable sequence of initial
Disposable elements.
- CompositeException - Exception in io.reactivex.rxjava3.exceptions
-
Represents an exception that is a composite of one or more other exceptions.
- CompositeException(Throwable...) - Constructor for exception io.reactivex.rxjava3.exceptions.CompositeException
-
Constructs a CompositeException with the given array of Throwables as the
list of suppressed exceptions.
- CompositeException(Iterable<? extends Throwable>) - Constructor for exception io.reactivex.rxjava3.exceptions.CompositeException
-
Constructs a CompositeException with the given array of Throwables as the
list of suppressed exceptions.
- COMPUTATION - Static variable in annotation type io.reactivex.rxjava3.annotations.SchedulerSupport
-
- computation() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
Returns a default, shared
Scheduler instance intended for computational work.
- concat(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Publisher<? extends CompletableSource>, int) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates elements of each
Publisher provided via an
Iterable sequence into a single sequence
of elements without interleaving them.
- concat(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by each of the
Publishers emitted by the source
Publisher, one after the other, without interleaving them.
- concat(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by each of the
Publishers emitted by the source
Publisher, one after the other, without interleaving them.
- concat(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by two
Publishers, one after the other, without
interleaving them.
- concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by three
Publishers, one after the other, without
interleaving them.
- concat(Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by four
Publishers, one after the other, without
interleaving them.
- concat(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenate the single values, in a non-overlapping fashion, of the
MaybeSource sources provided by
an
Iterable sequence as a
Flowable sequence.
- concat(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concat(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concat(MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concat(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenate the single values, in a non-overlapping fashion, of the
MaybeSource sources provided by
a
Publisher sequence as a
Flowable sequence.
- concat(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenate the single values, in a non-overlapping fashion, of the
MaybeSource sources provided by
a
Publisher sequence as a
Flowable sequence.
- concat(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates elements of each
ObservableSource provided via an
Iterable sequence into a single sequence
of elements without interleaving them.
- concat(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by each of the
ObservableSources emitted by the
ObservableSource, one after the other, without interleaving them.
- concat(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by each of the
ObservableSources emitted by the outer
ObservableSource, one after the other, without interleaving them.
- concat(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by two
ObservableSources, one after the other, without
interleaving them.
- concat(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by three
ObservableSources, one after the other, without
interleaving them.
- concat(ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by four
ObservableSources, one after the other, without
interleaving them.
- concat(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenate the single values, in a non-overlapping fashion, of the
SingleSources provided by
an
Iterable sequence.
- concat(ObservableSource<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concat(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenate the single values, in a non-overlapping fashion, of the
SingleSources provided by
a
Publisher sequence.
- concat(Publisher<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenate the single values, in a non-overlapping fashion, of the
SingleSources provided by
a
Publisher sequence and prefetched by the specified amount.
- concat(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concat(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concat(SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concatArray(CompletableSource...) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concatArray(Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a variable number of
Publisher sources.
- concatArray(MaybeSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenate the single values, in a non-overlapping fashion, of the
MaybeSource sources in the array
as a
Flowable sequence.
- concatArray(ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
- concatArray(SingleSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenate the single values, in a non-overlapping fashion, of the
SingleSources provided in
an array.
- concatArrayDelayError(CompletableSource...) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concatArrayDelayError(Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a variable number of
Publisher sources and delays errors from any of them
till all terminate.
- concatArrayDelayError(MaybeSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a variable number of
MaybeSource sources and delays errors from any of them
till all terminate as a
Flowable sequence.
- concatArrayDelayError(ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates a variable number of
ObservableSource sources and delays errors from any of them
till all terminate.
- concatArrayDelayError(SingleSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenate the single values, in a non-overlapping fashion, of the
SingleSources provided in
an array.
- concatArrayEager(Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates an array of
Publishers eagerly into a single stream of values.
- concatArrayEager(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates an array of
Publishers eagerly into a single stream of values.
- concatArrayEager(MaybeSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concatArrayEager(ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an array of
ObservableSources eagerly into a single stream of values.
- concatArrayEager(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an array of
ObservableSources eagerly into a single stream of values.
- concatArrayEager(SingleSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates a sequence of
SingleSource eagerly into a single stream of values.
- concatArrayEagerDelayError(Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates an array of
Publishers eagerly into a single stream of values
and delaying any errors until all sources terminate.
- concatArrayEagerDelayError(int, int, Publisher<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates an array of
Publishers eagerly into a single stream of values
and delaying any errors until all sources terminate.
- concatArrayEagerDelayError(MaybeSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concatArrayEagerDelayError(ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an array of
ObservableSources eagerly into a single stream of values
and delaying any errors until all sources terminate.
- concatArrayEagerDelayError(int, int, ObservableSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an array of
ObservableSources eagerly into a single stream of values
and delaying any errors until all sources terminate.
- concatArrayEagerDelayError(SingleSource<? extends T>...) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates a sequence of
SingleSource eagerly into a single stream of values.
- concatDelayError(Iterable<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concatDelayError(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concatDelayError(Publisher<? extends CompletableSource>, int) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concatDelayError(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates the
Iterable sequence of
Publishers into a single sequence by subscribing to each
Publisher,
one after the other, one at a time and delays any errors till the all inner
Publishers terminate.
- concatDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates the
Publisher sequence of
Publishers into a single sequence by subscribing to each inner
Publisher,
one after the other, one at a time and delays any errors till the all inner and the outer
Publishers terminate.
- concatDelayError(Publisher<? extends Publisher<? extends T>>, int, boolean) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates the
Publisher sequence of
Publishers into a single sequence by subscribing to each inner
Publisher,
one after the other, one at a time and delays any errors till the all inner and the outer
Publishers terminate.
- concatDelayError(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates the
Iterable sequence of
MaybeSources into a single sequence by subscribing to each
MaybeSource,
one after the other, one at a time and delays any errors till the all inner
MaybeSources terminate
as a
Flowable sequence.
- concatDelayError(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates the
Publisher sequence of
MaybeSources into a single sequence by subscribing to each inner
MaybeSource,
one after the other, one at a time and delays any errors till the all inner and the outer
Publisher terminate
as a
Flowable sequence.
- concatDelayError(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates the
Publisher sequence of
MaybeSources into a single sequence by subscribing to each inner
MaybeSource,
one after the other, one at a time and delays any errors till the all inner and the outer
Publisher terminate
as a
Flowable sequence.
- concatDelayError(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates the
Iterable sequence of
ObservableSources into a single
Observable sequence
by subscribing to each
ObservableSource, one after the other, one at a time and delays any errors till
the all inner
ObservableSources terminate.
- concatDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates the
ObservableSource sequence of
ObservableSources into a single
Observable sequence
by subscribing to each inner
ObservableSource, one after the other, one at a time and delays any errors till the
all inner and the outer
ObservableSources terminate.
- concatDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int, boolean) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates the
ObservableSource sequence of
ObservableSources into a single sequence by subscribing to each inner
ObservableSource,
one after the other, one at a time and delays any errors till the all inner and the outer
ObservableSources terminate.
- concatDelayError(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates the
Iterable sequence of
SingleSources into a single sequence by subscribing to each
SingleSource,
one after the other, one at a time and delays any errors till the all inner
SingleSources terminate
as a
Flowable sequence.
- concatDelayError(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates the
Publisher sequence of
SingleSources into a single sequence by subscribing to each inner
SingleSource,
one after the other, one at a time and delays any errors till the all inner and the outer
Publisher terminate
as a
Flowable sequence.
- concatDelayError(Publisher<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates the
Publisher sequence of
SingleSources into a single sequence by subscribing to each inner
SingleSource,
one after the other, one at a time and delays any errors till the all inner and the outer
Publisher terminate
as a
Flowable sequence.
- concatEager(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a sequence of
Publishers eagerly into a single stream of values.
- concatEager(Iterable<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a sequence of
Publishers eagerly into a single stream of values and
runs a limited number of inner sequences at once.
- concatEager(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a
Publisher sequence of
Publishers eagerly into a single stream of values.
- concatEager(Publisher<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a
Publisher sequence of
Publishers eagerly into a single stream of values and
runs a limited number of inner sequences at once.
- concatEager(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concatEager(Iterable<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a sequence of
MaybeSources eagerly into a
Flowable sequence and
runs a limited number of the inner sequences at once.
- concatEager(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- concatEager(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a
Publisher sequence of
MaybeSources eagerly into a
Flowable sequence,
running at most the given number of inner
MaybeSources at once.
- concatEager(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates a sequence of
ObservableSources eagerly into a single stream of values.
- concatEager(Iterable<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates a sequence of
ObservableSources eagerly into a single stream of values and
runs a limited number of inner sequences at once.
- concatEager(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an
ObservableSource sequence of
ObservableSources eagerly into a single stream of values.
- concatEager(ObservableSource<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an
ObservableSource sequence of
ObservableSources eagerly into a single stream of values
and runs a limited number of inner sequences at once.
- concatEager(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concatEager(Iterable<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates an
Iterable sequence of
SingleSources eagerly into a single stream of values and
runs a limited number of the inner sources at once.
- concatEager(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
- concatEager(Publisher<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates a
Publisher sequence of
SingleSources eagerly into a single stream of values and
runs a limited number of those inner
SingleSources at once.
- concatEagerDelayError(Iterable<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a sequence of
Publishers eagerly into a single stream of values,
delaying errors until all the inner sequences terminate.
- concatEagerDelayError(Iterable<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a sequence of
Publishers eagerly into a single stream of values,
delaying errors until all the inner sequences terminate and runs a limited number
of inner sequences at once.
- concatEagerDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a
Publisher sequence of
Publishers eagerly into a single stream of values,
delaying errors until all the inner and the outer sequences terminate.
- concatEagerDelayError(Publisher<? extends Publisher<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Concatenates a
Publisher sequence of
Publishers eagerly into a single stream of values,
delaying errors until all the inner and outer sequences terminate and runs a limited number of inner
sequences at once.
- concatEagerDelayError(Iterable<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a sequence of
MaybeSources eagerly into a
Flowable sequence,
delaying errors until all inner
MaybeSources terminate.
- concatEagerDelayError(Iterable<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a sequence of
MaybeSources eagerly into a
Flowable sequence,
delaying errors until all inner
MaybeSources terminate and
runs a limited number of inner
MaybeSources at once.
- concatEagerDelayError(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a
Publisher sequence of
MaybeSources eagerly into a
Flowable sequence,
delaying errors until all the inner and the outer sequence terminate.
- concatEagerDelayError(Publisher<? extends MaybeSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Concatenates a
Publisher sequence of
MaybeSources eagerly into a
Flowable sequence,
delaying errors until all the inner and the outer sequence terminate and
runs a limited number of the inner
MaybeSources at once.
- concatEagerDelayError(Iterable<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates a sequence of
ObservableSources eagerly into a single stream of values,
delaying errors until all the inner sequences terminate.
- concatEagerDelayError(Iterable<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates a sequence of
ObservableSources eagerly into a single stream of values,
delaying errors until all the inner sequences terminate and runs a limited number of inner
sequences at once.
- concatEagerDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an
ObservableSource sequence of
ObservableSources eagerly into a single stream of values,
delaying errors until all the inner and the outer sequence terminate.
- concatEagerDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Concatenates an
ObservableSource sequence of
ObservableSources eagerly into a single stream of values,
delaying errors until all the inner and the outer sequence terminate and runs a limited number of inner sequences at once.
- concatEagerDelayError(Iterable<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates an
Iterable sequence of
SingleSources eagerly into a single stream of values,
delaying errors until all the inner sources terminate.
- concatEagerDelayError(Iterable<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates an
Iterable sequence of
SingleSources eagerly into a single stream of values,
delaying errors until all the inner sources terminate.
- concatEagerDelayError(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates a
Publisher sequence of
SingleSources eagerly into a single stream of values,
delaying errors until all the inner and the outer sequence terminate.
- concatEagerDelayError(Publisher<? extends SingleSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Single
-
Concatenates a
Publisher sequence of
SingleSources eagerly into a single stream of values,
running at most the specified number of those inner
SingleSources at once and
delaying errors until all the inner and the outer sequence terminate.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable that emits items resulting from applying a function that you supply to each item
emitted by the current
Flowable, where that function returns a
Publisher, and then emitting the items
that result from concatenating those returned
Publishers.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable that emits items resulting from applying a function that you supply to each item
emitted by the current
Flowable, where that function returns a
Publisher, and then emitting the items
that result from concatenating those returned
Publishers.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>, int, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable that emits items resulting from applying a function (on a designated scheduler)
that you supply to each item emitted by the current
Flowable, where that function returns a
Publisher, and then emitting the items
that result from concatenating those returned
Publishers.
- concatMap(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that is based on applying a specified function to the item emitted by the current
Maybe,
where that function returns a
MaybeSource.
- concatMap(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable that emits items resulting from applying a function that you supply to each item
emitted by the current
Observable, where that function returns an
ObservableSource, and then emitting the items
that result from concatenating those returned
ObservableSources.
- concatMap(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable that emits items resulting from applying a function that you supply to each item
emitted by the current
Observable, where that function returns an
ObservableSource, and then emitting the items
that result from concatenating those returned
ObservableSources.
- concatMap(Function<? super T, ? extends ObservableSource<? extends R>>, int, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable that emits items resulting from applying a function that you supply to each item
emitted by the current
Observable, where that function returns an
ObservableSource, and then emitting the items
that result from concatenating those returned
ObservableSources.
- concatMap(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Single that is based on applying a specified function to the item emitted by the current
Single,
where that function returns a
SingleSource.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Generates and concatenates
Publishers on each 'rail', signalling errors immediately
and generating 2 publishers upfront.
- concatMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Generates and concatenates
Publishers on each 'rail', signalling errors immediately
and using the given prefetch amount for generating
Publishers upfront.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other completes.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other completes.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Completable that completes based on applying a specified function to the item emitted by the
current
Maybe, where that function returns a
Completable.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each element of the current
Observable into
CompletableSources, subscribes to them one at a time in
order and waits until the upstream and all
CompletableSources complete.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each element of the current
Observable into
CompletableSources, subscribes to them one at a time in
order and waits until the upstream and all
CompletableSources complete.
- concatMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Completable that completes based on applying a specified function to the item emitted by the
current
Single, where that function returns a
CompletableSource.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, delaying all errors till both this
Flowable and all
inner
CompletableSources terminate.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, optionally delaying all errors till both this
Flowable and all
inner
CompletableSources terminate.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, optionally delaying all errors till both this
Flowable and all
inner
CompletableSources terminate.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, delaying all errors till both the current
Observable and all
inner
CompletableSources terminate.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, optionally delaying all errors till both the current
Observable and all
inner
CompletableSources terminate.
- concatMapCompletableDelayError(Function<? super T, ? extends CompletableSource>, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
CompletableSources and subscribes to them one after the
other terminates, optionally delaying all errors till both the current
Observable and all
inner
CompletableSources terminate.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps each of the items into a
Publisher, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner
Publishers
till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps each of the items into a
Publisher, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner
Publishers
till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps each of the upstream items into a
Publisher, subscribes to them one after the other,
one at a time and emits their values in order
while executing the mapper function on the designated scheduler, delaying any error from either this or any of the
inner
Publishers till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each of the items into an
ObservableSource, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner
ObservableSources
till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each of the items into an
ObservableSource, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner
ObservableSources
till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, boolean, int, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each of the items into an
ObservableSource, subscribes to them one after the other,
one at a time and emits their values in order
while delaying any error from either this or any of the inner
ObservableSources
till all of them terminate.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Generates and concatenates
Publishers on each 'rail', optionally delaying errors
and generating 2 publishers upfront.
- concatMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, int, boolean) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Generates and concatenates
Publishers on each 'rail', optionally delaying errors
and using the given prefetch amount for generating
Publishers upfront.
- concatMapEager(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps a sequence of values into
Publishers and concatenates these
Publishers eagerly into a single
Publisher.
- concatMapEager(Function<? super T, ? extends Publisher<? extends R>>, int, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps a sequence of values into
Publishers and concatenates these
Publishers eagerly into a single
Publisher.
- concatMapEager(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps a sequence of values into
ObservableSources and concatenates these
ObservableSources eagerly into a single
Observable sequence.
- concatMapEager(Function<? super T, ? extends ObservableSource<? extends R>>, int, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps a sequence of values into
ObservableSources and concatenates these
ObservableSources eagerly into a single
Observable sequence.
- concatMapEagerDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps a sequence of values into
Publishers and concatenates these
Publishers eagerly into a single
Publisher.
- concatMapEagerDelayError(Function<? super T, ? extends Publisher<? extends R>>, boolean, int, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps a sequence of values into
Publishers and concatenates these
Publishers eagerly into a single
Flowable sequence.
- concatMapEagerDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps a sequence of values into
ObservableSources and concatenates these
ObservableSources eagerly into a single
Observable sequence.
- concatMapEagerDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, boolean, int, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps a sequence of values into
ObservableSources and concatenates these
ObservableSources eagerly into a single
Observable sequence.
- concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that concatenate each item emitted by the current
Flowable with the values in an
Iterable corresponding to that item that is generated by a selector.
- concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that concatenate each item emitted by the current
Flowable with the values in an
Iterable corresponding to that item that is generated by a selector.
- concatMapIterable(Function<? super T, ? extends Iterable<? extends U>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that concatenate each item emitted by the current
Observable with the values in an
Iterable corresponding to that item that is generated by a selector.
- concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either this
Flowable or the current inner
MaybeSource fail.
- concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either this
Flowable or the current inner
MaybeSource fail.
- concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either the current
Observable or the current inner
MaybeSource fail.
- concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other succeeds or completes, emits their success value if available or terminates immediately if
either the current
Observable or the current inner
MaybeSource fail.
- concatMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Maybe that is based on applying a specified function to the item emitted by the current
Single,
where that function returns a
MaybeSource.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and delaying all errors
till both this
Flowable and all inner
MaybeSources terminate.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both this
Flowable and all inner
MaybeSources terminate.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both this
Flowable and all inner
MaybeSources terminate.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and delaying all errors
till both the current
Observable and all inner
MaybeSources terminate.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both the current
Observable and all inner
MaybeSources terminate.
- concatMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and subscribes to them one after the
other terminates, emits their success value if available and optionally delaying all errors
till both the current
Observable and all inner
MaybeSources terminate.
- concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either this
Flowable or the current inner
SingleSource fail.
- concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either this
Flowable or the current inner
SingleSource fail.
- concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe based on applying a specified function to the item emitted by the
current
Maybe, where that function returns a
Single.
- concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either the current
Observable or the current inner
SingleSource fail.
- concatMapSingle(Function<? super T, ? extends SingleSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds, emits their success values or terminates immediately if
either the current
Observable or the current inner
SingleSource fail.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and delays all errors
till both this
Flowable and all inner
SingleSources terminate.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays all errors
till both this
Flowable and all inner
SingleSources terminate.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays errors
till both this
Flowable and all inner
SingleSources terminate.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and delays all errors
till both the current
Observable and all inner
SingleSources terminate.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays all errors
till both the current
Observable and all inner
SingleSources terminate.
- concatMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
SingleSources and subscribes to them one after the
other succeeds or fails, emits their success values and optionally delays errors
till both the current
Observable and all inner
SingleSources terminate.
- concatMapStream(Function<? super T, ? extends Stream<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps each upstream item into a
Stream and emits the
Stream's items to the downstream in a sequential fashion.
- concatMapStream(Function<? super T, ? extends Stream<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps each upstream item into a
Stream and emits the
Stream's items to the downstream in a sequential fashion.
- concatMapStream(Function<? super T, ? extends Stream<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps each upstream item into a
Stream and emits the
Stream's items to the downstream in a sequential fashion.
- concatWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
- concatWith(Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted from the current Flowable, then the next, one after
the other, without interleaving them.
- concatWith(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items from this
Flowable followed by the success item or error event
of the other
SingleSource.
- concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items from this
Flowable followed by the success item or terminal events
of the other
MaybeSource.
- concatWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits items from this
Flowable and when it completes normally, the
other
CompletableSource is subscribed to and the returned
Flowable emits its terminal events.
- concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable that emits the items emitted from the current
Maybe, then the
other MaybeSource, one after
the other, without interleaving them.
- concatWith(ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that first emits the items emitted from the current
Observable, then items
from the
other ObservableSource without interleaving them.
- concatWith(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items from the current
Observable followed by the success item or error event
of the
other SingleSource.
- concatWith(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items from the current
Observable followed by the success item or terminal events
of the other
MaybeSource.
- concatWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits items from the current
Observable and when it completes normally, the
other
CompletableSource is subscribed to and the returned
Observable emits its terminal events.
- concatWith(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Flowable that emits the item emitted by the current
Single, then the item emitted by the
specified
SingleSource.
- connect(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Instructs the
ConnectableFlowable to begin emitting the items from its underlying
Flowable to its
Subscribers.
- connect() - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Instructs the
ConnectableFlowable to begin emitting the items from its underlying
Flowable to its
Subscribers.
- connect(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Instructs the
ConnectableObservable to begin emitting the items from its underlying
Observable to its
Observers.
- connect() - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Instructs the
ConnectableObservable to begin emitting the items from its underlying
Observable to its
Observers.
- ConnectableFlowable<T> - Class in io.reactivex.rxjava3.flowables
-
- ConnectableFlowable() - Constructor for class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
- ConnectableObservable<T> - Class in io.reactivex.rxjava3.observables
-
- ConnectableObservable() - Constructor for class io.reactivex.rxjava3.observables.ConnectableObservable
-
- Consumer<T> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that accepts a single value.
- contains(Object) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean that indicates whether the current
Flowable emitted a
specified item.
- contains(Object) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits a
Boolean that indicates whether the current
Maybe emitted a
specified item.
- contains(Object) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean that indicates whether the current
Observable emitted a
specified item.
- contains(Object) - Method in class io.reactivex.rxjava3.core.Single
-
Signals
true if the current
Single signals a success value that is
Object.equals(Object) with the value
provided.
- contains(Object, BiPredicate<Object, Object>) - Method in class io.reactivex.rxjava3.core.Single
-
Signals
true if the current
Single signals a success value that is equal with
the value provided by calling a
BiPredicate.
- count() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that counts the total number of items emitted by the current
Flowable and emits
this count as a 64-bit
Long.
- count() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that counts the total number of items emitted (0 or 1) by the current
Maybe and emits
this count as a 64-bit
Long.
- count() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that counts the total number of items emitted by the current
Observable and emits
this count as a 64-bit
Long.
- create(CompletableOnSubscribe) - Static method in class io.reactivex.rxjava3.core.Completable
-
Provides an API (via a cold Completable) that bridges the reactive world with the callback-style world.
- create(FlowableOnSubscribe<T>, BackpressureStrategy) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Provides an API (via a cold Flowable) that bridges the reactive world with the callback-style,
generally non-backpressured world.
- create(MaybeOnSubscribe<T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Provides an API (via a cold Maybe) that bridges the reactive world with the callback-style world.
- create(ObservableOnSubscribe<T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Provides an API (via a cold Observable) that bridges the reactive world with the callback-style world.
- create(SingleOnSubscribe<T>) - Static method in class io.reactivex.rxjava3.core.Single
-
Provides an API (via a cold Single) that bridges the reactive world with the callback-style world.
- create() - Static method in class io.reactivex.rxjava3.observers.TestObserver
-
Constructs a non-forwarding TestObserver.
- create(Observer<? super T>) - Static method in class io.reactivex.rxjava3.observers.TestObserver
-
Constructs a forwarding TestObserver.
- create() - Static method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
Creates a new AsyncProcessor.
- create() - Static method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- create() - Static method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Constructs a fresh instance with the default Flowable.bufferSize() prefetch
amount and no refCount-behavior.
- create(boolean) - Static method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Constructs a fresh instance with the default Flowable.bufferSize() prefetch
amount and the optional refCount-behavior.
- create(int) - Static method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Constructs a fresh instance with the given prefetch amount and no refCount behavior.
- create(int, boolean) - Static method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Constructs a fresh instance with the given prefetch amount and the optional
refCount-behavior.
- create() - Static method in class io.reactivex.rxjava3.processors.PublishProcessor
-
Constructs a PublishProcessor.
- create() - Static method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Creates an unbounded ReplayProcessor.
- create(int) - Static method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Creates an unbounded ReplayProcessor with the specified initial buffer capacity.
- create() - Static method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
Creates an UnicastSubject with an internal buffer capacity hint 16.
- create(int) - Static method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
Creates an UnicastProcessor with the given internal buffer capacity hint.
- create(boolean) - Static method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
Creates an UnicastProcessor with default internal buffer capacity hint and delay error flag.
- create(int, Runnable) - Static method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
Creates an UnicastProcessor with the given internal buffer capacity hint and a callback for
the case when the single Subscriber cancels its subscription or the
processor is terminated.
- create(int, Runnable, boolean) - Static method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
Creates an UnicastProcessor with the given internal buffer capacity hint, delay error flag and a callback for
the case when the single Subscriber cancels its subscription or
the processor is terminated.
- create() - Static method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
Creates a new AsyncProcessor.
- create() - Static method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- create() - Static method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
Creates a fresh CompletableSubject.
- create() - Static method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
Creates a fresh MaybeSubject.
- create() - Static method in class io.reactivex.rxjava3.subjects.PublishSubject
-
Constructs a PublishSubject.
- create() - Static method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Creates an unbounded replay subject.
- create(int) - Static method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Creates an unbounded replay subject with the specified initial buffer capacity.
- create() - Static method in class io.reactivex.rxjava3.subjects.SingleSubject
-
Creates a fresh SingleSubject.
- create() - Static method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
Creates an UnicastSubject with an internal buffer capacity hint 16.
- create(int) - Static method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
Creates an UnicastSubject with the given internal buffer capacity hint.
- create(int, Runnable) - Static method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
Creates an UnicastSubject with the given internal buffer capacity hint and a callback for
the case when the single Subscriber cancels its subscription
or the subject is terminated.
- create(int, Runnable, boolean) - Static method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
Creates an UnicastSubject with the given internal buffer capacity hint, delay error flag and
a callback for the case when the single Observer disposes its
Disposable
or the subject is terminated.
- create(boolean) - Static method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
Creates an UnicastSubject with an internal buffer capacity hint 16 and given delay error flag.
- create() - Static method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- create(long) - Static method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Creates a TestSubscriber with the given initial request amount.
- create(Subscriber<? super T>) - Static method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Constructs a forwarding TestSubscriber.
- createComputationScheduler(ThreadFactory) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
- createDefault(T) - Static method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- createDefault(T) - Static method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
Creates a
BehaviorSubject that emits the last item it observed and all subsequent items to each
Observer that subscribes to it.
- createIoScheduler(ThreadFactory) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
- createNewThreadScheduler(ThreadFactory) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
- createOnComplete() - Static method in class io.reactivex.rxjava3.core.Notification
-
Returns the empty and stateless shared instance of a notification representing
an onComplete signal.
- createOnError(Throwable) - Static method in class io.reactivex.rxjava3.core.Notification
-
Constructs an onError notification containing the error.
- createOnNext(T) - Static method in class io.reactivex.rxjava3.core.Notification
-
Constructs an onNext notification containing the given value.
- createSingleScheduler(ThreadFactory) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
- createWithSize(int) - Static method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Creates a size-bounded ReplayProcessor.
- createWithSize(int) - Static method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Creates a size-bounded replay subject.
- createWithTime(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Creates a time-bounded ReplayProcessor.
- createWithTime(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Creates a time-bounded replay subject.
- createWithTimeAndSize(long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Creates a time- and size-bounded ReplayProcessor.
- createWithTimeAndSize(long, TimeUnit, Scheduler, int) - Static method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Creates a time- and size-bounded replay subject.
- createWorker() - Method in class io.reactivex.rxjava3.core.Scheduler
-
Retrieves or creates a new
Scheduler.Worker that represents sequential execution of actions.
- createWorker() - Method in class io.reactivex.rxjava3.schedulers.TestScheduler
-
- CUSTOM - Static variable in annotation type io.reactivex.rxjava3.annotations.SchedulerSupport
-
A special value indicating the operator/class requires a scheduler to be manually specified.
- debounce(Function<? super T, ? extends Publisher<U>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, except that it drops items emitted by the
current Flowable that are followed by another item within a computed debounce duration.
- debounce(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, except that it drops items emitted by the
current Flowable that are followed by newer items before a timeout value expires.
- debounce(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, except that it drops items emitted by the
current
Flowable that are followed by newer items before a timeout value expires on a specified
Scheduler.
- debounce(Function<? super T, ? extends ObservableSource<U>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, except that it drops items emitted by the
current
Observable that are followed by another item within a computed debounce duration
denoted by an item emission or completion from a generated inner
ObservableSource for that original item.
- debounce(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable, except that it drops items emitted by the
current Observable that are followed by newer items before a timeout value expires.
- debounce(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, except that it drops items emitted by the
current
Observable that are followed by newer items before a timeout value expires on a specified
Scheduler.
- defaultIfEmpty(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable or a specified default item
if the current Flowable is empty.
- defaultIfEmpty(T) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits the item emitted by the current
Maybe or a specified default item
if the current
Maybe is empty.
- defaultIfEmpty(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable or a specified default item
if the current Observable is empty.
- DefaultObserver<T> - Class in io.reactivex.rxjava3.observers
-
- DefaultObserver() - Constructor for class io.reactivex.rxjava3.observers.DefaultObserver
-
- DefaultSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
- DefaultSubscriber() - Constructor for class io.reactivex.rxjava3.subscribers.DefaultSubscriber
-
- defer(Supplier<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Defers the subscription to a Completable instance returned by a supplier.
- defer(Supplier<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that calls a
Publisher factory to create a
Publisher for each new
Subscriber
that subscribes.
- defer(Supplier<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
- defer(Supplier<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that calls an
ObservableSource factory to create an
ObservableSource for each new
Observer
that subscribes.
- defer(Supplier<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
- delay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable which delays the emission of the completion event by the given time.
- delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which delays the emission of the completion event by the given time while
running on the specified
Scheduler.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Completable
-
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.
- delay(Function<? super T, ? extends Publisher<U>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that delays the emissions of the current
Flowable via another
Publisher on a
per-item basis.
- delay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items emitted by the current Flowable shifted forward in time by a
specified delay.
- delay(Publisher<U>, Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that delays the subscription to and emissions from the current
Flowable via another
Publisher on a per-item basis.
- delay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that signals the events emitted by the current Maybe shifted forward in time by a
specified delay.
- delay(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that signals the events emitted by the current Maybe shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that signals the events emitted by the current Maybe shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that signals the events emitted by the current
Maybe shifted forward in time by a
specified delay running on the specified
Scheduler.
- delay(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Delays the emission of this
Maybe until the given
Publisher signals an item or completes.
- delay(Function<? super T, ? extends ObservableSource<U>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that delays the emissions of the current
Observable via
a per-item derived
ObservableSource's item emission or termination, on a per source item basis.
- delay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable shifted forward in time by a
specified delay.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items emitted by the current Observable shifted forward in time by a
specified delay.
- delay(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that delays the subscription to and emissions from the current
Observable via
ObservableSources for the subscription itself and on a per-item basis.
- delay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the emission of the success signal from the current Single by the specified amount.
- delay(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the emission of the success or error signal from the current Single by the specified amount.
- delay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the emission of the success signal from the current Single by the specified amount.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the emission of the success or error signal from the current Single by the specified amount.
- delaySubscription(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that delays the subscription to the upstream by a given amount of time.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that delays the subscription to the upstream by a given amount of time,
both waiting and subscribing on a given
Scheduler.
- delaySubscription(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that delays the subscription to this
Publisher
until the other
Publisher emits an element or completes normally.
- delaySubscription(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that delays the subscription to the current Flowable by a given amount of time.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that delays the subscription to the current
Flowable by a given amount of time,
both waiting and subscribing on a given
Scheduler.
- delaySubscription(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that delays the subscription to this
Maybe
until the other
Publisher emits an element or completes normally.
- delaySubscription(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that delays the subscription to the current Maybe by a given amount of time.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that delays the subscription to the current
Maybe by a given amount of time,
both waiting and subscribing on a given
Scheduler.
- delaySubscription(ObservableSource<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that delays the subscription to the current
Observable
until the other
ObservableSource emits an element or completes normally.
- delaySubscription(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that delays the subscription to the current Observable by a given amount of time.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that delays the subscription to the current
Observable by a given amount of time,
both waiting and subscribing on a given
Scheduler.
- delaySubscription(CompletableSource) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current
Single until the given other
CompletableSource
completes.
- delaySubscription(SingleSource<U>) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current
Single until the given other
SingleSource
signals success.
- delaySubscription(ObservableSource<U>) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current
Single until the given other
ObservableSource
signals its first value or completes.
- delaySubscription(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current
Single until the given other
Publisher
signals its first value or completes.
- delaySubscription(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current Single until the given time delay elapsed.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Delays the actual subscription to the current Single until the given time delay elapsed.
- delete(Disposable) - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Removes (but does not dispose) the given
Disposable if it is part of this
container.
- delete(Disposable) - Method in interface io.reactivex.rxjava3.disposables.DisposableContainer
-
Removes but does not dispose the given disposable if it is part of this
container.
- dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that reverses the effect of
materialize by transforming the
Notification objects extracted from the source items via a selector function
into their respective
Subscriber signal types.
- dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Maps the
Notification success value of the current
Maybe back into normal
onSuccess,
onError or
onComplete signals.
- dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that reverses the effect of
materialize by transforming the
Notification objects extracted from the source items via a selector function
into their respective
Observer signal types.
- dematerialize(Function<? super T, Notification<R>>) - Method in class io.reactivex.rxjava3.core.Single
-
Maps the
Notification success value of the current
Single back into normal
onSuccess,
onError or
onComplete signals as a
Maybe source.
- Disposable - Interface in io.reactivex.rxjava3.disposables
-
Represents a disposable resource.
- DisposableCompletableObserver - Class in io.reactivex.rxjava3.observers
-
An abstract
CompletableObserver that allows asynchronous cancellation by implementing Disposable.
- DisposableCompletableObserver() - Constructor for class io.reactivex.rxjava3.observers.DisposableCompletableObserver
-
- DisposableContainer - Interface in io.reactivex.rxjava3.disposables
-
Common interface to add and remove disposables from a container.
- DisposableMaybeObserver<T> - Class in io.reactivex.rxjava3.observers
-
- DisposableMaybeObserver() - Constructor for class io.reactivex.rxjava3.observers.DisposableMaybeObserver
-
- DisposableObserver<T> - Class in io.reactivex.rxjava3.observers
-
- DisposableObserver() - Constructor for class io.reactivex.rxjava3.observers.DisposableObserver
-
- DisposableSingleObserver<T> - Class in io.reactivex.rxjava3.observers
-
- DisposableSingleObserver() - Constructor for class io.reactivex.rxjava3.observers.DisposableSingleObserver
-
- DisposableSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
An abstract Subscriber that allows asynchronous, external cancellation by implementing
Disposable.
- DisposableSubscriber() - Constructor for class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- dispose() - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
- dispose() - Method in interface io.reactivex.rxjava3.disposables.Disposable
-
Dispose the resource, the operation should be idempotent.
- dispose() - Method in class io.reactivex.rxjava3.disposables.SerialDisposable
-
- dispose() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Cancel/dispose this test consumer.
- dispose() - Method in class io.reactivex.rxjava3.observers.DisposableCompletableObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.DisposableMaybeObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.DisposableObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.DisposableSingleObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
Cancels the main disposable (if any) and disposes the resources associated with
this ResourceCompletableObserver (if any).
- dispose() - Method in class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
Cancels the main disposable (if any) and disposes the resources associated with
this ResourceMaybeObserver (if any).
- dispose() - Method in class io.reactivex.rxjava3.observers.ResourceObserver
-
Cancels the main disposable (if any) and disposes the resources associated with
this ResourceObserver (if any).
- dispose() - Method in class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
Cancels the main disposable (if any) and disposes the resources associated with
this ResourceSingleObserver (if any).
- dispose() - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- dispose() - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- dispose() - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- dispose() - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
Cancels the subscription (if any) and disposes the resources associated with
this ResourceSubscriber (if any).
- dispose() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- disposed() - Static method in interface io.reactivex.rxjava3.disposables.Disposable
-
Returns a shared, disposed Disposable instance.
- distinct() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits all items emitted by the current
Flowable that are distinct
based on
Object.equals(Object) comparison.
- distinct(Function<? super T, K>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits all items emitted by the current
Flowable that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function.
- distinct(Function<? super T, K>, Supplier<? extends Collection<? super K>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits all items emitted by the current
Flowable that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function.
- distinct() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits all items emitted by the current
Observable that are distinct
based on
Object.equals(Object) comparison.
- distinct(Function<? super T, K>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits all items emitted by the current
Observable that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function.
- distinct(Function<? super T, K>, Supplier<? extends Collection<? super K>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits all items emitted by the current
Observable that are distinct according
to a key selector function and based on
Object.equals(Object) comparison of the objects
returned by the key selector function.
- distinctUntilChanged() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits all items emitted by the current
Flowable that are distinct from their
immediate predecessors based on
Object.equals(Object) comparison.
- distinctUntilChanged(Function<? super T, K>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits all items emitted by the current
Flowable that are distinct from their
immediate predecessors, according to a key selector function and based on
Object.equals(Object) comparison
of those objects returned by the key selector function.
- distinctUntilChanged(BiPredicate<? super T, ? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits all items emitted by the current Flowable that are distinct from their
immediate predecessors when compared with each other via the provided comparator function.
- distinctUntilChanged() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits all items emitted by the current
Observable that are distinct from their
immediate predecessors based on
Object.equals(Object) comparison.
- distinctUntilChanged(Function<? super T, K>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits all items emitted by the current
Observable that are distinct from their
immediate predecessors, according to a key selector function and based on
Object.equals(Object) comparison
of those objects returned by the key selector function.
- distinctUntilChanged(BiPredicate<? super T, ? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits all items emitted by the current Observable that are distinct from their
immediate predecessors when compared with each other via the provided comparator function.
- doAfterNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the specified consumer with the current item after this item has been emitted to the downstream.
- doAfterNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the specified
Consumer with the current item after this item has been emitted to the downstream.
- doAfterNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the current element passing through any 'rail'
after it has been delivered to downstream within the rail.
- doAfterSuccess(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the specified
Consumer with the success item after this item has been emitted to the downstream.
- doAfterSuccess(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the specified consumer with the success item after this item has been emitted to the downstream.
- doAfterTerminate(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that calls the given
onAfterTerminate Action after this
Completable
completes normally or with an exception.
- doAfterTerminate(Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
- doAfterTerminate(Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
- doAfterTerminate(Action) - Method in class io.reactivex.rxjava3.core.Observable
-
- doAfterTerminate(Action) - Method in class io.reactivex.rxjava3.core.Single
-
Registers an
Action to be called after this
Single invokes either
onSuccess or
onError.
- doAfterTerminated(Action) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Run the specified
Action when a 'rail' completes or signals an error.
- doFinally(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Calls the specified
Action after this
Completable signals
onError or
onComplete or gets disposed by
the downstream.
- doFinally(Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the specified action after this Flowable signals onError or onComplete or gets canceled by
the downstream.
- doFinally(Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the specified action after this Maybe signals onSuccess, onError or onComplete or gets disposed by
the downstream.
- doFinally(Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the specified action after the current Observable signals onError or onCompleted or gets disposed by
the downstream.
- doFinally(Action) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the specified action after this Single signals onSuccess or onError or gets disposed by
the downstream.
- done - Variable in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
The latch that indicates an onError or onComplete has been called.
- doOnCancel(Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the cancel
Action if the downstream cancels the sequence.
- doOnCancel(Action) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Run the specified
Action when a 'rail' receives a cancellation.
- doOnComplete(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which calls the given
onComplete Action if this
Completable completes.
- doOnComplete(Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Invokes an
Action just before the current
Flowable calls
onComplete.
- doOnComplete(Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Invokes an
Action just before the current
Maybe calls
onComplete.
- doOnComplete(Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that invokes an
Action when the current
Observable calls
onComplete.
- doOnComplete(Action) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Run the specified
Action when a 'rail' completes.
- doOnDispose(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
- doOnDispose(Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
- doOnDispose(Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the given shared
Action if the downstream disposes the sequence.
- doOnDispose(Action) - Method in class io.reactivex.rxjava3.core.Single
-
- doOnEach(Consumer<? super Notification<T>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Invokes a
Consumer with a
Notification instances matching the signals emitted by the current
Flowable
before they are forwarded to the downstream.
- doOnEach(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the appropriate methods of the given
Subscriber when the current
Flowable signals events before forwarding it
to the downstream.
- doOnEach(Consumer<? super Notification<T>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that invokes a
Consumer with the appropriate
Notification
object when the current
Observable signals an item or terminates.
- doOnEach(Observer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that forwards the items and terminal events of the current
Observable to its
Observers and to the given shared
Observer instance.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which calls the given
onError Consumer if this
Completable emits an error.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the given
Consumer with the error
Throwable if the current
Flowable failed before forwarding it to
the downstream.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the shared
Consumer with the error sent via
onError for each
MaybeObserver that subscribes to the current
Maybe.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the given
Consumer with the error
Throwable if the current
Observable failed before forwarding it to
the downstream.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the shared consumer with the error sent via
onError for each
SingleObserver that subscribes to the current
Single.
- doOnError(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the exception passing through any 'rail'.
- doOnEvent(Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which calls the given
onEvent Consumer with the
Throwable for an
onError
or
null for an
onComplete signal from this
Completable before delivering the signal to the downstream.
- doOnEvent(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the given onEvent callback with the (success value, null) for an onSuccess, (null, throwable) for
an onError or (null, null) for an onComplete signal from this Maybe before delivering said
signal to the downstream.
- doOnEvent(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the shared consumer with the error sent via
onError or the value
via
onSuccess for each
SingleObserver that subscribes to the current
Single.
- doOnLifecycle(Consumer<? super Disposable>, Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Calls the appropriate
onXXX method (shared between all
CompletableObservers) for the lifecycle events of
the sequence (subscription, disposal).
- doOnLifecycle(Consumer<? super Subscription>, LongConsumer, Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the appropriate
onXXX method (shared between all
Subscribers) for the lifecycle events of
the sequence (subscription, cancellation, requesting).
- doOnLifecycle(Consumer<? super Disposable>, Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the appropriate
onXXX method (shared between all
MaybeObservers) for the lifecycle events of
the sequence (subscription, disposal).
- doOnLifecycle(Consumer<? super Disposable>, Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the appropriate
onXXX method (shared between all
Observers) for the lifecycle events of
the sequence (subscription, disposal).
- doOnLifecycle(Consumer<? super Disposable>, Action) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the appropriate
onXXX method (shared between all
SingleObservers) for the lifecycle events of
the sequence (subscription, disposal).
- doOnNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the given
Consumer with the value emitted by the current
Flowable before forwarding it to the downstream.
- doOnNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the given
Consumer with the value emitted by the current
Observable before forwarding it to the downstream.
- doOnNext(Consumer<? super T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the current element passing through any 'rail'.
- doOnNext(Consumer<? super T>, ParallelFailureHandling) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the current element passing through any 'rail' and
handles errors based on the given
ParallelFailureHandling enumeration value.
- doOnNext(Consumer<? super T>, BiFunction<? super Long, ? super Throwable, ParallelFailureHandling>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the current element passing through any 'rail' and
handles errors based on the returned value by the handler function.
- doOnRequest(LongConsumer) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the given
LongConsumer with the request amount from the downstream before forwarding it
to the current
Flowable.
- doOnRequest(LongConsumer) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified consumer with the request amount if any rail receives a request.
- doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that calls the given
onSubscribe callback with the disposable
that the downstream
CompletableObservers receive upon subscription.
- doOnSubscribe(Consumer<? super Subscription>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the given
Consumer with the
Subscription provided by the current
Flowable upon
subscription from the downstream before forwarding it to the subscriber's
onSubscribe method.
- doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable so that it invokes the given
Consumer when the current
Observable is subscribed from
its
Observers.
- doOnSubscribe(Consumer<? super Disposable>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the shared consumer with the
Disposable sent through the
onSubscribe for each
SingleObserver that subscribes to the current
Single.
- doOnSubscribe(Consumer<? super Subscription>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Call the specified callback when a 'rail' receives a
Subscription from its upstream.
- doOnSuccess(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the shared
Consumer with the success value sent via
onSuccess for each
MaybeObserver that subscribes to the current
Maybe.
- doOnSuccess(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the shared consumer with the success value sent via
onSuccess for each
SingleObserver that subscribes to the current
Single.
- doOnTerminate(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that calls the given
onTerminate Action just before this
Completable
completes normally or with an exception.
- doOnTerminate(Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the given
Action when the current
Flowable completes normally or with an error before those signals
are forwarded to the downstream.
- doOnTerminate(Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe instance that calls the given onTerminate callback
just before this Maybe completes normally or with an exception.
- doOnTerminate(Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable so that it invokes an action when the current Observable calls onComplete or
onError.
- doOnTerminate(Action) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a Single instance that calls the given onTerminate callback
just before this Single completes normally or with an exception.
- generate(Consumer<Emitter<T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a cold, synchronous, stateless and backpressure-aware generator of values.
- generate(Supplier<S>, BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
- generate(Supplier<S>, BiConsumer<S, Emitter<T>>, Consumer<? super S>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
- generate(Supplier<S>, BiFunction<S, Emitter<T>, S>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
- generate(Supplier<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a cold, synchronous, stateful and backpressure-aware generator of values.
- generate(Consumer<Emitter<T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a cold, synchronous and stateless generator of values.
- generate(Supplier<S>, BiConsumer<S, Emitter<T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a cold, synchronous and stateful generator of values.
- generate(Supplier<S>, BiConsumer<S, Emitter<T>>, Consumer<? super S>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a cold, synchronous and stateful generator of values.
- generate(Supplier<S>, BiFunction<S, Emitter<T>, S>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a cold, synchronous and stateful generator of values.
- generate(Supplier<S>, BiFunction<S, Emitter<T>, S>, Consumer<? super S>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a cold, synchronous and stateful generator of values.
- get() - Method in class io.reactivex.rxjava3.disposables.SerialDisposable
-
Returns the currently contained Disposable or null if this container is empty.
- get() - Method in interface io.reactivex.rxjava3.functions.Supplier
-
Produces a value or throws an exception.
- getAsBoolean() - Method in interface io.reactivex.rxjava3.functions.BooleanSupplier
-
Returns a boolean value.
- getCause() - Method in exception io.reactivex.rxjava3.exceptions.CompositeException
-
- getComputationSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getError() - Method in class io.reactivex.rxjava3.core.Notification
-
Returns the container
Throwable error if this notification is an
onError
signal, null otherwise.
- getErrorHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the a hook consumer.
- getExceptions() - Method in exception io.reactivex.rxjava3.exceptions.CompositeException
-
Retrieves the list of exceptions that make up the CompositeException.
- getInitComputationSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getInitIoSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getInitNewThreadSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getInitSingleSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getIoSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getKey() - Method in class io.reactivex.rxjava3.flowables.GroupedFlowable
-
Returns the key that identifies the group of items emitted by this GroupedFlowable.
- getKey() - Method in class io.reactivex.rxjava3.observables.GroupedObservable
-
Returns the key that identifies the group of items emitted by this GroupedObservable.
- getMessage() - Method in exception io.reactivex.rxjava3.exceptions.CompositeException
-
- getNewThreadSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnBeforeBlocking() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current blocking handler or null if no custom handler
is set.
- getOnCompletableAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnCompletableSubscribe() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnConnectableFlowableAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnConnectableObservableAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnFlowableAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnFlowableSubscribe() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnMaybeAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnMaybeSubscribe() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnObservableAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnObservableSubscribe() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnParallelAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnSingleAssembly() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getOnSingleSubscribe() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getScheduleHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getSingleSchedulerHandler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns the current hook function.
- getThrowable() - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.processors.FlowableProcessor
-
Returns the error that caused the FlowableProcessor to terminate or null if the FlowableProcessor
hasn't terminated yet.
- getThrowable() - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
Returns the terminal error if this CompletableSubject has been terminated with an error, null otherwise.
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
Returns the terminal error if this MaybeSubject has been terminated with an error, null otherwise.
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
Returns the terminal error if this SingleSubject has been terminated with an error, null otherwise.
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.Subject
-
Returns the error that caused the Subject to terminate or null if the Subject
hasn't terminated yet.
- getThrowable() - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- getValue() - Method in class io.reactivex.rxjava3.core.Notification
-
Returns the contained value if this notification is an onNext
signal, null otherwise.
- getValue() - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
Returns a single value this processor currently has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
Returns a single value the BehaviorProcessor currently has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Returns the latest value this processor has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
Returns a single value the Subject currently has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
Returns a single value the Subject currently has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
Returns the success value if this MaybeSubject was terminated with a success value.
- getValue() - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Returns a single value the Subject currently has or null if no such value exists.
- getValue() - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
Returns the success value if this SingleSubject was terminated with a success value.
- getValues() - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Returns an Object array containing snapshot all values of this processor.
- getValues(T[]) - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
Returns a typed array containing a snapshot of all values of this processor.
- getValues() - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Returns an Object array containing snapshot all values of the Subject.
- getValues(T[]) - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
Returns a typed array containing a snapshot of all values of the Subject.
- getWrappedRunnable() - Method in interface io.reactivex.rxjava3.schedulers.SchedulerRunnableIntrospection
-
Returns the wrapped action.
- groupBy(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int, Function<? super Consumer<Object>, ? extends Map<K, Object>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Groups the items emitted by the current
Flowable according to a specified criterion, and emits these
grouped items as
GroupedFlowables.
- groupBy(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Observable
-
Groups the items emitted by the current
Observable according to a specified criterion, and emits these
grouped items as
GroupedObservables.
- groupBy(Function<? super T, ? extends K>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Groups the items emitted by the current
Observable according to a specified criterion, and emits these
grouped items as
GroupedObservables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Observable
-
Groups the items emitted by the current
Observable according to a specified criterion, and emits these
grouped items as
GroupedObservables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Groups the items emitted by the current
Observable according to a specified criterion, and emits these
grouped items as
GroupedObservables.
- groupBy(Function<? super T, ? extends K>, Function<? super T, ? extends V>, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Groups the items emitted by the current
Observable according to a specified criterion, and emits these
grouped items as
GroupedObservables.
- GroupedFlowable<K,T> - Class in io.reactivex.rxjava3.flowables
-
- GroupedFlowable(K) - Constructor for class io.reactivex.rxjava3.flowables.GroupedFlowable
-
Constructs a GroupedFlowable with the given key.
- GroupedObservable<K,T> - Class in io.reactivex.rxjava3.observables
-
- GroupedObservable(K) - Constructor for class io.reactivex.rxjava3.observables.GroupedObservable
-
Constructs a GroupedObservable with the given key.
- groupJoin(Publisher<? extends TRight>, Function<? super T, ? extends Publisher<TLeftEnd>>, Function<? super TRight, ? extends Publisher<TRightEnd>>, BiFunction<? super T, ? super Flowable<TRight>, ? extends R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that correlates two
Publishers when they overlap in time and groups the results.
- groupJoin(ObservableSource<? extends TRight>, Function<? super T, ? extends ObservableSource<TLeftEnd>>, Function<? super TRight, ? extends ObservableSource<TRightEnd>>, BiFunction<? super T, ? super Observable<TRight>, ? extends R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that correlates two
ObservableSources when they overlap in time and groups the results.
- ignoreElement() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Completable that ignores the item emitted by the current
Maybe and only calls
onComplete or
onError.
- ignoreElement() - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Completable that ignores the success value of this
Single
and signals
onComplete instead.
- ignoreElements() - Method in class io.reactivex.rxjava3.core.Flowable
-
Ignores all items emitted by the current Flowable and only calls onComplete or onError.
- ignoreElements() - Method in class io.reactivex.rxjava3.core.Observable
-
Ignores all items emitted by the current Observable and only calls onComplete or onError.
- initComputationScheduler(Supplier<Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- initIoScheduler(Supplier<Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- initNewThreadScheduler(Supplier<Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- initSingleScheduler(Supplier<Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- interval(long, long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits a 0L after the initialDelay and ever-increasing numbers
after each period of time thereafter.
- interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits a
0L after the
initialDelay and ever-increasing numbers
after each
period of time thereafter, on a specified
Scheduler.
- interval(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits a sequential number every specified interval of time.
- interval(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits a sequential number every specified interval of time, on a
specified
Scheduler.
- interval(long, long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits a 0L after the initialDelay and ever increasing numbers
after each period of time thereafter.
- interval(long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits a
0L after the
initialDelay and ever increasing numbers
after each
period of time thereafter, on a specified
Scheduler.
- interval(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits a sequential number every specified interval of time.
- interval(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits a sequential number every specified interval of time, on a
specified
Scheduler.
- intervalRange(long, long, long, long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Signals a range of long values, the first after some initial delay and the rest periodically after.
- intervalRange(long, long, long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Signals a range of long values, the first after some initial delay and the rest periodically after.
- intervalRange(long, long, long, long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Observable
-
Signals a range of long values, the first after some initial delay and the rest periodically after.
- intervalRange(long, long, long, long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Observable
-
Signals a range of long values, the first after some initial delay and the rest periodically after.
- IntFunction<T> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that takes a primitive value and return value of type T.
- IO - Static variable in annotation type io.reactivex.rxjava3.annotations.SchedulerSupport
-
The operator/class runs on RxJava's
I/O scheduler or takes
timing information from it.
- io() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
Returns a default, shared
Scheduler instance intended for IO-bound work.
- io.reactivex.rxjava3.annotations - package io.reactivex.rxjava3.annotations
-
- io.reactivex.rxjava3.core - package io.reactivex.rxjava3.core
-
- io.reactivex.rxjava3.disposables - package io.reactivex.rxjava3.disposables
-
Default implementations for
Disposable-based resource management
(
Disposable container types) and utility classes to construct
Disposables from callbacks and other types.
- io.reactivex.rxjava3.exceptions - package io.reactivex.rxjava3.exceptions
-
- io.reactivex.rxjava3.flowables - package io.reactivex.rxjava3.flowables
-
- io.reactivex.rxjava3.functions - package io.reactivex.rxjava3.functions
-
Functional interfaces of functions and actions of arity 0 to 9 and related
utility classes.
- io.reactivex.rxjava3.observables - package io.reactivex.rxjava3.observables
-
- io.reactivex.rxjava3.observers - package io.reactivex.rxjava3.observers
-
Default wrappers and implementations for observer-based consumer classes and interfaces,
including disposable and resource-tracking variants and
the
TestObserver that allows unit testing
Observable-,
Single-,
Maybe- and
Completable-based flows.
- io.reactivex.rxjava3.parallel - package io.reactivex.rxjava3.parallel
-
- io.reactivex.rxjava3.plugins - package io.reactivex.rxjava3.plugins
-
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers.
- io.reactivex.rxjava3.processors - package io.reactivex.rxjava3.processors
-
Classes representing so-called hot backpressure-aware sources, aka
processors,
that implement the
FlowableProcessor class,
the Reactive Streams
Processor interface
to allow forms of multicasting events to one or more subscribers as well as consuming another
Reactive Streams
Publisher.
- io.reactivex.rxjava3.schedulers - package io.reactivex.rxjava3.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.
- io.reactivex.rxjava3.subjects - package io.reactivex.rxjava3.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.
- io.reactivex.rxjava3.subscribers - package io.reactivex.rxjava3.subscribers
-
- isCancelled() - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
- isCancelled() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Returns true if this TestSubscriber has been cancelled.
- isDisposed() - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
- isDisposed() - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
- isDisposed() - Method in interface io.reactivex.rxjava3.core.ObservableEmitter
-
- isDisposed() - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
- isDisposed() - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
- isDisposed() - Method in interface io.reactivex.rxjava3.disposables.Disposable
-
Returns true if this resource has been disposed.
- isDisposed() - Method in class io.reactivex.rxjava3.disposables.SerialDisposable
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Returns true if this test consumer was cancelled/disposed.
- isDisposed() - Method in class io.reactivex.rxjava3.observers.DisposableCompletableObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.DisposableMaybeObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.DisposableObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.DisposableSingleObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
Returns true if this ResourceCompletableObserver has been disposed/cancelled.
- isDisposed() - Method in class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
Returns true if this ResourceMaybeObserver has been disposed/cancelled.
- isDisposed() - Method in class io.reactivex.rxjava3.observers.ResourceObserver
-
Returns true if this ResourceObserver has been disposed/cancelled.
- isDisposed() - Method in class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
Returns true if this ResourceSingleObserver has been disposed/cancelled.
- isDisposed() - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- isDisposed() - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- isDisposed() - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
Returns true if this ResourceSubscriber has been disposed/cancelled.
- isDisposed() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- isEmpty() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits
true if the current
Flowable is empty, otherwise
false.
- isEmpty() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits
true if the current
Maybe is empty, otherwise
false.
- isEmpty() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits
true if the current
Observable is empty, otherwise
false.
- isFailOnNonBlockingScheduler() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns true if the blockingX operators fail
with an IllegalStateException on a non-blocking scheduler
such as computation or single.
- isLockdown() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Returns true if the plugins were locked down.
- isOnComplete() - Method in class io.reactivex.rxjava3.core.Notification
-
Returns true if this notification is an onComplete signal.
- isOnError() - Method in class io.reactivex.rxjava3.core.Notification
-
- isOnNext() - Method in class io.reactivex.rxjava3.core.Notification
-
- Observable<T> - Class in io.reactivex.rxjava3.core
-
The Observable class is the non-backpressured, optionally multi-valued base reactive class that
offers factory methods, intermediate operators and the ability to consume synchronous
and/or asynchronous reactive dataflows.
- Observable() - Constructor for class io.reactivex.rxjava3.core.Observable
-
- ObservableConverter<T,R> - Interface in io.reactivex.rxjava3.core
-
- ObservableEmitter<T> - Interface in io.reactivex.rxjava3.core
-
Abstraction over an RxJava
Observer that allows associating
a resource with it.
- ObservableOnSubscribe<T> - Interface in io.reactivex.rxjava3.core
-
A functional interface that has a
subscribe() method that receives
an instance of an
ObservableEmitter instance that allows pushing
events in a cancellation-safe manner.
- ObservableOperator<Downstream,Upstream> - Interface in io.reactivex.rxjava3.core
-
Interface to map/wrap a downstream
Observer to an upstream
Observer.
- ObservableSource<T> - Interface in io.reactivex.rxjava3.core
-
Represents a basic, non-backpressured
Observable source base interface,
consumable via an
Observer.
- ObservableTransformer<Upstream,Downstream> - Interface in io.reactivex.rxjava3.core
-
- observeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which emits the terminal events from the thread of the specified
Scheduler.
- observeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Signals the items and terminal signals of the current
Flowable on the specified
Scheduler,
asynchronously with a bounded buffer of
Flowable.bufferSize() slots.
- observeOn(Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Signals the items and terminal signals of the current
Flowable on the specified
Scheduler,
asynchronously with a bounded buffer and optionally delays
onError notifications.
- observeOn(Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Signals the items and terminal signals of the current
Flowable on the specified
Scheduler,
asynchronously with a bounded buffer of configurable size and optionally delays
onError notifications.
- observeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Wraps a
Maybe to emit its item (or notify of its error) on a specified
Scheduler,
asynchronously.
- observeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable to perform the current
Observable's emissions and notifications on a specified
Scheduler,
asynchronously with an unbounded buffer with
Flowable.bufferSize() "island size".
- observeOn(Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable to perform the current
Observable's emissions and notifications on a specified
Scheduler,
asynchronously with an unbounded buffer with
Flowable.bufferSize() "island size" and optionally delays
onError notifications.
- observeOn(Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable to perform the current
Observable's emissions and notifications on a specified
Scheduler,
asynchronously with an unbounded buffer of configurable "island size" and optionally delays
onError notifications.
- observeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Signals the success item or the terminal signals of the current
Single on the specified
Scheduler,
asynchronously.
- Observer<T> - Interface in io.reactivex.rxjava3.core
-
Provides a mechanism for receiving push-based notifications.
- offer(T) - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
Tries to emit the item to all currently subscribed Subscribers if all of them
has requested some value, returns false otherwise.
- offer(T) - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Tries to offer an item into the internal queue and returns false
if the queue is full.
- offer(T) - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
Tries to emit the item to all currently subscribed Subscribers if all of them
has requested some value, returns false otherwise.
- ofType(Class<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Filters the items emitted by the current Flowable, only emitting those of the specified type.
- ofType(Class<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Filters the items emitted by the current
Maybe, only emitting its success value if that
is an instance of the supplied
Class.
- ofType(Class<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Filters the items emitted by the current Observable, only emitting those of the specified type.
- ofType(Class<U>) - Method in class io.reactivex.rxjava3.core.Single
-
Filters the items emitted by the current
Single, only emitting its success value if that
is an instance of the supplied
Class.
- onAssembly(Maybe<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(Flowable<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(ConnectableFlowable<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(Observable<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(ConnectableObservable<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(Single<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(Completable) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onAssembly(ParallelFlowable<T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onBackpressureBuffer() - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an unlimited number of items from the current Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place.
- onBackpressureBuffer(boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an unlimited number of items from the current Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place, optionally delaying an error until all buffered items have been consumed.
- onBackpressureBuffer(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an limited number of items from the current
Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place, however, the resulting
Flowable will signal a
MissingBackpressureException via
onError as soon as the buffer's capacity is exceeded, dropping all undelivered
items, and canceling the flow.
- onBackpressureBuffer(int, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an limited number of items from the current
Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place, however, the resulting
Flowable will signal a
MissingBackpressureException via
onError as soon as the buffer's capacity is exceeded, dropping all undelivered
items, and canceling the flow.
- onBackpressureBuffer(int, boolean, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an optionally unlimited number of items from the current Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place.
- onBackpressureBuffer(int, boolean, boolean, Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an optionally unlimited number of items from the current Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place.
- onBackpressureBuffer(int, Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an limited number of items from the current
Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place, however, the resulting
Flowable will signal a
MissingBackpressureException via
onError as soon as the buffer's capacity is exceeded, dropping all undelivered
items, canceling the flow and calling the
onOverflow action.
- onBackpressureBuffer(long, Action, BackpressureOverflowStrategy) - Method in class io.reactivex.rxjava3.core.Flowable
-
Buffers an optionally unlimited number of items from the current Flowable and allows it to emit as fast it can while allowing the
downstream to consume the items at its own place.
- onBackpressureDrop() - Method in class io.reactivex.rxjava3.core.Flowable
-
Drops items from the current
Flowable if the downstream is not ready to receive new items (indicated
by a lack of
Subscription.request(long) calls from it).
- onBackpressureDrop(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Drops items from the current
Flowable if the downstream is not ready to receive new items (indicated
by a lack of
Subscription.request(long) calls from it) and calls the given
Consumer with such
dropped items.
- onBackpressureLatest() - Method in class io.reactivex.rxjava3.core.Flowable
-
Drops all but the latest item emitted by the current
Flowable if the downstream is not ready to receive
new items (indicated by a lack of
Subscription.request(long) calls from it) and emits this latest
item when the downstream becomes ready.
- onBeforeBlocking() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Called before an operator attempts a blocking operation
such as awaiting a condition or signal
and should return true to indicate the operator
should not block but throw an IllegalArgumentException.
- onComplete() - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
Signal the completion.
- onComplete() - Method in interface io.reactivex.rxjava3.core.CompletableObserver
-
Called once the deferred computation completes normally.
- onComplete() - Method in interface io.reactivex.rxjava3.core.Emitter
-
Signal a completion.
- onComplete() - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
Signal the completion.
- onComplete() - Method in interface io.reactivex.rxjava3.core.MaybeObserver
-
Called once the deferred computation completes normally.
- onComplete() - Method in interface io.reactivex.rxjava3.core.Observer
-
- onComplete() - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- onComplete() - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- onComplete() - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- onComplete() - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- onComplete() - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- onComplete() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- onComputationScheduler(Scheduler) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
Signal an exception.
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.CompletableObserver
-
Called once if the deferred computation 'throws' an exception.
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.Emitter
-
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
Signal an exception.
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.MaybeObserver
-
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.Observer
-
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
Signal an exception.
- onError(Throwable) - Method in interface io.reactivex.rxjava3.core.SingleObserver
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- onError(Throwable) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Called when an undeliverable error occurs.
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- onError(Throwable) - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- onErrorComplete() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that if this
Completable emits an error, it will emit an
onComplete
and swallow the upstream
Throwable.
- onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that if this
Completable emits an error and the
Predicate returns
true, it will emit an
onComplete and swallow the
Throwable.
- onErrorComplete() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable instance that if the current Flowable emits an error, it will emit an onComplete
and swallow the throwable.
- onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable instance that if the current Flowable emits an error and the predicate returns
true, it will emit an onComplete and swallow the throwable.
- onErrorComplete() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe instance that if this Maybe emits an error, it will emit an onComplete
and swallow the throwable.
- onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe instance that if this Maybe emits an error and the predicate returns
true, it will emit an onComplete and swallow the throwable.
- onErrorComplete() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable instance that if the current Observable emits an error, it will emit an onComplete
and swallow the throwable.
- onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable instance that if the current Observable emits an error and the predicate returns
true, it will emit an onComplete and swallow the throwable.
- onErrorComplete() - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Maybe instance that if the current
Single emits an error, it will emit an
onComplete
and swallow the throwable.
- onErrorComplete(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Maybe instance that if this
Single emits an error and the predicate returns
true, it will emit an
onComplete and swallow the throwable.
- OnErrorNotImplementedException - Exception in io.reactivex.rxjava3.exceptions
-
Represents an exception used to signal to the RxJavaPlugins.onError() that a
callback-based subscribe() method on a base reactive type didn't specify
an onError handler.
- OnErrorNotImplementedException(String, Throwable) - Constructor for exception io.reactivex.rxjava3.exceptions.OnErrorNotImplementedException
-
Customizes the Throwable with a custom message and wraps it before it
is signalled to the RxJavaPlugins.onError() handler as OnErrorNotImplementedException.
- OnErrorNotImplementedException(Throwable) - Constructor for exception io.reactivex.rxjava3.exceptions.OnErrorNotImplementedException
-
Wraps the Throwable before it
is signalled to the RxJavaPlugins.onError()
handler as OnErrorNotImplementedException.
- onErrorResumeNext(Function<? super Throwable, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that when encounters an error from this
Completable, calls the
specified
mapper Function that returns a
CompletableSource instance for it and resumes the
execution with it.
- onErrorResumeNext(Function<? super Throwable, ? extends Publisher<? extends T>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Resumes the flow with a
Publisher returned for the failure
Throwable of the current
Flowable by a
function instead of signaling the error via
onError.
- onErrorResumeNext(Function<? super Throwable, ? extends MaybeSource<? extends T>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Resumes the flow with a
MaybeSource returned for the failure
Throwable of the current
Maybe by a
function instead of signaling the error via
onError.
- onErrorResumeNext(Function<? super Throwable, ? extends ObservableSource<? extends T>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Resumes the flow with an
ObservableSource returned for the failure
Throwable of the current
Observable by a
function instead of signaling the error via
onError.
- onErrorResumeNext(Function<? super Throwable, ? extends SingleSource<? extends T>>) - Method in class io.reactivex.rxjava3.core.Single
-
Resumes the flow with a
SingleSource returned for the failure
Throwable of the current
Single by a
function instead of signaling the error via
onError.
- onErrorResumeWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Resumes the flow with the given
CompletableSource when the current
Completable fails instead of
signaling the error via
onError.
- onErrorResumeWith(Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Resumes the flow with the given
Publisher when the current
Flowable fails instead of
signaling the error via
onError.
- onErrorResumeWith(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Resumes the flow with the given
MaybeSource when the current
Maybe fails instead of
signaling the error via
onError.
- onErrorResumeWith(ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Resumes the flow with the given
ObservableSource when the current
Observable fails instead of
signaling the error via
onError.
- onErrorResumeWith(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Resumes the flow with the given
SingleSource when the current
Single fails instead of
signaling the error via
onError.
- onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Ends the flow with a success item returned by a function for the
Throwable error signaled by the current
Completable instead of signaling the error via
onError.
- onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Ends the flow with a last item returned by a function for the
Throwable error signaled by the current
Flowable instead of signaling the error via
onError.
- onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Ends the flow with a success item returned by a function for the
Throwable error signaled by the current
Maybe instead of signaling the error via
onError.
- onErrorReturn(Function<? super Throwable, ? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Ends the flow with a last item returned by a function for the
Throwable error signaled by the current
Observable instead of signaling the error via
onError.
- onErrorReturn(Function<Throwable, ? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Ends the flow with a success item returned by a function for the
Throwable error signaled by the current
Single instead of signaling the error via
onError.
- onErrorReturnItem(T) - Method in class io.reactivex.rxjava3.core.Completable
-
Ends the flow with the given success item when the current Completable
fails instead of signaling the error via onError.
- onErrorReturnItem(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Ends the flow with the given last item when the current Flowable fails instead of signaling the error via onError.
- onErrorReturnItem(T) - Method in class io.reactivex.rxjava3.core.Maybe
-
Ends the flow with the given success item when the current Maybe fails instead of signaling the error via onError.
- onErrorReturnItem(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Ends the flow with the given last item when the current Observable fails instead of signaling the error via onError.
- onErrorReturnItem(T) - Method in class io.reactivex.rxjava3.core.Single
-
Signals the specified value as success in case the current Single signals an error.
- onIoScheduler(Scheduler) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onNewThreadScheduler(Scheduler) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onNext(T) - Method in interface io.reactivex.rxjava3.core.Emitter
-
Signal a normal value.
- onNext(T) - Method in interface io.reactivex.rxjava3.core.Observer
-
Provides the
Observer with a new item to observe.
- onNext(T) - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- onNext(T) - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- onNext(T) - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- onNext(T) - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- onNext(T) - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- onNext(T) - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- onNext(T) - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- onNext(T) - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- onNext(T) - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- onNext(T) - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- onNext(T) - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- onSchedule(Runnable) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Called when a task is scheduled.
- onSingleScheduler(Scheduler) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onStart() - Method in class io.reactivex.rxjava3.observers.DefaultObserver
-
Called once the subscription has been set on this observer; override this
to perform initialization.
- onStart() - Method in class io.reactivex.rxjava3.observers.DisposableCompletableObserver
-
- onStart() - Method in class io.reactivex.rxjava3.observers.DisposableMaybeObserver
-
- onStart() - Method in class io.reactivex.rxjava3.observers.DisposableObserver
-
Called once the single upstream Disposable is set via onSubscribe.
- onStart() - Method in class io.reactivex.rxjava3.observers.DisposableSingleObserver
-
- onStart() - Method in class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
Called once the upstream sets a
Disposable on this
ResourceCompletableObserver.
- onStart() - Method in class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
Called once the upstream sets a
Disposable on this
ResourceMaybeObserver.
- onStart() - Method in class io.reactivex.rxjava3.observers.ResourceObserver
-
Called once the upstream sets a
Disposable on this
ResourceObserver.
- onStart() - Method in class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
Called once the upstream sets a
Disposable on this
ResourceSingleObserver.
- onStart() - Method in class io.reactivex.rxjava3.subscribers.DefaultSubscriber
-
Called once the subscription has been set on this observer; override this
to perform initialization or issue an initial request.
- onStart() - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- onStart() - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
Called once the upstream sets a
Subscription on this
ResourceSubscriber.
- onStart() - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Called after the onSubscribe is called and handled.
- onSubscribe(Disposable) - Method in interface io.reactivex.rxjava3.core.CompletableObserver
-
Called once by the
Completable to set a
Disposable on this instance which
then can be used to cancel the subscription at any time.
- onSubscribe(Subscription) - Method in interface io.reactivex.rxjava3.core.FlowableSubscriber
-
- onSubscribe(Disposable) - Method in interface io.reactivex.rxjava3.core.MaybeObserver
-
Provides the
MaybeObserver with the means of cancelling (disposing) the
connection (channel) with the
Maybe in both
synchronous (from within
onSubscribe(Disposable) itself) and asynchronous manner.
- onSubscribe(Disposable) - Method in interface io.reactivex.rxjava3.core.Observer
-
- onSubscribe(Disposable) - Method in interface io.reactivex.rxjava3.core.SingleObserver
-
Provides the
SingleObserver with the means of cancelling (disposing) the
connection (channel) with the Single in both
synchronous (from within
onSubscribe(Disposable) itself) and asynchronous manner.
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.DefaultObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.DisposableCompletableObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.DisposableMaybeObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.DisposableObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.DisposableSingleObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.SafeObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.SerializedObserver
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- onSubscribe(Flowable<T>, Subscriber<? super T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onSubscribe(Observable<T>, Observer<? super T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onSubscribe(Single<T>, SingleObserver<? super T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onSubscribe(Completable, CompletableObserver) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onSubscribe(Maybe<T>, MaybeObserver<? super T>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Calls the associated hook function.
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
- onSubscribe(Disposable) - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.DefaultSubscriber
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- onSubscribe(Subscription) - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- onSuccess(T) - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
Signal a success value.
- onSuccess(T) - Method in interface io.reactivex.rxjava3.core.MaybeObserver
-
Notifies the
MaybeObserver with one item and that the
Maybe has finished sending
push-based notifications.
- onSuccess(T) - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
Signal a success value.
- onSuccess(T) - Method in interface io.reactivex.rxjava3.core.SingleObserver
-
Notifies the
SingleObserver with a single item and that the
Single has finished sending
push-based notifications.
- onSuccess(T) - Method in class io.reactivex.rxjava3.observers.TestObserver
-
- onSuccess(T) - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
- onSuccess(T) - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
- onTerminateDetach() - Method in class io.reactivex.rxjava3.core.Completable
-
Nulls out references to the upstream producer and downstream
CompletableObserver if
the sequence is terminated or downstream calls
dispose().
- onTerminateDetach() - Method in class io.reactivex.rxjava3.core.Flowable
-
Nulls out references to the upstream producer and downstream
Subscriber if
the sequence is terminated or downstream cancels.
- onTerminateDetach() - Method in class io.reactivex.rxjava3.core.Maybe
-
Nulls out references to the upstream producer and downstream
MaybeObserver if
the sequence is terminated or downstream calls
dispose().
- onTerminateDetach() - Method in class io.reactivex.rxjava3.core.Observable
-
Nulls out references to the upstream producer and downstream
Observer if
the sequence is terminated or downstream calls
dispose().
- onTerminateDetach() - Method in class io.reactivex.rxjava3.core.Single
-
Nulls out references to the upstream producer and downstream
SingleObserver if
the sequence is terminated or downstream calls
dispose().
- range(int, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits a sequence of
Integers within a specified range.
- range(int, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits a sequence of
Integers within a specified range.
- rangeLong(long, long) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits a sequence of
Longs within a specified range.
- rangeLong(long, long) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits a sequence of
Longs within a specified range.
- rebatchRequests(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Requests n initially from the upstream and then 75% of n subsequently
after 75% of n values have been emitted to the downstream.
- reduce(BiFunction<T, T, T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Maybe that applies a specified accumulator function to the first item emitted by the current
Flowable, then feeds the result of that function along with the second item emitted by the current
Flowable into the same function, and so on until all items have been emitted by the current and finite
Flowable,
and emits the final result from the final call to your function as its sole item.
- reduce(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that applies a specified accumulator function to the first item emitted by the current
Flowable and a specified seed value, then feeds the result of that function along with the second item
emitted by the current
Flowable into the same function, and so on until all items have been emitted by the
current and finite
Flowable, emitting the final result from the final call to your function as its sole item.
- reduce(BiFunction<T, T, T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Maybe that applies a specified accumulator function to the first item emitted by the current
Observable, then feeds the result of that function along with the second item emitted by the current
Observable into the same function, and so on until all items have been emitted by the current and finite
Observable,
and emits the final result from the final call to your function as its sole item.
- reduce(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that applies a specified accumulator function to the first item emitted by the current
Observable and a specified seed value, then feeds the result of that function along with the second item
emitted by the current
Observable into the same function, and so on until all items have been emitted by the
current and finite
Observable, emitting the final result from the final call to your function as its sole item.
- reduce(BiFunction<T, T, T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Reduces all values within a 'rail' and across 'rails' with a reducer function into one
Flowable sequence.
- reduce(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Reduces all values within a 'rail' to a single value (with a possibly different type) via
a reducer function that is initialized on each rail from an initialSupplier value.
- reduceWith(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that applies a specified accumulator function to the first item emitted by the current
Flowable and a seed value derived from calling a specified
seedSupplier, then feeds the result
of that function along with the second item emitted by the current
Flowable into the same function, and so on until
all items have been emitted by the current and finite
Flowable, emitting the final result from the final call to your
function as its sole item.
- reduceWith(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that applies a specified accumulator function to the first item emitted by the current
Observable and a seed value derived from calling a specified
seedSupplier, then feeds the result
of that function along with the second item emitted by the current
Observable into the same function,
and so on until all items have been emitted by the current and finite
Observable, emitting the final result
from the final call to your function as its sole item.
- refCount() - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Returns a Flowable that stays connected to this ConnectableFlowable as long as there
is at least one subscription to this ConnectableFlowable.
- refCount(int) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Connects to the upstream ConnectableFlowable if the number of subscribed
subscriber reaches the specified count and disconnect if all subscribers have unsubscribed.
- refCount(long, TimeUnit) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Connects to the upstream ConnectableFlowable if the number of subscribed
subscriber reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed.
- refCount(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Connects to the upstream ConnectableFlowable if the number of subscribed
subscriber reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed.
- refCount(int, long, TimeUnit) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
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.
- refCount(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
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.
- refCount() - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Returns an Observable that stays connected to this ConnectableObservable as long as there
is at least one subscription to this ConnectableObservable.
- refCount(int) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Connects to the upstream ConnectableObservable if the number of subscribed
observers reaches the specified count and disconnect if all subscribers have unsubscribed.
- refCount(long, TimeUnit) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Connects to the upstream ConnectableObservable if the number of subscribed
observers reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed.
- refCount(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Connects to the upstream ConnectableObservable if the number of subscribed
observers reaches 1 and disconnect after the specified
timeout if all subscribers have unsubscribed.
- refCount(int, long, TimeUnit) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Connects to the upstream ConnectableObservable if the number of subscribed
observers reaches the specified count and disconnect after the specified
timeout if all subscribers have unsubscribed.
- refCount(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Connects to the upstream ConnectableObservable if the number of subscribed
observers reaches the specified count and disconnect after the specified
timeout if all subscribers have unsubscribed.
- remove(Disposable) - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
Removes and disposes the given
Disposable if it is part of this
container.
- remove(Disposable) - Method in interface io.reactivex.rxjava3.disposables.DisposableContainer
-
Removes and disposes the given disposable if it is part of this
container.
- repeat() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that repeatedly subscribes to this Completable until disposed.
- repeat(long) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that subscribes repeatedly at most the given number of times to this Completable.
- repeat() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that repeats the sequence of items emitted by the current Flowable indefinitely.
- repeat(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that repeats the sequence of items emitted by the current Flowable at most
count times.
- repeat() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable that repeats the sequence of items emitted by the current
Maybe indefinitely.
- repeat(long) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable that repeats the sequence of items emitted by the current
Maybe at most
count times.
- repeat() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that repeats the sequence of items emitted by the current Observable indefinitely.
- repeat(long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that repeats the sequence of items emitted by the current Observable at most
count times.
- repeat() - Method in class io.reactivex.rxjava3.core.Single
-
Repeatedly re-subscribes to the current
Single and emits each success value as a
Flowable sequence.
- repeat(long) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribes to the current
Single at most the given number of times and emits each success value as a
Flowable sequence.
- repeatUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that repeatedly subscribes to this
Completable so long as the given
stop
BooleanSupplier returns
false.
- repeatUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that repeats the sequence of items emitted by the current Flowable until
the provided stop function returns true.
- repeatUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable that repeats the sequence of items emitted by the current
Maybe until
the provided stop function returns
true.
- repeatUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that repeats the sequence of items emitted by the current Observable until
the provided stop function returns true.
- repeatUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribes to the current
Single until the given
BooleanSupplier returns
true
and emits the success items as a
Flowable sequence.
- repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that repeats when the
Publisher returned by the handler
Function
emits an item or completes when this
Publisher emits an
onComplete event.
- repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the same values as the current Flowable with the exception of an
onComplete.
- repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable that emits the same values as the current
Maybe with the exception of an
onComplete.
- repeatWhen(Function<? super Observable<Object>, ? extends ObservableSource<?>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the same values as the current Observable with the exception of an
onComplete.
- repeatWhen(Function<? super Flowable<Object>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribes to the current
Single if
the
Publisher returned by the handler function signals a value in response to a
value signaled through the
Flowable the handler receives.
- replace(Disposable) - Method in class io.reactivex.rxjava3.disposables.SerialDisposable
-
Atomically: set the next disposable on this container but don't dispose the previous
one (if any) or dispose next if the container has been disposed.
- replay() - Method in class io.reactivex.rxjava3.core.Flowable
-
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits items that are the results of invoking a specified selector on the items
emitted by a
ConnectableFlowable that shares a single subscription to the current
Flowable.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying
bufferSize notifications.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying
bufferSize notifications.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, int, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying all items that were emitted within a specified time window.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying all items that were emitted within a specified time window.
- replay(Function<? super Flowable<T>, ? extends Publisher<R>>, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
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 current
Flowable,
replaying all items that were emitted within a specified time window.
- replay(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays at most
bufferSize items to late
Subscribers.
- replay(int, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays at most
bufferSize items to late
Subscribers.
- replay(int, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays at most
bufferSize items that were emitted during a specified time window.
- replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays a maximum of
bufferSize items that are emitted within a specified time window to late
Subscribers.
- replay(int, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays a maximum of
bufferSize items that are emitted within a specified time window to late
Subscribers.
- replay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays all items emitted by it within a specified time window to late
Subscribers.
- replay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays all items emitted by it within a specified time window to late
Subscribers.
- replay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
ConnectableFlowable that shares a single subscription to the current
Flowable and
replays all items emitted by it within a specified time window to late
Subscribers.
- replay() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable
that will replay all of its items and notifications to any future
Observer.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits items that are the results of invoking a specified selector on the items
emitted by a
ConnectableObservable that shares a single subscription to the current
Observable.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying
bufferSize notifications.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying
bufferSize notifications.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, int, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying no more than
bufferSize items that were emitted within a specified time window.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying all items that were emitted within a specified time window.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying all items that were emitted within a specified time window.
- replay(Function<? super Observable<T>, ? extends ObservableSource<R>>, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
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 current
Observable,
replaying all items that were emitted within a specified time window.
- replay(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable that
replays at most
bufferSize items emitted by the current
Observable.
- replay(int, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable that
replays at most
bufferSize items emitted by the current
Observable.
- replay(int, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
replays at most
bufferSize items that were emitted during a specified time window.
- replay(int, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
that replays a maximum of
bufferSize items that are emitted within a specified time window.
- replay(int, long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
that replays a maximum of
bufferSize items that are emitted within a specified time window.
- replay(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
replays all items emitted by the current
Observable within a specified time window.
- replay(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
replays all items emitted by the current
Observable within a specified time window.
- replay(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
ConnectableObservable that shares a single subscription to the current
Observable and
replays all items emitted by the current
Observable within a specified time window.
- ReplayProcessor<T> - Class in io.reactivex.rxjava3.processors
-
Replays events to Subscribers.
- ReplaySubject<T> - Class in io.reactivex.rxjava3.subjects
-
Replays events (in a configurable bounded or unbounded manner) to current and late
Observers.
- request(long) - Method in class io.reactivex.rxjava3.subscribers.DefaultSubscriber
-
- request(long) - Method in class io.reactivex.rxjava3.subscribers.DisposableSubscriber
-
Requests the specified amount from the upstream if its
Subscription is set via
onSubscribe already.
- request(long) - Method in class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
Request the specified amount of elements from upstream.
- request(long) - Method in class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
- request(long) - Method in class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
- request(long) - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- requested() - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
The current outstanding request amount.
- requestMore(long) - Method in class io.reactivex.rxjava3.subscribers.TestSubscriber
-
- reset() - Method in class io.reactivex.rxjava3.flowables.ConnectableFlowable
-
Resets this ConnectableFlowable into its fresh state if it has terminated.
- reset() - Method in class io.reactivex.rxjava3.observables.ConnectableObservable
-
Resets this ConnectableObservable into its fresh state if it has terminated
or has been disposed.
- reset() - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Removes all handlers and resets to default behavior.
- ResourceCompletableObserver - Class in io.reactivex.rxjava3.observers
-
An abstract
CompletableObserver that allows asynchronous cancellation of its subscription and associated resources.
- ResourceCompletableObserver() - Constructor for class io.reactivex.rxjava3.observers.ResourceCompletableObserver
-
- ResourceMaybeObserver<T> - Class in io.reactivex.rxjava3.observers
-
An abstract
MaybeObserver that allows asynchronous cancellation of its subscription and associated resources.
- ResourceMaybeObserver() - Constructor for class io.reactivex.rxjava3.observers.ResourceMaybeObserver
-
- ResourceObserver<T> - Class in io.reactivex.rxjava3.observers
-
An abstract
Observer that allows asynchronous cancellation of its subscription and associated resources.
- ResourceObserver() - Constructor for class io.reactivex.rxjava3.observers.ResourceObserver
-
- ResourceSingleObserver<T> - Class in io.reactivex.rxjava3.observers
-
An abstract
SingleObserver that allows asynchronous cancellation of its subscription
and the associated resources.
- ResourceSingleObserver() - Constructor for class io.reactivex.rxjava3.observers.ResourceSingleObserver
-
- ResourceSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
An abstract Subscriber that allows asynchronous cancellation of its
subscription and associated resources.
- ResourceSubscriber() - Constructor for class io.reactivex.rxjava3.subscribers.ResourceSubscriber
-
- retry() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that retries this Completable as long as it emits an onError event.
- retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that retries this Completable in case of an error as long as the predicate
returns true.
- retry(long) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that when this Completable emits an error, retries at most the given
number of times before giving up and emitting the last error.
- retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable that when this Completable emits an error, retries at most times
or until the predicate returns false, whichever happens first and emitting the last error.
- retry(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that when this
Completable emits an error, calls the given predicate with
the latest
Throwable to decide whether to resubscribe to the upstream or not.
- retry() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, resubscribing to it if it calls onError
(infinite retry count).
- retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, resubscribing to it if it calls onError
and the predicate returns true for that specific exception and retry count.
- retry(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, resubscribing to it if it calls onError
up to a specified number of retries.
- retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Retries at most times or until the predicate returns false, whichever happens first.
- retry(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Retries the current Flowable if the predicate returns true.
- retry() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that mirrors the current Maybe, resubscribing to it if it calls onError
(infinite retry count).
- retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that mirrors the current Maybe, resubscribing to it if it calls onError
and the predicate returns true for that specific exception and retry count.
- retry(long) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that mirrors the current Maybe, resubscribing to it if it calls onError
up to a specified number of retries.
- retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Retries at most times or until the predicate returns false, whichever happens first.
- retry(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Retries the current Maybe if it fails and the predicate returns true.
- retry() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable, resubscribing to it if it calls onError
(infinite retry count).
- retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable, resubscribing to it if it calls onError
and the predicate returns true for that specific exception and retry count.
- retry(long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable, resubscribing to it if it calls onError
up to a specified number of retries.
- retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Retries at most times or until the predicate returns false, whichever happens first.
- retry(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Retries the current Observable if the predicate returns true.
- retry() - Method in class io.reactivex.rxjava3.core.Single
-
Repeatedly re-subscribes to the current Single indefinitely if it fails with an onError.
- retry(long) - Method in class io.reactivex.rxjava3.core.Single
-
Repeatedly re-subscribe at most the specified times to the current Single
if it fails with an onError.
- retry(BiPredicate<? super Integer, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribe to the current Single if the given predicate returns true when the Single fails
with an onError.
- retry(long, Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Repeatedly re-subscribe at most times or until the predicate returns false, whichever happens first
if it fails with an onError.
- retry(Predicate<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribe to the current Single if the given predicate returns true when the Single fails
with an onError.
- retryUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Completable
-
Retries until the given stop function returns true.
- retryUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Flowable
-
Retries until the given stop function returns true.
- retryUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Maybe
-
Retries until the given stop function returns true.
- retryUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Observable
-
Retries until the given stop function returns true.
- retryUntil(BooleanSupplier) - Method in class io.reactivex.rxjava3.core.Single
-
Retries until the given stop function returns true.
- retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which given a
Publisher and when this
Completable emits an error, delivers
that error through a
Flowable and the
Publisher should signal a value indicating a retry in response
or a terminal event indicating a termination.
- retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the same values as the current Flowable with the exception of an
onError.
- retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that emits the same values as the current Maybe with the exception of an
onError.
- retryWhen(Function<? super Observable<Throwable>, ? extends ObservableSource<?>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the same values as the current Observable with the exception of an
onError.
- retryWhen(Function<? super Flowable<Throwable>, ? extends Publisher<?>>) - Method in class io.reactivex.rxjava3.core.Single
-
Re-subscribes to the current
Single if and when the
Publisher returned by the handler
function signals a value.
- run() - Method in interface io.reactivex.rxjava3.functions.Action
-
Runs the action and optionally throws a checked exception.
- runOn(Scheduler) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Specifies where each 'rail' will observe its incoming values, specified via a
Scheduler, with
no work-stealing and default prefetch amount.
- runOn(Scheduler, int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Specifies where each 'rail' will observe its incoming values, specified via a
Scheduler, with
possibly work-stealing and a given prefetch amount.
- RxJavaPlugins - Class in io.reactivex.rxjava3.plugins
-
Utility class to inject handlers to certain standard RxJava operations.
- SafeObserver<T> - Class in io.reactivex.rxjava3.observers
-
Wraps another
Observer and ensures all
onXXX methods conform the protocol
(except the requirement for serialized access).
- SafeObserver(Observer<? super T>) - Constructor for class io.reactivex.rxjava3.observers.SafeObserver
-
Constructs a
SafeObserver by wrapping the given actual
Observer.
- safeSubscribe(CompletableObserver) - Method in class io.reactivex.rxjava3.core.Completable
-
- safeSubscribe(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the current
Flowable and wraps the given
Subscriber into a
SafeSubscriber
(if not already a
SafeSubscriber) that
deals with exceptions thrown by a misbehaving
Subscriber (that doesn't follow the
Reactive Streams specification).
- safeSubscribe(MaybeObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- safeSubscribe(Observer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the current
Observable and wraps the given
Observer into a
SafeObserver
(if not already a
SafeObserver) that
deals with exceptions thrown by a misbehaving
Observer (that doesn't follow the
Reactive Streams specification).
- safeSubscribe(SingleObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
- SafeSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
Wraps another
Subscriber and ensures all
onXXX methods conform the protocol
(except the requirement for serialized access).
- SafeSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.rxjava3.subscribers.SafeSubscriber
-
Constructs a
SafeSubscriber by wrapping the given actual
Subscriber.
- sample(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the most recently emitted item (if any) emitted by the current Flowable
within periodic time intervals.
- sample(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the most recently emitted item (if any) emitted by the current Flowable
within periodic time intervals and optionally emit the very last upstream item when the upstream completes.
- sample(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the most recently emitted item (if any) emitted by the current
Flowable
within periodic time intervals, where the intervals are defined on a particular
Scheduler.
- sample(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the most recently emitted item (if any) emitted by the current
Flowable
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.
- sample(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that, when the specified
sampler Publisher emits an item or completes,
emits the most recently emitted item (if any) emitted by the current
Flowable since the previous
emission from the
sampler Publisher.
- sample(Publisher<U>, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that, when the specified
sampler Publisher emits an item or completes,
emits the most recently emitted item (if any) emitted by the current
Flowable since the previous
emission from the
sampler Publisher
and optionally emit the very last upstream item when the upstream or other
Publisher complete.
- sample(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the most recently emitted item (if any) emitted by the current Observable
within periodic time intervals.
- sample(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the most recently emitted item (if any) emitted by the current Observable
within periodic time intervals and optionally emit the very last upstream item when the upstream completes.
- sample(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the most recently emitted item (if any) emitted by the current
Observable
within periodic time intervals, where the intervals are defined on a particular
Scheduler.
- sample(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the most recently emitted item (if any) emitted by the current
Observable
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.
- sample(ObservableSource<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that, when the specified
sampler ObservableSource emits an item or completes,
emits the most recently emitted item (if any) emitted by the current
Observable since the previous
emission from the
sampler ObservableSource.
- sample(ObservableSource<U>, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that, when the specified
sampler ObservableSource emits an item or completes,
emits the most recently emitted item (if any) emitted by the current
Observable since the previous
emission from the
sampler ObservableSource
and optionally emit the very last upstream item when the upstream or other
ObservableSource complete.
- scan(BiFunction<T, T, T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that applies a specified accumulator function to the first item emitted by the current
Flowable, then feeds the result of that function along with the second item emitted by the current
Floawble into the same function, and so on until all items have been emitted by the current Flowable,
emitting the result of each of these iterations.
- scan(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that applies a specified accumulator function to the first item emitted by the current
Flowable and a seed value, then feeds the result of that function along with the second item emitted by
the current Flowable into the same function, and so on until all items have been emitted by the current
Flowable, emitting the result of each of these iterations.
- scan(BiFunction<T, T, T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by the current
Observable, then feeds the result of that function along with the second item emitted by the current
Observable into the same function, and so on until all items have been emitted by the current Observable,
emitting the result of each of these iterations.
- scan(R, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by the current
Observable and a seed value, then feeds the result of that function along with the second item emitted by
the current Observable into the same function, and so on until all items have been emitted by the current
Observable, emitting the result of each of these iterations.
- scanWith(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that applies a specified accumulator function to the first item emitted by the current
Flowable and a seed value, then feeds the result of that function along with the second item emitted by
the current Flowable into the same function, and so on until all items have been emitted by the current
Flowable, emitting the result of each of these iterations.
- scanWith(Supplier<R>, BiFunction<R, ? super T, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by the current
Observable and a seed value, then feeds the result of that function along with the second item emitted by
the current Observable into the same function, and so on until all items have been emitted by the current
Observable, emitting the result of each of these iterations.
- schedule(Runnable) - Method in class io.reactivex.rxjava3.core.Scheduler.Worker
-
Schedules a Runnable for execution without any time delay.
- schedule(Runnable, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Scheduler.Worker
-
Schedules an Runnable for execution at some point in the future specified by a time delay
relative to the current time.
- scheduleDirect(Runnable) - Method in class io.reactivex.rxjava3.core.Scheduler
-
Schedules the given task on this Scheduler without any time delay.
- scheduleDirect(Runnable, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Scheduler
-
Schedules the execution of the given task with the given time delay.
- schedulePeriodically(Runnable, long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Scheduler.Worker
-
Schedules a periodic execution of the given task with the given initial time delay and repeat period.
- schedulePeriodicallyDirect(Runnable, long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Scheduler
-
Schedules a periodic execution of the given task with the given initial time delay and repeat period.
- Scheduler - Class in io.reactivex.rxjava3.core
-
A
Scheduler is an object that specifies an API for scheduling
units of work provided in the form of
Runnables to be
executed without delay (effectively as soon as possible), after a specified time delay or periodically
and represents an abstraction over an asynchronous boundary that ensures
these units of work get executed by some underlying task-execution scheme
(such as custom Threads, event loop,
Executor or Actor system)
with some uniform properties and guarantees regardless of the particular underlying
scheme.
- Scheduler() - Constructor for class io.reactivex.rxjava3.core.Scheduler
-
- Scheduler.Worker - Class in io.reactivex.rxjava3.core
-
Represents an isolated, sequential worker of a parent Scheduler for executing
Runnable tasks on
an underlying task-execution scheme (such as custom Threads, event loop,
Executor or Actor system).
- SchedulerRunnableIntrospection - Interface in io.reactivex.rxjava3.schedulers
-
- Schedulers - Class in io.reactivex.rxjava3.schedulers
-
Static factory methods for returning standard Scheduler instances.
- SchedulerSupport - Annotation Type in io.reactivex.rxjava3.annotations
-
Indicates what kind of scheduler the class or method uses.
- sequenceEqual(CompletableSource, CompletableSource) - Static method in class io.reactivex.rxjava3.core.Completable
-
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean value that indicates whether two
Publisher sequences are the
same by comparing the items emitted by each
Publisher pairwise.
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean value that indicates whether two
Publisher sequences are the
same by comparing the items emitted by each
Publisher pairwise based on the results of a specified
equality function.
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, BiPredicate<? super T, ? super T>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean value that indicates whether two
Publisher sequences are the
same by comparing the items emitted by each
Publisher pairwise based on the results of a specified
equality function.
- sequenceEqual(Publisher<? extends T>, Publisher<? extends T>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
Boolean value that indicates whether two
Publisher sequences are the
same by comparing the items emitted by each
Publisher pairwise.
- sequenceEqual(MaybeSource<? extends T>, MaybeSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits a
Boolean value that indicates whether two
MaybeSource sequences are the
same by comparing the items emitted by each
MaybeSource pairwise.
- sequenceEqual(MaybeSource<? extends T>, MaybeSource<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits a
Boolean value that indicates whether two
MaybeSources are the
same by comparing the items emitted by each
MaybeSource pairwise based on the results of a specified
equality function.
- sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean value that indicates whether two
ObservableSource sequences are the
same by comparing the items emitted by each
ObservableSource pairwise.
- sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean value that indicates whether two
ObservableSource sequences are the
same by comparing the items emitted by each
ObservableSource pairwise based on the results of a specified
equality function.
- sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, BiPredicate<? super T, ? super T>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean value that indicates whether two
ObservableSource sequences are the
same by comparing the items emitted by each
ObservableSource pairwise based on the results of a specified
equality function.
- sequenceEqual(ObservableSource<? extends T>, ObservableSource<? extends T>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
Boolean value that indicates whether two
ObservableSource sequences are the
same by comparing the items emitted by each
ObservableSource pairwise.
- sequenceEqual(SingleSource<? extends T>, SingleSource<? extends T>) - Static method in class io.reactivex.rxjava3.core.Single
-
- sequential() - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular
Flowable sequence, running with a default prefetch value
for the rails.
- sequential(int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular
Flowable sequence, running with a give prefetch value
for the rails.
- sequentialDelayError() - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular
Flowable sequence, running with a default prefetch value
for the rails and delaying errors from all rails till all terminate.
- sequentialDelayError(int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Merges the values from each 'rail' in a round-robin or same-order fashion and
exposes it as a regular
Flowable sequence, running with a give prefetch value
for the rails and delaying errors from all rails till all terminate.
- SerialDisposable - Class in io.reactivex.rxjava3.disposables
-
A Disposable container that allows atomically updating/replacing the contained
Disposable with another Disposable, disposing the old one when updating plus
handling the disposition when the container itself is disposed.
- SerialDisposable() - Constructor for class io.reactivex.rxjava3.disposables.SerialDisposable
-
Constructs an empty SerialDisposable.
- SerialDisposable(Disposable) - Constructor for class io.reactivex.rxjava3.disposables.SerialDisposable
-
Constructs a SerialDisposable with the given initial Disposable instance.
- serialize() - Method in class io.reactivex.rxjava3.core.Flowable
-
Forces the current
Flowable's emissions and notifications to be serialized and for it to obey
the Publisher contract in other ways.
- serialize() - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
Ensures that calls to onNext, onError and onComplete are properly serialized.
- serialize() - Method in class io.reactivex.rxjava3.core.Observable
-
- serialize() - Method in interface io.reactivex.rxjava3.core.ObservableEmitter
-
Ensures that calls to onNext, onError and onComplete are properly serialized.
- SerializedObserver<T> - Class in io.reactivex.rxjava3.observers
-
- SerializedObserver(Observer<? super T>) - Constructor for class io.reactivex.rxjava3.observers.SerializedObserver
-
Construct a
SerializedObserver by wrapping the given actual
Observer.
- SerializedObserver(Observer<? super T>, boolean) - Constructor for class io.reactivex.rxjava3.observers.SerializedObserver
-
Construct a SerializedObserver by wrapping the given actual
Observer and
optionally delaying the errors till all regular values have been emitted
from the internal buffer.
- SerializedSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
- SerializedSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
Construct a
SerializedSubscriber by wrapping the given actual
Subscriber.
- SerializedSubscriber(Subscriber<? super T>, boolean) - Constructor for class io.reactivex.rxjava3.subscribers.SerializedSubscriber
-
Construct a
SerializedSubscriber by wrapping the given actual
Subscriber and
optionally delaying the errors till all regular values have been emitted
from the internal buffer.
- set(Disposable) - Method in class io.reactivex.rxjava3.disposables.SerialDisposable
-
Atomically: set the next disposable on this container and dispose the previous
one (if any) or dispose next if the container has been disposed.
- setCancellable(Cancellable) - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
- setCancellable(Cancellable) - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
- setCancellable(Cancellable) - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
- setCancellable(Cancellable) - Method in interface io.reactivex.rxjava3.core.ObservableEmitter
-
- setCancellable(Cancellable) - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
- setComputationSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setDisposable(Disposable) - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
- setDisposable(Disposable) - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
- setDisposable(Disposable) - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
- setDisposable(Disposable) - Method in interface io.reactivex.rxjava3.core.ObservableEmitter
-
- setDisposable(Disposable) - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
- setErrorHandler(Consumer<? super Throwable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setFailOnNonBlockingScheduler(boolean) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Enables or disables the blockingX operators to fail
with an IllegalStateException on a non-blocking
scheduler such as computation or single.
- setInitComputationSchedulerHandler(Function<? super Supplier<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setInitIoSchedulerHandler(Function<? super Supplier<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setInitNewThreadSchedulerHandler(Function<? super Supplier<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setInitSingleSchedulerHandler(Function<? super Supplier<Scheduler>, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setIoSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setNewThreadSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnBeforeBlocking(BooleanSupplier) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Set the handler that is called when an operator attempts a blocking
await; the handler should return true to prevent the blocking
and to signal an IllegalStateException instead.
- setOnCompletableAssembly(Function<? super Completable, ? extends Completable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnCompletableSubscribe(BiFunction<? super Completable, ? super CompletableObserver, ? extends CompletableObserver>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnConnectableFlowableAssembly(Function<? super ConnectableFlowable, ? extends ConnectableFlowable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnConnectableObservableAssembly(Function<? super ConnectableObservable, ? extends ConnectableObservable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnFlowableAssembly(Function<? super Flowable, ? extends Flowable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnFlowableSubscribe(BiFunction<? super Flowable, ? super Subscriber, ? extends Subscriber>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnMaybeAssembly(Function<? super Maybe, ? extends Maybe>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnMaybeSubscribe(BiFunction<? super Maybe, MaybeObserver, ? extends MaybeObserver>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnObservableAssembly(Function<? super Observable, ? extends Observable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnObservableSubscribe(BiFunction<? super Observable, ? super Observer, ? extends Observer>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnParallelAssembly(Function<? super ParallelFlowable, ? extends ParallelFlowable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnSingleAssembly(Function<? super Single, ? extends Single>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setOnSingleSubscribe(BiFunction<? super Single, ? super SingleObserver, ? extends SingleObserver>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setScheduleHandler(Function<? super Runnable, ? extends Runnable>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- setSingleSchedulerHandler(Function<? super Scheduler, ? extends Scheduler>) - Static method in class io.reactivex.rxjava3.plugins.RxJavaPlugins
-
Sets the specific hook function.
- share() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new Flowable that multicasts (and shares a single subscription to) the current Flowable.
- share() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new Observable that multicasts (and shares a single subscription to) the current Observable.
- shutdown() - Method in class io.reactivex.rxjava3.core.Scheduler
-
Instructs the Scheduler instance to stop threads,
stop accepting tasks on any outstanding
Scheduler.Worker instances
and clean up any associated resources with this Scheduler.
- shutdown() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
Shuts down the standard Schedulers.
- SINGLE - Static variable in annotation type io.reactivex.rxjava3.annotations.SchedulerSupport
-
The operator/class runs on RxJava's
single scheduler
or takes timing information from it.
- single(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits the single item emitted by the current
Flowable if it
emits only a single item, or a default item if the current
Flowable emits no items.
- single(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits the single item emitted by the current
Observable, if the current
Observable
emits only a single item, or a default item if the current
Observable emits no items.
- Single<T> - Class in io.reactivex.rxjava3.core
-
The Single class implements the Reactive Pattern for a single value response.
- Single() - Constructor for class io.reactivex.rxjava3.core.Single
-
- single() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
Returns a default, shared, single-thread-backed
Scheduler instance for work
requiring strongly-sequential execution on the same background thread.
- SingleConverter<T,R> - Interface in io.reactivex.rxjava3.core
-
- singleElement() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Maybe that completes if this
Flowable is empty, signals one item if this
Flowable
signals exactly one item or signals an
IllegalArgumentException if this
Flowable signals
more than one item.
- singleElement() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Maybe that completes if the current
Observable is empty or emits the single item
emitted by the current
Observable, or signals an
IllegalArgumentException if the current
Observable emits more than one item.
- SingleEmitter<T> - Interface in io.reactivex.rxjava3.core
-
Abstraction over an RxJava
SingleObserver that allows associating
a resource with it.
- SingleObserver<T> - Interface in io.reactivex.rxjava3.core
-
Provides a mechanism for receiving push-based notification of a single value or an error.
- SingleOnSubscribe<T> - Interface in io.reactivex.rxjava3.core
-
A functional interface that has a
subscribe() method that receives
an instance of a
SingleEmitter instance that allows pushing
an event in a cancellation-safe manner.
- SingleOperator<Downstream,Upstream> - Interface in io.reactivex.rxjava3.core
-
Interface to map/wrap a downstream
SingleObserver to an upstream
SingleObserver.
- singleOrError() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits the single item emitted by this
Flowable, if this
Flowable
emits only a single item, otherwise
if this
Flowable completes without emitting any items a
NoSuchElementException will be signaled and
if this
Flowable emits more than one item, an
IllegalArgumentException will be signaled.
- singleOrError() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits the single item emitted by the current
Observable if it
emits only a single item, otherwise
if the current
Observable completes without emitting any items or emits more than one item a
NoSuchElementException or
IllegalArgumentException will be signaled respectively.
- singleOrErrorStage() - Method in class io.reactivex.rxjava3.core.Flowable
-
- singleOrErrorStage() - Method in class io.reactivex.rxjava3.core.Observable
-
- SingleSource<T> - Interface in io.reactivex.rxjava3.core
-
- singleStage(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
- singleStage(T) - Method in class io.reactivex.rxjava3.core.Observable
-
- SingleSubject<T> - Class in io.reactivex.rxjava3.subjects
-
Represents a hot Single-like source and consumer of events similar to Subjects.
- SingleTransformer<Upstream,Downstream> - Interface in io.reactivex.rxjava3.core
-
- size() - Method in class io.reactivex.rxjava3.disposables.CompositeDisposable
-
- size() - Method in exception io.reactivex.rxjava3.exceptions.CompositeException
-
Returns the number of suppressed exceptions.
- skip(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that skips the first count items emitted by the current Flowable and emits
the remainder.
- skip(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that skips values emitted by the current Flowable before a specified time window
elapses.
- skip(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that skips values emitted by the current
Flowable before a specified time window
on a specified
Scheduler elapses.
- skip(long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that skips the first count items emitted by the current Observable and emits
the remainder.
- skip(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that skips values emitted by the current Observable before a specified time window
elapses.
- skip(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that skips values emitted by the current
Observable before a specified time window
on a specified
Scheduler elapses.
- skipLast(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops a specified number of items from the end of the sequence emitted by the
current Flowable.
- skipLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops items emitted by the current Flowable during a specified time window
before the source completes.
- skipLast(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops items emitted by the current Flowable during a specified time window
before the source completes.
- skipLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops items emitted by the current Flowable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops items emitted by the current Flowable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that drops items emitted by the current Flowable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipLast(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops a specified number of items from the end of the sequence emitted by the
current Observable.
- skipLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops items emitted by the current Observable during a specified time window
before the source completes.
- skipLast(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops items emitted by the current Observable during a specified time window
before the source completes.
- skipLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops items emitted by the current Observable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops items emitted by the current Observable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that drops items emitted by the current Observable during a specified time window
(defined on a specified scheduler) before the source completes.
- skipUntil(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that skips items emitted by the current
Flowable until a second
Publisher emits
an item.
- skipUntil(ObservableSource<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that skips items emitted by the current
Observable until a second
ObservableSource emits
an item.
- skipWhile(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that skips all items emitted by the current Flowable as long as a specified
condition holds true, but emits all further source items as soon as the condition becomes false.
- skipWhile(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that skips all items emitted by the current Observable as long as a specified
condition holds true, but emits all further source items as soon as the condition becomes false.
- sorted() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the events emitted by source
Publisher, in a
sorted order.
- sorted(Comparator<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the events emitted by source
Publisher, in a
sorted order based on a specified comparison function.
- sorted() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the events emitted by the current Observable, in a
sorted order.
- sorted(Comparator<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the events emitted by the current Observable, in a
sorted order based on a specified comparison function.
- sorted(Comparator<? super T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Sorts the 'rails' of this
ParallelFlowable and returns a
Flowable that sequentially
picks the smallest next value from the rails.
- sorted(Comparator<? super T>, int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Sorts the 'rails' of this
ParallelFlowable and returns a
Flowable that sequentially
picks the smallest next value from the rails.
- start() - Method in class io.reactivex.rxjava3.core.Scheduler
-
Allows the Scheduler instance to start threads
and accept tasks on them.
- start() - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Initializes this Processor by setting an upstream Subscription that
ignores request amounts, uses a fixed buffer
and allows using the onXXX and offer methods
afterwards.
- start() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
Starts the standard Schedulers.
- startUnbounded() - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
Initializes this Processor by setting an upstream Subscription that
ignores request amounts, uses an unbounded buffer
and allows using the onXXX and offer methods
afterwards.
- startWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which first runs the other
CompletableSource
then the current
Completable if the other completed normally.
- startWith(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Flowable which first runs the other
SingleSource
then the current
Completable if the other succeeded normally.
- startWith(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Flowable which first runs the other
MaybeSource
then the current
Completable if the other succeeded or completed normally.
- startWith(ObservableSource<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
- startWith(Publisher<T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Flowable which first delivers the events
of the other
Publisher then runs the current
Completable.
- startWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable which first runs the other
CompletableSource
then the current
Flowable if the other completed normally.
- startWith(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable which first runs the other
SingleSource
then the current
Flowable if the other succeeded normally.
- startWith(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable which first runs the other
MaybeSource
then the current
Flowable if the other succeeded or completed normally.
- startWith(Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items in a specified
Publisher before it begins to emit
items emitted by the current
Flowable.
- startWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Maybe
-
- startWith(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable which first runs the other
SingleSource
then the current
Maybe if the other succeeded normally.
- startWith(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable which first runs the other
MaybeSource
then the current
Maybe if the other succeeded or completed normally.
- startWith(ObservableSource<T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- startWith(Publisher<T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Flowable which first delivers the events
of the other
Publisher then runs the current
Maybe.
- startWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable which first runs the other
CompletableSource
then the current
Observable if the other completed normally.
- startWith(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable which first runs the other
SingleSource
then the current
Observable if the other succeeded normally.
- startWith(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable which first runs the other
MaybeSource
then the current
Observable if the other succeeded or completed normally.
- startWith(ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items in a specified
ObservableSource before it begins to emit
items emitted by the current
Observable.
- startWith(CompletableSource) - Method in class io.reactivex.rxjava3.core.Single
-
- startWith(SingleSource<T>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Flowable which first runs the other
SingleSource
then the current
Single if the other succeeded normally.
- startWith(MaybeSource<T>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Flowable which first runs the other
MaybeSource
then the current
Single if the other succeeded or completed normally.
- startWith(ObservableSource<T>) - Method in class io.reactivex.rxjava3.core.Single
-
- startWith(Publisher<T>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Flowable which first delivers the events
of the other
Publisher then runs the current
Single.
- startWithArray(T...) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the specified items before it begins to emit items emitted by the current
Flowable.
- startWithArray(T...) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the current
Observable.
- startWithItem(T) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits a specified item before it begins to emit items emitted by the current
Flowable.
- startWithItem(T) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits a specified item before it begins to emit items emitted by the current
Observable.
- startWithIterable(Iterable<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items in a specified
Iterable before it begins to emit items
emitted by the current
Flowable.
- startWithIterable(Iterable<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items in a specified
Iterable before it begins to emit items
emitted by the current
Observable.
- Subject<T> - Class in io.reactivex.rxjava3.subjects
-
Represents an
Observer and an
Observable at the same time, allowing
multicasting events from a single source to multiple child
Observers.
- Subject() - Constructor for class io.reactivex.rxjava3.subjects.Subject
-
- subscribe() - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to this
Completable and returns a
Disposable which can be used to dispose
the subscription.
- subscribe(CompletableObserver) - Method in class io.reactivex.rxjava3.core.Completable
-
- subscribe(Action, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to this Completable and calls back either the onError or onComplete functions.
- subscribe(Action) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes to this
Completable and calls the given
Action when this
Completable
completes normally.
- subscribe(CompletableEmitter) - Method in interface io.reactivex.rxjava3.core.CompletableOnSubscribe
-
- subscribe(CompletableObserver) - Method in interface io.reactivex.rxjava3.core.CompletableSource
-
- subscribe() - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the current Flowable and ignores onNext and onComplete emissions.
- subscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the current Flowable and provides a callback to handle the items it emits.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the current Flowable and provides callbacks to handle the items it emits and any error
notification it issues.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes to the current Flowable and provides callbacks to handle the items it emits and any error or
completion notification it issues.
- subscribe(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
- subscribe(FlowableSubscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Establish a connection between this
Flowable and the given
FlowableSubscriber and
start streaming events based on the demand of the
FlowableSubscriber.
- subscribe(FlowableEmitter<T>) - Method in interface io.reactivex.rxjava3.core.FlowableOnSubscribe
-
- subscribe() - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to a Maybe and ignores onSuccess and onComplete emissions.
- subscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to a Maybe and provides a callback to handle the items it emits.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error
notification it issues.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes to a Maybe and provides callbacks to handle the items it emits and any error or
completion notification it issues.
- subscribe(MaybeObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- subscribe(MaybeEmitter<T>) - Method in interface io.reactivex.rxjava3.core.MaybeOnSubscribe
-
- subscribe(MaybeObserver<? super T>) - Method in interface io.reactivex.rxjava3.core.MaybeSource
-
- subscribe() - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the current Observable and ignores onNext and onComplete emissions.
- subscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the current Observable and provides a callback to handle the items it emits.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the current Observable and provides callbacks to handle the items it emits and any error
notification it signals.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>, Action) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes to the current Observable and provides callbacks to handle the items it emits and any error or
completion notification it signals.
- subscribe(Observer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
- subscribe(ObservableEmitter<T>) - Method in interface io.reactivex.rxjava3.core.ObservableOnSubscribe
-
Called for each
Observer that subscribes.
- subscribe(Observer<? super T>) - Method in interface io.reactivex.rxjava3.core.ObservableSource
-
- subscribe() - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to a Single but ignore its emission or notification.
- subscribe(BiConsumer<? super T, ? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to a Single and provides a composite callback to handle the item it emits
or any error notification it issues.
- subscribe(Consumer<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to a Single and provides a callback to handle the item it emits.
- subscribe(Consumer<? super T>, Consumer<? super Throwable>) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it
issues.
- subscribe(SingleObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
- subscribe(SingleEmitter<T>) - Method in interface io.reactivex.rxjava3.core.SingleOnSubscribe
-
- subscribe(SingleObserver<? super T>) - Method in interface io.reactivex.rxjava3.core.SingleSource
-
- subscribe(Subscriber<? super T>[]) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Subscribes an array of
Subscribers to this
ParallelFlowable and triggers
the execution chain for all 'rails'.
- subscribeActual(CompletableObserver) - Method in class io.reactivex.rxjava3.core.Completable
-
Implement this method to handle the incoming
CompletableObservers and
perform the business logic in your operator.
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Operator implementations (both source and intermediate) should implement this method that
performs the necessary business logic and handles the incoming
Subscribers.
- subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Implement this method in subclasses to handle the incoming
MaybeObservers.
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Operator implementations (both source and intermediate) should implement this method that
performs the necessary business logic and handles the incoming
Observers.
- subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.rxjava3.core.Single
-
Implement this method in subclasses to handle the incoming
SingleObservers.
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.AsyncProcessor
-
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.BehaviorProcessor
-
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.MulticastProcessor
-
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.PublishProcessor
-
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.ReplayProcessor
-
- subscribeActual(Subscriber<? super T>) - Method in class io.reactivex.rxjava3.processors.UnicastProcessor
-
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.subjects.AsyncSubject
-
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.subjects.BehaviorSubject
-
- subscribeActual(CompletableObserver) - Method in class io.reactivex.rxjava3.subjects.CompletableSubject
-
- subscribeActual(MaybeObserver<? super T>) - Method in class io.reactivex.rxjava3.subjects.MaybeSubject
-
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.subjects.PublishSubject
-
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.subjects.ReplaySubject
-
- subscribeActual(SingleObserver<? super T>) - Method in class io.reactivex.rxjava3.subjects.SingleSubject
-
- subscribeActual(Observer<? super T>) - Method in class io.reactivex.rxjava3.subjects.UnicastSubject
-
- subscribeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable which subscribes the downstream subscriber on the specified scheduler, making
sure the subscription side-effects happen on that specific thread of the
Scheduler.
- subscribeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
- subscribeOn(Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Asynchronously subscribes
Subscribers to the current
Flowable on the specified
Scheduler
optionally reroutes requests from other threads to the same
Scheduler thread.
- subscribeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Asynchronously subscribes subscribers to this
Maybe on the specified
Scheduler.
- subscribeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Asynchronously subscribes
Observers to the current
Observable on the specified
Scheduler.
- subscribeOn(Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
- subscribeWith(E) - Method in class io.reactivex.rxjava3.core.Completable
-
Subscribes a given
CompletableObserver (subclass) to this
Completable and returns the given
CompletableObserver as is.
- subscribeWith(E) - Method in class io.reactivex.rxjava3.core.Flowable
-
Subscribes a given
Subscriber (subclass) to this
Flowable and returns the given
Subscriber as is.
- subscribeWith(E) - Method in class io.reactivex.rxjava3.core.Maybe
-
Subscribes a given
MaybeObserver (subclass) to this
Maybe and returns the given
MaybeObserver as is.
- subscribeWith(E) - Method in class io.reactivex.rxjava3.core.Observable
-
Subscribes a given
Observer (subclass) to the current
Observable and returns the given
Observer instance as is.
- subscribeWith(E) - Method in class io.reactivex.rxjava3.core.Single
-
Subscribes a given
SingleObserver (subclass) to this
Single and returns the given
SingleObserver as is.
- Supplier<T> - Interface in io.reactivex.rxjava3.functions
-
A functional interface (callback) that provides a single value or
throws an exception.
- switchIfEmpty(Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by the current
Flowable or the items of an alternate
Publisher if the current
Flowable is empty.
- switchIfEmpty(MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that emits the items emitted by the current
Maybe or the items of an alternate
MaybeSource if the current
Maybe is empty.
- switchIfEmpty(SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Single that emits the items emitted by the current
Maybe or the item of an alternate
SingleSource if the current
Maybe is empty.
- switchIfEmpty(ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by the current
Observable or the items of an alternate
ObservableSource if the current
Observable is empty.
- switchMap(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable by applying a function that you supply to each item emitted by the current
Flowable that returns a
Publisher, and then emitting the items emitted by the most recently emitted
of these
Publishers.
- switchMap(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable by applying a function that you supply to each item emitted by the current
Flowable that returns a
Publisher, and then emitting the items emitted by the most recently emitted
of these
Publishers.
- switchMap(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns an
ObservableSource, and then emitting the items emitted by the most recently emitted
of these
ObservableSources.
- switchMap(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns an
ObservableSource, and then emitting the items emitted by the most recently emitted
of these
ObservableSources.
- switchMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream values into
CompletableSources, subscribes to the newer one while
disposing the subscription to the previous
CompletableSource, thus keeping at most one
active
CompletableSource running.
- switchMapCompletable(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the items of the current
Observable into
CompletableSources, subscribes to the newer one while
disposing the subscription to the previous
CompletableSource, thus keeping at most one
active
CompletableSource running.
- switchMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream values into
CompletableSources, subscribes to the newer one while
disposing the subscription to the previous
CompletableSource, thus keeping at most one
active
CompletableSource running and delaying any main or inner errors until all
of them terminate.
- switchMapCompletableDelayError(Function<? super T, ? extends CompletableSource>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream values into
CompletableSources, subscribes to the newer one while
disposing the subscription to the previous
CompletableSource, thus keeping at most one
active
CompletableSource running and delaying any main or inner errors until all
of them terminate.
- switchMapDelayError(Function<? super T, ? extends Publisher<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable by applying a function that you supply to each item emitted by the current
Flowable that returns a
Publisher, and then emitting the items emitted by the most recently emitted
of these
Publishers and delays any error until all
Publishers terminate.
- switchMapDelayError(Function<? super T, ? extends Publisher<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a new
Flowable by applying a function that you supply to each item emitted by the current
Flowable that returns a
Publisher, and then emitting the items emitted by the most recently emitted
of these
Publishers and delays any error until all
Publishers terminate.
- switchMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns an
ObservableSource, and then emitting the items emitted by the most recently emitted
of these
ObservableSources and delays any error until all
ObservableSources terminate.
- switchMapDelayError(Function<? super T, ? extends ObservableSource<? extends R>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns an
ObservableSource, and then emitting the items emitted by the most recently emitted
of these
ObservableSources and delays any error until all
ObservableSources terminate.
- switchMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available while failing immediately if this
Flowable or any of the
active inner
MaybeSources fail.
- switchMapMaybe(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the items of the current
Observable into
MaybeSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available while failing immediately if the current
Observable or any of the
active inner
MaybeSources fail.
- switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
MaybeSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available, delaying errors from this
Flowable or the inner
MaybeSources until all terminate.
- switchMapMaybeDelayError(Function<? super T, ? extends MaybeSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Maps the upstream items into
MaybeSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one if
available, delaying errors from the current
Observable or the inner
MaybeSources until all terminate.
- switchMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one
while failing immediately if this
Flowable or any of the
active inner
SingleSources fail.
- switchMapSingle(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns a
SingleSource, and then emitting the item emitted by the most recently emitted
of these
SingleSources.
- switchMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Maps the upstream items into
SingleSources and switches (subscribes) to the newer ones
while disposing the older ones (and ignoring their signals) and emits the latest success value of the current one,
delaying errors from this
Flowable or the inner
SingleSources until all terminate.
- switchMapSingleDelayError(Function<? super T, ? extends SingleSource<? extends R>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a new
Observable by applying a function that you supply to each item emitted by the current
Observable that returns a
SingleSource, and then emitting the item emitted by the most recently emitted
of these
SingleSources and delays any error until all
SingleSources terminate.
- switchOnNext(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Switches between
CompletableSources emitted by the source
Publisher whenever
a new
CompletableSource is emitted, disposing the previously running
CompletableSource,
exposing the setup as a
Completable sequence.
- switchOnNext(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Converts a
Publisher that emits
Publishers into a
Publisher that emits the items emitted by the
most recently emitted of those
Publishers.
- switchOnNext(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Converts a
Publisher that emits
Publishers into a
Publisher that emits the items emitted by the
most recently emitted of those
Publishers.
- switchOnNext(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Switches between
MaybeSources emitted by the source
Publisher whenever
a new
MaybeSource is emitted, disposing the previously running
MaybeSource,
exposing the success items as a
Flowable sequence.
- switchOnNext(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Converts an
ObservableSource that emits
ObservableSources into an
Observable that emits the items emitted by the
most recently emitted of those
ObservableSources.
- switchOnNext(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Converts an
ObservableSource that emits
ObservableSources into an
Observable that emits the items emitted by the
most recently emitted of those
ObservableSources.
- switchOnNext(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Switches between
SingleSources emitted by the source
Publisher whenever
a new
SingleSource is emitted, disposing the previously running
SingleSource,
exposing the success items as a
Flowable sequence.
- switchOnNextDelayError(Publisher<? extends CompletableSource>) - Static method in class io.reactivex.rxjava3.core.Completable
-
Switches between
CompletableSources emitted by the source
Publisher whenever
a new
CompletableSource is emitted, disposing the previously running
CompletableSource,
exposing the setup as a
Completable sequence and delaying all errors from
all of them until all terminate.
- switchOnNextDelayError(Publisher<? extends Publisher<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Converts a
Publisher that emits
Publishers into a
Publisher that emits the items emitted by the
most recently emitted of those
Publishers and delays any exception until all
Publishers terminate.
- switchOnNextDelayError(Publisher<? extends Publisher<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Converts a
Publisher that emits
Publishers into a
Publisher that emits the items emitted by the
most recently emitted of those
Publishers and delays any exception until all
Publishers terminate.
- switchOnNextDelayError(Publisher<? extends MaybeSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Switches between
MaybeSources emitted by the source
Publisher whenever
a new
MaybeSource is emitted, disposing the previously running
MaybeSource,
exposing the success items as a
Flowable sequence and delaying all errors from
all of them until all terminate.
- switchOnNextDelayError(ObservableSource<? extends ObservableSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Observable
-
Converts an
ObservableSource that emits
ObservableSources into an
Observable that emits the items emitted by the
most recently emitted of those
ObservableSources and delays any exception until all
ObservableSources terminate.
- switchOnNextDelayError(ObservableSource<? extends ObservableSource<? extends T>>, int) - Static method in class io.reactivex.rxjava3.core.Observable
-
Converts an
ObservableSource that emits
ObservableSources into an
Observable that emits the items emitted by the
most recently emitted of those
ObservableSources and delays any exception until all
ObservableSources terminate.
- switchOnNextDelayError(Publisher<? extends SingleSource<? extends T>>) - Static method in class io.reactivex.rxjava3.core.Single
-
Switches between
SingleSources emitted by the source
Publisher whenever
a new
SingleSource is emitted, disposing the previously running
SingleSource,
exposing the success items as a
Flowable sequence and delaying all errors from
all of them until all terminate.
- tag - Variable in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
The optional tag associated with this test consumer.
- take(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits only the first count items emitted by the current Flowable.
- take(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits those items emitted by source
Publisher before a specified time runs
out.
- take(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits those items emitted by source
Publisher before a specified time (on a
specified
Scheduler) runs out.
- take(long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits only the first count items emitted by the current Observable.
- take(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits those items emitted by the current Observable before a specified time runs
out.
- take(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits those items emitted by the current
Observable before a specified time (on a
specified
Scheduler) runs out.
- takeLast(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits at most the last count items emitted by the current Flowable.
- takeLast(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits at most a specified number of items from the current Flowable that were
emitted in a specified window of time before the current Flowable completed.
- takeLast(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits at most a specified number of items from the current
Flowable that were
emitted in a specified window of time before the current
Flowable completed, where the timing information is
provided by a given
Scheduler.
- takeLast(long, long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits at most a specified number of items from the current
Flowable that were
emitted in a specified window of time before the current
Flowable completed, where the timing information is
provided by a given
Scheduler.
- takeLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items from the current Flowable that were emitted in a specified
window of time before the current Flowable completed.
- takeLast(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits the items from the current Flowable that were emitted in a specified
window of time before the current Flowable completed.
- takeLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items from the current
Flowable that were emitted in a specified
window of time before the current
Flowable completed, where the timing information is provided by a specified
Scheduler.
- takeLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items from the current
Flowable that were emitted in a specified
window of time before the current
Flowable completed, where the timing information is provided by a specified
Scheduler.
- takeLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items from the current
Flowable that were emitted in a specified
window of time before the current
Flowable completed, where the timing information is provided by a specified
Scheduler.
- takeLast(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits at most the last count items emitted by the current Observable.
- takeLast(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits at most a specified number of items from the current Observable that were
emitted in a specified window of time before the current Observable completed.
- takeLast(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits at most a specified number of items from the current
Observable that were
emitted in a specified window of time before the current
Observable completed, where the timing information is
provided by a given
Scheduler.
- takeLast(long, long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits at most a specified number of items from the current
Observable that were
emitted in a specified window of time before the current
Observable completed, where the timing information is
provided by a given
Scheduler.
- takeLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items from the current Observable that were emitted in a specified
window of time before the current Observable completed.
- takeLast(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits the items from the current Observable that were emitted in a specified
window of time before the current Observable completed.
- takeLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items from the current
Observable that were emitted in a specified
window of time before the current
Observable completed, where the timing information is provided by a specified
Scheduler.
- takeLast(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items from the current
Observable that were emitted in a specified
window of time before the current
Observable completed, where the timing information is provided by a specified
Scheduler.
- takeLast(long, TimeUnit, Scheduler, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items from the current
Observable that were emitted in a specified
window of time before the current
Observable completed, where the timing information is provided by a specified
Scheduler.
- takeUntil(CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Terminates the downstream if this or the other Completable
terminates (wins the termination race) while disposing the connection to the losing source.
- takeUntil(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits items emitted by the current Flowable, checks the specified predicate
for each item, and then completes when the condition is satisfied.
- takeUntil(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits the items emitted by the current
Flowable until a second
Publisher
emits an item.
- takeUntil(MaybeSource<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that emits the items emitted by the current
Maybe until a second
MaybeSource
emits an item.
- takeUntil(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that emits the item emitted by the current
Maybe until a second
Publisher
emits an item.
- takeUntil(ObservableSource<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits the items emitted by the current
Observable until a second
ObservableSource
emits an item.
- takeUntil(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits items emitted by the current Observable, checks the specified predicate
for each item, and then completes when the condition is satisfied.
- takeUntil(CompletableSource) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Single that emits the item emitted by the current
Single until a
CompletableSource terminates.
- takeUntil(Publisher<E>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Single that emits the item emitted by the current
Single until a
Publisher emits an item or completes.
- takeUntil(SingleSource<? extends E>) - Method in class io.reactivex.rxjava3.core.Single
-
Returns a Single that emits the item emitted by the current Single until a second Single emits an item.
- takeWhile(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits items emitted by the current Flowable so long as each item satisfied a
specified condition, and then completes as soon as this condition is not satisfied.
- takeWhile(Predicate<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits items emitted by the current Observable so long as each item satisfied a
specified condition, and then completes as soon as this condition is not satisfied.
- test() - Method in class io.reactivex.rxjava3.core.Completable
-
Creates a
TestObserver and subscribes
it to this
Completable.
- test(boolean) - Method in class io.reactivex.rxjava3.core.Completable
-
Creates a
TestObserver optionally in cancelled state, then subscribes it to this
Completable.
- test() - Method in class io.reactivex.rxjava3.core.Flowable
-
- test(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Creates a
TestSubscriber with the given initial request amount and subscribes
it to this
Flowable.
- test(long, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Creates a
TestSubscriber with the given initial request amount,
optionally cancels it before the subscription and subscribes
it to this
Flowable.
- test() - Method in class io.reactivex.rxjava3.core.Maybe
-
- test(boolean) - Method in class io.reactivex.rxjava3.core.Maybe
-
Creates a
TestObserver optionally in cancelled state, then subscribes it to this
Maybe.
- test() - Method in class io.reactivex.rxjava3.core.Observable
-
Creates a
TestObserver and subscribes it to the current
Observable.
- test(boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Creates a
TestObserver, optionally disposes it and then subscribes
it to the current
Observable.
- test() - Method in class io.reactivex.rxjava3.core.Single
-
- test(boolean) - Method in class io.reactivex.rxjava3.core.Single
-
Creates a
TestObserver optionally in cancelled state, then subscribes it to this
Single.
- test(T1, T2) - Method in interface io.reactivex.rxjava3.functions.BiPredicate
-
Test the given input values and return a boolean.
- test(T) - Method in interface io.reactivex.rxjava3.functions.Predicate
-
Test the given input value and return a boolean.
- TestObserver<T> - Class in io.reactivex.rxjava3.observers
-
- TestObserver() - Constructor for class io.reactivex.rxjava3.observers.TestObserver
-
Constructs a non-forwarding TestObserver.
- TestObserver(Observer<? super T>) - Constructor for class io.reactivex.rxjava3.observers.TestObserver
-
Constructs a forwarding TestObserver.
- TestScheduler - Class in io.reactivex.rxjava3.schedulers
-
A special, non thread-safe scheduler for testing operators that require
a scheduler without introducing real concurrency and allows manually advancing
a virtual time.
- TestScheduler() - Constructor for class io.reactivex.rxjava3.schedulers.TestScheduler
-
Creates a new TestScheduler with initial virtual time of zero.
- TestScheduler(long, TimeUnit) - Constructor for class io.reactivex.rxjava3.schedulers.TestScheduler
-
Creates a new TestScheduler with the specified initial virtual time.
- TestSubscriber<T> - Class in io.reactivex.rxjava3.subscribers
-
A
Subscriber implementation that records events and allows making assertions about them.
- TestSubscriber() - Constructor for class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Constructs a non-forwarding
TestSubscriber with an initial request value of
Long.MAX_VALUE.
- TestSubscriber(long) - Constructor for class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Constructs a non-forwarding TestSubscriber with the specified initial request value.
- TestSubscriber(Subscriber<? super T>) - Constructor for class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Constructs a forwarding
TestSubscriber but leaves the requesting to the wrapped
Subscriber.
- TestSubscriber(Subscriber<? super T>, long) - Constructor for class io.reactivex.rxjava3.subscribers.TestSubscriber
-
Constructs a forwarding
TestSubscriber with the specified initial request amount
and an actual
Subscriber to forward events to.
- throttleFirst(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits only the first item emitted by the current Flowable during sequential
time windows of a specified duration.
- throttleFirst(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits only the first item emitted by the current
Flowable during sequential
time windows of a specified duration, where the windows are managed by a specified
Scheduler.
- throttleFirst(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits only the first item emitted by the current Observable during sequential
time windows of a specified duration.
- throttleFirst(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits only the first item emitted by the current
Observable during sequential
time windows of a specified duration, where the windows are managed by a specified
Scheduler.
- throttleLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits only the last item emitted by the current Flowable during sequential
time windows of a specified duration.
- throttleLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits only the last item emitted by the current
Flowable during sequential
time windows of a specified duration, where the duration is governed by a specified
Scheduler.
- throttleLast(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits only the last item emitted by the current Observable during sequential
time windows of a specified duration.
- throttleLast(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits only the last item emitted by the current
Observable during sequential
time windows of a specified duration, where the duration is governed by a specified
Scheduler.
- throttleLatest(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
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.
- throttleLatest(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
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.
- throttleLatest(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
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.
- throttleLatest(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
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.
- throttleLatest(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Throttles items from the current Observable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them.
- throttleLatest(long, TimeUnit, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Throttles items from the current Observable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them.
- throttleLatest(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Throttles items from the current Observable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them.
- throttleLatest(long, TimeUnit, Scheduler, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Throttles items from the current Observable by first emitting the next
item from upstream, then periodically emitting the latest item (if any) when
the specified timeout elapses between them.
- throttleWithTimeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable, except that it drops items emitted by the
current Flowable that are followed by newer items before a timeout value expires.
- throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, except that it drops items emitted by the
current
Flowable that are followed by newer items before a timeout value expires on a specified
Scheduler.
- throttleWithTimeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable, except that it drops items emitted by the
current Observable that are followed by newer items before a timeout value expires.
- throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, except that it drops items emitted by the
current
Observable that are followed by newer items before a timeout value expires on a specified
Scheduler.
- throwIfFatal(Throwable) - Static method in class io.reactivex.rxjava3.exceptions.Exceptions
-
Throws a particular Throwable only if it belongs to a set of "fatal" error varieties.
- time() - Method in class io.reactivex.rxjava3.schedulers.Timed
-
Returns the time value.
- time(TimeUnit) - Method in class io.reactivex.rxjava3.schedulers.Timed
-
Returns the contained time value in the time unit specified.
- Timed<T> - Class in io.reactivex.rxjava3.schedulers
-
Holds onto a value along with time information.
- Timed(T, long, TimeUnit) - Constructor for class io.reactivex.rxjava3.schedulers.Timed
-
Constructs a Timed instance with the given value and time information.
- timeInterval() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
current Flowable.
- timeInterval(Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits records of the time interval between consecutive items emitted by the
current
Flowable, where this interval is computed on a specified
Scheduler.
- timeInterval(TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits records of the time interval between consecutive items emitted by the
current Flowable.
- timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits records of the time interval between consecutive items emitted by the
current
Flowable, where this interval is computed on a specified
Scheduler.
- timeInterval() - Method in class io.reactivex.rxjava3.core.Maybe
-
Measures the time (in milliseconds) between the subscription and success item emission
of the current
Maybe and signals it as a tuple (
Timed)
success value.
- timeInterval(Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Measures the time (in milliseconds) between the subscription and success item emission
of the current
Maybe and signals it as a tuple (
Timed)
success value.
- timeInterval(TimeUnit) - Method in class io.reactivex.rxjava3.core.Maybe
-
Measures the time between the subscription and success item emission
of the current
Maybe and signals it as a tuple (
Timed)
success value.
- timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Measures the time between the subscription and success item emission
of the current
Maybe and signals it as a tuple (
Timed)
success value.
- timeInterval() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits records of the time interval between consecutive items emitted by the
current Observable.
- timeInterval(Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits records of the time interval between consecutive items emitted by the
current
Observable, where this interval is computed on a specified
Scheduler.
- timeInterval(TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits records of the time interval between consecutive items emitted by the
current Observable.
- timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits records of the time interval between consecutive items emitted by the
current
Observable, where this interval is computed on a specified
Scheduler.
- timeInterval() - Method in class io.reactivex.rxjava3.core.Single
-
Measures the time (in milliseconds) between the subscription and success item emission
of the current
Single and signals it as a tuple (
Timed)
success value.
- timeInterval(Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Measures the time (in milliseconds) between the subscription and success item emission
of the current
Single and signals it as a tuple (
Timed)
success value.
- timeInterval(TimeUnit) - Method in class io.reactivex.rxjava3.core.Single
-
Measures the time between the subscription and success item emission
of the current
Single and signals it as a tuple (
Timed)
success value.
- timeInterval(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Measures the time between the subscription and success item emission
of the current
Single and signals it as a tuple (
Timed)
success value.
- timeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that runs this
Completable and emits a
TimeoutException in case
this
Completable doesn't complete within the given time.
- timeout(long, TimeUnit, CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that runs this
Completable and switches to the other
CompletableSource
in case this
Completable doesn't complete within the given time.
- timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Completable
-
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.
- timeout(long, TimeUnit, Scheduler, CompletableSource) - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable that runs this
Completable and switches to the other
CompletableSource
in case this
Completable doesn't complete within the given time while "waiting" on
the specified
Scheduler.
- timeout(Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, but notifies
Subscribers of a
TimeoutException if an item emitted by the current
Flowable doesn't arrive within a window of
time after the emission of the previous item, where that period of time is measured by a
Publisher that
is a function of the previous item.
- timeout(Function<? super T, ? extends Publisher<V>>, Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, but that switches to a fallback
Publisher if
an item emitted by the current
Flowable doesn't arrive within a window of time after the emission of the
previous item, where that period of time is measured by a
Publisher that is a function of the previous
item.
- timeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that mirrors the current Flowable but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, Scheduler, Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable but applies a timeout policy for each emitted
item using a specified
Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable but applies a timeout policy for each emitted
item, where this policy is governed by a specified
Scheduler.
- timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, but notifies
Subscribers of a
TimeoutException if either the first item emitted by the current
Flowable or any subsequent item
doesn't arrive within time windows defined by other
Publishers.
- timeout(Publisher<U>, Function<? super T, ? extends Publisher<V>>, Publisher<? extends T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that mirrors the current
Flowable, but switches to a fallback
Publisher if either
the first item emitted by the current
Flowable or any subsequent item doesn't arrive within time windows
defined by other
Publishers.
- timeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that mirrors the current Maybe but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that mirrors the current Maybe but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, Scheduler, MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that mirrors the current
Maybe but applies a timeout policy for each emitted
item using a specified
Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that mirrors the current
Maybe but applies a timeout policy for each emitted
item, where this policy is governed on a specified
Scheduler.
- timeout(MaybeSource<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
- timeout(MaybeSource<U>, MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
If the current
Maybe didn't signal an event before the
timeoutIndicator MaybeSource signals,
the current
Maybe is disposed and the
fallback MaybeSource subscribed to
as a continuation.
- timeout(Publisher<U>) - Method in class io.reactivex.rxjava3.core.Maybe
-
If the current
Maybe source didn't signal an event before the
timeoutIndicator Publisher signals, a
TimeoutException is signaled instead.
- timeout(Publisher<U>, MaybeSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Maybe
-
If the current
Maybe didn't signal an event before the
timeoutIndicator Publisher signals,
the current
Maybe is disposed and the
fallback MaybeSource subscribed to
as a continuation.
- timeout(Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, but notifies observers of a
TimeoutException if an item emitted by the current
Observable doesn't arrive within a window of
time after the emission of the previous item, where that period of time is measured by an
ObservableSource that
is a function of the previous item.
- timeout(Function<? super T, ? extends ObservableSource<V>>, ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, but that switches to a fallback
ObservableSource if
an item emitted by the current
Observable doesn't arrive within a window of time after the emission of the
previous item, where that period of time is measured by an
ObservableSource that is a function of the previous
item.
- timeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that mirrors the current Observable but applies a timeout policy for each emitted
item.
- timeout(long, TimeUnit, Scheduler, ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable but applies a timeout policy for each emitted
item using a specified
Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable but applies a timeout policy for each emitted
item, where this policy is governed on a specified
Scheduler.
- timeout(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, but notifies observers of a
TimeoutException if either the first item emitted by the current
Observable or any subsequent item
doesn't arrive within time windows defined by indicator
ObservableSources.
- timeout(ObservableSource<U>, Function<? super T, ? extends ObservableSource<V>>, ObservableSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that mirrors the current
Observable, but switches to a fallback
ObservableSource if either
the first item emitted by the current
Observable or any subsequent item doesn't arrive within time windows
defined by indicator
ObservableSources.
- timeout(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Single
-
Signals a
TimeoutException if the current
Single doesn't signal a success value within the
specified timeout window.
- timeout(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Signals a
TimeoutException if the current
Single doesn't signal a success value within the
specified timeout window.
- timeout(long, TimeUnit, Scheduler, SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Runs the current
Single and if it doesn't signal within the specified timeout window, it is
disposed and the other
SingleSource subscribed to.
- timeout(long, TimeUnit, SingleSource<? extends T>) - Method in class io.reactivex.rxjava3.core.Single
-
Runs the current
Single and if it doesn't signal within the specified timeout window, it is
disposed and the other
SingleSource subscribed to.
- timeout - Variable in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Indicates that one of the awaitX method has timed out.
- timer(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a Completable instance that fires its onComplete event after the given delay elapsed.
- timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Completable instance that fires its
onComplete event after the given delay elapsed
by using the supplied
Scheduler.
- timer(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits 0L after a specified delay, and then completes.
- timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits
0L after a specified delay, on a specified
Scheduler, and then
completes.
- timer(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Returns a Maybe that emits 0L after a specified delay.
- timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Maybe that emits
0L after a specified delay on a specified
Scheduler.
- timer(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits 0L after a specified delay, and then completes.
- timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits
0L after a specified delay, on a specified
Scheduler, and then
completes.
- timer(long, TimeUnit) - Static method in class io.reactivex.rxjava3.core.Single
-
Signals success with 0L value after the given delay when a
SingleObserver subscribes.
- timer(long, TimeUnit, Scheduler) - Static method in class io.reactivex.rxjava3.core.Single
-
- timestamp() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits each item emitted by the current
Flowable, wrapped in a
Timed object.
- timestamp(Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits each item emitted by the current
Flowable, wrapped in a
Timed object whose timestamps are provided by a specified
Scheduler.
- timestamp(TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits each item emitted by the current
Flowable, wrapped in a
Timed object.
- timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits each item emitted by the current
Flowable, wrapped in a
Timed object whose timestamps are provided by a specified
Scheduler.
- timestamp() - Method in class io.reactivex.rxjava3.core.Maybe
-
Combines the success value from the current
Maybe with the current time (in milliseconds) of
its reception, using the
computation Scheduler as time source,
then signals them as a
Timed instance.
- timestamp(Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Combines the success value from the current
Maybe with the current time (in milliseconds) of
its reception, using the given
Scheduler as time source,
then signals them as a
Timed instance.
- timestamp(TimeUnit) - Method in class io.reactivex.rxjava3.core.Maybe
-
Combines the success value from the current
Maybe with the current time of
its reception, using the
computation Scheduler as time source,
then signals it as a
Timed instance.
- timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Maybe
-
Combines the success value from the current
Maybe with the current time of
its reception, using the given
Scheduler as time source,
then signals it as a
Timed instance.
- timestamp() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits each item emitted by the current
Observable, wrapped in a
Timed object.
- timestamp(Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits each item emitted by the current
Observable, wrapped in a
Timed object whose timestamps are provided by a specified
Scheduler.
- timestamp(TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits each item emitted by the current
Observable, wrapped in a
Timed object.
- timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits each item emitted by the current
Observable, wrapped in a
Timed object whose timestamps are provided by a specified
Scheduler.
- timestamp() - Method in class io.reactivex.rxjava3.core.Single
-
Combines the success value from the current
Single with the current time (in milliseconds) of
its reception, using the
computation Scheduler as time source,
then signals them as a
Timed instance.
- timestamp(Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Combines the success value from the current
Single with the current time (in milliseconds) of
its reception, using the given
Scheduler as time source,
then signals them as a
Timed instance.
- timestamp(TimeUnit) - Method in class io.reactivex.rxjava3.core.Single
-
Combines the success value from the current
Single with the current time of
its reception, using the
computation Scheduler as time source,
then signals it as a
Timed instance.
- timestamp(TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Single
-
Combines the success value from the current
Single with the current time of
its reception, using the given
Scheduler as time source,
then signals it as a
Timed instance.
- to(CompletableConverter<? extends R>) - Method in class io.reactivex.rxjava3.core.Completable
-
Calls the specified
CompletableConverter function during assembly time and returns its resulting value.
- to(FlowableConverter<T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Calls the specified converter function during assembly time and returns its resulting value.
- to(MaybeConverter<T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Maybe
-
Calls the specified converter function during assembly time and returns its resulting value.
- to(ObservableConverter<T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Calls the specified converter function during assembly time and returns its resulting value.
- to(SingleConverter<T, ? extends R>) - Method in class io.reactivex.rxjava3.core.Single
-
Calls the specified converter function during assembly time and returns its resulting value.
- to(ParallelFlowableConverter<T, R>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Calls the specified converter function during assembly time and returns its resulting value.
- toAutoCloseable(Disposable) - Static method in interface io.reactivex.rxjava3.disposables.Disposable
-
Construct an
AutoCloseable by wrapping a
Disposable that is
disposed when the returned
AutoCloseable is closed.
- toCompletionStage(T) - Method in class io.reactivex.rxjava3.core.Completable
-
Signals the given default item when the upstream completes or signals the upstream error via
a
CompletionStage.
- toCompletionStage() - Method in class io.reactivex.rxjava3.core.Maybe
-
- toCompletionStage(T) - Method in class io.reactivex.rxjava3.core.Maybe
-
Signals the upstream success item (or the default item if the upstream is empty) via
a
CompletionStage.
- toCompletionStage() - Method in class io.reactivex.rxjava3.core.Single
-
- toFlowable() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Flowable which when subscribed to subscribes to this
Completable and
relays the terminal events to the downstream
Subscriber.
- toFlowable() - Method in class io.reactivex.rxjava3.core.Maybe
-
Converts this
Maybe into a backpressure-aware
Flowable instance composing cancellation
through.
- toFlowable(BackpressureStrategy) - Method in class io.reactivex.rxjava3.core.Observable
-
Converts the current
Observable into a
Flowable by applying the specified backpressure strategy.
- toFlowable() - Method in class io.reactivex.rxjava3.core.Single
-
- toFuture() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns a
Future representing the termination of the current
Completable
via a
null value.
- toFuture() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Future representing the only value emitted by this
Flowable.
- toFuture() - Method in class io.reactivex.rxjava3.core.Maybe
-
Returns a
Future representing the single value emitted by the current
Maybe
or
null if the current
Maybe is empty.
- toFuture() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Future representing the only value emitted by the current
Observable.
- toFuture() - Method in class io.reactivex.rxjava3.core.Single
-
Returns a
Future representing the single value emitted by this
Single.
- toList() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single item, a list composed of all the items emitted by the
finite upstream source
Publisher.
- toList(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single item, a list composed of all the items emitted by the
finite source
Publisher.
- toList(Supplier<U>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single item, a list composed of all the items emitted by the
finite source
Publisher.
- toList() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single item, a
List composed of all the items emitted by the
current and finite
Observable.
- toList(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single item, a
List composed of all the items emitted by the
current and finite
Observable.
- toList(Supplier<U>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single item, a
Collection (subclass) composed of all the items emitted by the
finite upstream
Observable.
- toMap(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
HashMap containing all items emitted by the finite source
Publisher,
mapped by the keys returned by a specified
keySelector function.
- toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
HashMap containing values corresponding to items emitted by the
finite source
Publisher, mapped by the keys returned by a specified
keySelector function.
- toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<? extends Map<K, V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
Map, returned by a specified
mapFactory function, that
contains keys and values extracted from the items emitted by the finite source
Publisher.
- toMap(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
HashMap containing all items emitted by the
current and finite
Observable, mapped by the keys returned by a specified
keySelector function.
- toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
HashMap containing values corresponding to items emitted by the
current and finite
Observable, mapped by the keys and values returned by the given selector functions.
- toMap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<? extends Map<K, V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
Map (subclass), returned by a specified
mapFactory function, that
contains keys and values extracted from the items, via selector functions, emitted by the current and finite
Observable.
- toMaybe() - Method in class io.reactivex.rxjava3.core.Completable
-
Converts this
Completable into a
Maybe.
- toMaybe() - Method in class io.reactivex.rxjava3.core.Single
-
Converts this
Single into a
Maybe.
- toMultimap(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
HashMap that contains an
ArrayList of items emitted by the
finite source
Publisher keyed by a specified
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
HashMap that contains an
ArrayList of values extracted by a
specified
valueSelector function from items emitted by the finite source
Publisher, keyed by a
specified
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<? extends Map<K, Collection<V>>>, Function<? super K, ? extends Collection<? super V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
Map, returned by a specified
mapFactory function, that
contains a custom collection of values, extracted by a specified
valueSelector function from
items emitted by the finite source
Publisher, and keyed by the
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, Collection<V>>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a single
Map, returned by a specified
mapFactory function, that
contains an
ArrayList of values, extracted by a specified
valueSelector function from items
emitted by the finite source
Publisher and keyed by the
keySelector function.
- toMultimap(Function<? super T, ? extends K>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
HashMap that contains an
ArrayList of items emitted by the
current and finite
Observable keyed by a specified
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
HashMap that contains an
ArrayList of values extracted by a
specified
valueSelector function from items emitted by the current and finite
Observable,
keyed by a specified
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<? extends Map<K, Collection<V>>>, Function<? super K, ? extends Collection<? super V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
Map (subclass), returned by a specified
mapFactory function, that
contains a custom
Collection of values, extracted by a specified
valueSelector function from
items emitted by the current and finite
Observable, and keyed by the
keySelector function.
- toMultimap(Function<? super T, ? extends K>, Function<? super T, ? extends V>, Supplier<Map<K, Collection<V>>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a single
Map (subclass), returned by a specified
mapFactory function, that
contains an
ArrayList of values, extracted by a specified
valueSelector function from items
emitted by the current and finite
Observable and keyed by the
keySelector function.
- toObservable() - Method in class io.reactivex.rxjava3.core.Completable
-
Returns an
Observable which when subscribed to subscribes to this
Completable and
relays the terminal events to the downstream
Observer.
- toObservable() - Method in class io.reactivex.rxjava3.core.Flowable
-
Converts the current
Flowable into a non-backpressured
Observable.
- toObservable() - Method in class io.reactivex.rxjava3.core.Maybe
-
Converts this
Maybe into an
Observable instance composing disposal
through.
- toObservable() - Method in class io.reactivex.rxjava3.core.Single
-
- toSerialized() - Method in class io.reactivex.rxjava3.processors.FlowableProcessor
-
Wraps this FlowableProcessor and serializes the calls to the onSubscribe, onNext, onError and
onComplete methods, making them thread-safe.
- toSerialized() - Method in class io.reactivex.rxjava3.subjects.Subject
-
Wraps this Subject and serializes the calls to the onSubscribe, onNext, onError and
onComplete methods, making them thread-safe.
- toSingle(Supplier<? extends T>) - Method in class io.reactivex.rxjava3.core.Completable
-
Converts this
Completable into a
Single which when this
Completable completes normally,
calls the given
Supplier and emits its returned value through
onSuccess.
- toSingle() - Method in class io.reactivex.rxjava3.core.Maybe
-
- toSingleDefault(T) - Method in class io.reactivex.rxjava3.core.Completable
-
Converts this
Completable into a
Single which when this
Completable completes normally,
emits the given value through
onSuccess.
- toSortedList() - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
List that contains the items emitted by the finite source
Publisher, in a
sorted order.
- toSortedList(Comparator<? super T>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
List that contains the items emitted by the finite source
Publisher, in a
sorted order based on a specified comparison function.
- toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
List that contains the items emitted by the finite source
Publisher, in a
sorted order based on a specified comparison function.
- toSortedList(int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Single that emits a
List that contains the items emitted by the finite source
Publisher, in a
sorted order.
- toSortedList() - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
List that contains the items emitted by the current and finite
Observable, in a
sorted order.
- toSortedList(Comparator<? super T>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
List that contains the items emitted by the current and finite
Observable, in a
sorted order based on a specified comparison function.
- toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
List that contains the items emitted by the current and finite
Observable, in a
sorted order based on a specified comparison function.
- toSortedList(int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns a
Single that emits a
List that contains the items emitted by the current and finite
Observable, in a
sorted order.
- toSortedList(Comparator<? super T>) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Sorts the 'rails' according to the comparator and returns a full sorted
List as a
Flowable.
- toSortedList(Comparator<? super T>, int) - Method in class io.reactivex.rxjava3.parallel.ParallelFlowable
-
Sorts the 'rails' according to the comparator and returns a full sorted
List as a
Flowable.
- toString() - Method in class io.reactivex.rxjava3.core.Notification
-
- toString() - Method in class io.reactivex.rxjava3.schedulers.Timed
-
- TRAMPOLINE - Static variable in annotation type io.reactivex.rxjava3.annotations.SchedulerSupport
-
- trampoline() - Static method in class io.reactivex.rxjava3.schedulers.Schedulers
-
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.
- triggerActions() - Method in class io.reactivex.rxjava3.schedulers.TestScheduler
-
Triggers any actions that have not yet been triggered and that are scheduled to be triggered at or
before this Scheduler's present time.
- tryOnError(Throwable) - Method in interface io.reactivex.rxjava3.core.CompletableEmitter
-
Attempts to emit the specified
Throwable error if the downstream
hasn't cancelled the sequence or is otherwise terminated, returning false
if the emission is not allowed to happen due to lifecycle restrictions.
- tryOnError(Throwable) - Method in interface io.reactivex.rxjava3.core.FlowableEmitter
-
Attempts to emit the specified
Throwable error if the downstream
hasn't cancelled the sequence or is otherwise terminated, returning false
if the emission is not allowed to happen due to lifecycle restrictions.
- tryOnError(Throwable) - Method in interface io.reactivex.rxjava3.core.MaybeEmitter
-
Attempts to emit the specified
Throwable error if the downstream
hasn't cancelled the sequence or is otherwise terminated, returning false
if the emission is not allowed to happen due to lifecycle restrictions.
- tryOnError(Throwable) - Method in interface io.reactivex.rxjava3.core.ObservableEmitter
-
Attempts to emit the specified
Throwable error if the downstream
hasn't cancelled the sequence or is otherwise terminated, returning false
if the emission is not allowed to happen due to lifecycle restrictions.
- tryOnError(Throwable) - Method in interface io.reactivex.rxjava3.core.SingleEmitter
-
Attempts to emit the specified
Throwable error if the downstream
hasn't cancelled the sequence or is otherwise terminated, returning false
if the emission is not allowed to happen due to lifecycle restrictions.
- when(Function<Flowable<Flowable<Completable>>, Completable>) - Method in class io.reactivex.rxjava3.core.Scheduler
-
Allows the use of operators for controlling the timing around when
actions scheduled on workers are actually done.
- window(long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, long, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, long, TimeUnit, Scheduler, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, long, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, Scheduler, long) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, Scheduler, long, boolean) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long, TimeUnit, Scheduler, long, boolean, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(Publisher<B>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits non-overlapping windows of items it collects from the current
Flowable
where the boundary of each window is determined by the items emitted from a specified boundary-governing
Publisher.
- window(Publisher<B>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a
Flowable that emits non-overlapping windows of items it collects from the current
Flowable
where the boundary of each window is determined by the items emitted from a specified boundary-governing
Publisher.
- window(Publisher<U>, Function<? super U, ? extends Publisher<V>>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(Publisher<U>, Function<? super U, ? extends Publisher<V>>, int) - Method in class io.reactivex.rxjava3.core.Flowable
-
Returns a Flowable that emits windows of items it collects from the current Flowable.
- window(long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, long, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, long, TimeUnit, Scheduler, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, long, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, Scheduler) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, Scheduler, long) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, Scheduler, long, boolean) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(long, TimeUnit, Scheduler, long, boolean, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(ObservableSource<B>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits non-overlapping windows of items it collects from the current
Observable
where the boundary of each window is determined by the items emitted from a specified boundary-governing
ObservableSource.
- window(ObservableSource<B>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an
Observable that emits non-overlapping windows of items it collects from the current
Observable
where the boundary of each window is determined by the items emitted from a specified boundary-governing
ObservableSource.
- window(ObservableSource<U>, Function<? super U, ? extends ObservableSource<V>>) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- window(ObservableSource<U>, Function<? super U, ? extends ObservableSource<V>>, int) - Method in class io.reactivex.rxjava3.core.Observable
-
Returns an Observable that emits windows of items it collects from the current Observable.
- withLatestFrom(Publisher<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Merges the specified
Publisher into the current
Flowable sequence by using the
resultSelector
function only when the current
Flowable (this instance) emits an item.
- withLatestFrom(Publisher<T1>, Publisher<T2>, Function3<? super T, ? super T1, ? super T2, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Combines the value emission from the current
Flowable with the latest emissions from the
other
Publishers via a function to produce the output item.
- withLatestFrom(Publisher<T1>, Publisher<T2>, Publisher<T3>, Function4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Combines the value emission from the current
Flowable with the latest emissions from the
other
Publishers via a function to produce the output item.
- withLatestFrom(Publisher<T1>, Publisher<T2>, Publisher<T3>, Publisher<T4>, Function5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Combines the value emission from the current
Flowable with the latest emissions from the
other
Publishers via a function to produce the output item.
- withLatestFrom(Publisher<?>[], Function<? super Object[], R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Combines the value emission from the current
Flowable with the latest emissions from the
other
Publishers via a function to produce the output item.
- withLatestFrom(Iterable<? extends Publisher<?>>, Function<? super Object[], R>) - Method in class io.reactivex.rxjava3.core.Flowable
-
Combines the value emission from the current
Flowable with the latest emissions from the
other
Publishers via a function to produce the output item.
- withLatestFrom(ObservableSource<? extends U>, BiFunction<? super T, ? super U, ? extends R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Merges the specified
ObservableSource into the current
Observable sequence by using the
resultSelector
function only when the current
Observable emits an item.
- withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, Function3<? super T, ? super T1, ? super T2, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Combines the value emission from the current
Observable with the latest emissions from the
other
ObservableSources via a function to produce the output item.
- withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, ObservableSource<T3>, Function4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Combines the value emission from the current
Observable with the latest emissions from the
other
ObservableSources via a function to produce the output item.
- withLatestFrom(ObservableSource<T1>, ObservableSource<T2>, ObservableSource<T3>, ObservableSource<T4>, Function5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Combines the value emission from the current
Observable with the latest emissions from the
other
ObservableSources via a function to produce the output item.
- withLatestFrom(ObservableSource<?>[], Function<? super Object[], R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Combines the value emission from the current
Observable with the latest emissions from the
other
ObservableSources via a function to produce the output item.
- withLatestFrom(Iterable<? extends ObservableSource<?>>, Function<? super Object[], R>) - Method in class io.reactivex.rxjava3.core.Observable
-
Combines the value emission from the current
Observable with the latest emissions from the
other
ObservableSources via a function to produce the output item.
- withTag(CharSequence) - Method in class io.reactivex.rxjava3.observers.BaseTestConsumer
-
Set the tag displayed along with an assertion failure's
other state information.
- Worker() - Constructor for class io.reactivex.rxjava3.core.Scheduler.Worker
-
- wrap(CompletableSource) - Static method in class io.reactivex.rxjava3.core.Completable
-
- wrap(MaybeSource<T>) - Static method in class io.reactivex.rxjava3.core.Maybe
-
Wraps a
MaybeSource instance into a new
Maybe instance if not already a
Maybe
instance.
- wrap(ObservableSource<T>) - Static method in class io.reactivex.rxjava3.core.Observable
-
- wrap(SingleSource<T>) - Static method in class io.reactivex.rxjava3.core.Single
-
Wraps a
SingleSource instance into a new
Single instance if not already a
Single
instance.