Uses of Annotation Interface
io.reactivex.rxjava3.annotations.Nullable
Packages that use Nullable
Package
Description
Base reactive classes:
Flowable
, Observable
,
Single
, Maybe
and
Completable
; base reactive consumers;
other common base interfaces.Default implementations for
Disposable
-based resource management
(Disposable
container types) and utility classes to construct
Disposables
from callbacks and other types.Classes supporting the Flowable base reactive class:
ConnectableFlowable
and
GroupedFlowable
.Classes supporting the Observable base reactive class:
ConnectableObservable
and
GroupedObservable
.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.Classes and interfaces for writing advanced operators within and outside RxJava.
Contains the central plugin handler
RxJavaPlugins
class to hook into the lifecycle of the base reactive types and schedulers.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
.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.
-
Uses of Nullable in io.reactivex.rxjava3.core
Fields in io.reactivex.rxjava3.core with annotations of type NullableMethods in io.reactivex.rxjava3.core with annotations of type NullableModifier and TypeMethodDescriptionfinal T
Maybe.blockingGet()
Waits in a blocking fashion until the currentMaybe
signals a success value (which is returned),null
if completed or an exception (which is propagated).Notification.getError()
Returns the containerThrowable
error if this notification is anonError
signal, null otherwise.Notification.getValue()
Returns the contained value if this notification is anonNext
signal, null otherwise.Method parameters in io.reactivex.rxjava3.core with annotations of type NullableModifier and TypeMethodDescriptionfinal @NonNull CompletionStage
<T> Flowable.firstStage
(@NonNull T defaultItem) Signals the first upstream item (or the default item if the upstream is empty) via aCompletionStage
.final @NonNull CompletionStage
<T> Observable.firstStage
(@NonNull T defaultItem) Signals the first upstream item (or the default item if the upstream is empty) via aCompletionStage
.final @NonNull CompletionStage
<T> Signals the last upstream item (or the default item if the upstream is empty) via aCompletionStage
.final @NonNull CompletionStage
<T> Signals the last upstream item (or the default item if the upstream is empty) via aCompletionStage
.Flowable.onBackpressureBuffer
(long capacity, @Nullable Action onOverflow, @NonNull BackpressureOverflowStrategy overflowStrategy) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.Flowable.onBackpressureBuffer
(long capacity, @Nullable Action onOverflow, @NonNull BackpressureOverflowStrategy overflowStrategy, @NonNull Consumer<? super @NonNull T> onDropped) Buffers an optionally unlimited number of items from the currentFlowable
and allows it to emit as fast it can while allowing the downstream to consume the items at its own place.void
CompletableEmitter.setCancellable
(@Nullable Cancellable c) Sets a Cancellable on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
FlowableEmitter.setCancellable
(@Nullable Cancellable c) Sets aCancellable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
MaybeEmitter.setCancellable
(@Nullable Cancellable c) Sets aCancellable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
ObservableEmitter.setCancellable
(@Nullable Cancellable c) Sets aCancellable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
SingleEmitter.setCancellable
(@Nullable Cancellable c) Sets a Cancellable on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
CompletableEmitter.setDisposable
(@Nullable Disposable d) Sets a Disposable on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
FlowableEmitter.setDisposable
(@Nullable Disposable d) Sets a Disposable on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
MaybeEmitter.setDisposable
(@Nullable Disposable d) Sets aDisposable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
ObservableEmitter.setDisposable
(@Nullable Disposable d) Sets aDisposable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.void
SingleEmitter.setDisposable
(@Nullable Disposable d) Sets aDisposable
on this emitter; any previousDisposable
orCancellable
will be disposed/cancelled.final @NonNull CompletionStage
<T> Flowable.singleStage
(@NonNull T defaultItem) Signals the only expected upstream item (or the default item if the upstream is empty) or signalsIllegalArgumentException
if the upstream has more than one item via aCompletionStage
.final @NonNull CompletionStage
<T> Observable.singleStage
(@NonNull T defaultItem) Signals the only expected upstream item (or the default item if the upstream is empty) or signalsIllegalArgumentException
if the upstream has more than one item via aCompletionStage
.private @NonNull Observable
<T> Observable.timeout0
(long timeout, @NonNull TimeUnit unit, @Nullable ObservableSource<? extends @NonNull T> fallback, @NonNull Scheduler scheduler) private <U,
V> @NonNull Observable <T> Observable.timeout0
(@NonNull ObservableSource<U> firstTimeoutIndicator, @NonNull Function<? super @NonNull T, ? extends ObservableSource<V>> itemTimeoutIndicator, @Nullable ObservableSource<? extends @NonNull T> fallback) final @NonNull CompletionStage
<T> Maybe.toCompletionStage
(@NonNull T defaultItem) Signals the upstream success item (or the default item if the upstream is empty) via aCompletionStage
.Constructor parameters in io.reactivex.rxjava3.core with annotations of type NullableModifierConstructorDescriptionprivate
Notification
(@Nullable Object value) Not meant to be implemented externally. -
Uses of Nullable in io.reactivex.rxjava3.disposables
Methods in io.reactivex.rxjava3.disposables with annotations of type NullableModifier and TypeMethodDescriptionSerialDisposable.get()
Returns the currently contained Disposable or null if this container is empty.Method parameters in io.reactivex.rxjava3.disposables with annotations of type NullableModifier and TypeMethodDescription(package private) void
CompositeDisposable.dispose
(@Nullable OpenHashSet<Disposable> set) Dispose the contents of theOpenHashSet
by suppressing non-fatalThrowable
s till the end.boolean
SerialDisposable.replace
(@Nullable Disposable next) 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.boolean
SerialDisposable.set
(@Nullable Disposable next) Atomically: set the next disposable on this container and dispose the previous one (if any) or dispose next if the container has been disposed.Constructor parameters in io.reactivex.rxjava3.disposables with annotations of type NullableModifierConstructorDescriptionSerialDisposable
(@Nullable Disposable initialDisposable) Constructs a SerialDisposable with the given initial Disposable instance. -
Uses of Nullable in io.reactivex.rxjava3.flowables
Methods in io.reactivex.rxjava3.flowables with annotations of type NullableModifier and TypeMethodDescriptionGroupedFlowable.getKey()
Returns the key that identifies the group of items emitted by thisGroupedFlowable
.Constructor parameters in io.reactivex.rxjava3.flowables with annotations of type NullableModifierConstructorDescriptionprotected
GroupedFlowable
(K key) Constructs a GroupedFlowable with the given key. -
Uses of Nullable in io.reactivex.rxjava3.internal.disposables
Methods in io.reactivex.rxjava3.internal.disposables with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.internal.jdk8
Methods in io.reactivex.rxjava3.internal.jdk8 with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.internal.observers
Methods in io.reactivex.rxjava3.internal.observers with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.internal.operators.flowable
Fields in io.reactivex.rxjava3.internal.operators.flowable with annotations of type NullableModifier and TypeFieldDescriptionFlowableCombineLatest.array
FlowableCombineLatest.iterable
(package private) final @Nullable org.reactivestreams.Publisher<?>[]
FlowableWithLatestFromMany.otherArray
FlowableWithLatestFromMany.otherIterable
Methods in io.reactivex.rxjava3.internal.operators.flowable with annotations of type NullableModifier and TypeMethodDescriptionFlowableCombineLatest.CombineLatestCoordinator.poll()
FlowableDistinct.DistinctSubscriber.poll()
FlowableDistinctUntilChanged.DistinctUntilChangedConditionalSubscriber.poll()
FlowableDistinctUntilChanged.DistinctUntilChangedSubscriber.poll()
FlowableDoAfterNext.DoAfterConditionalSubscriber.poll()
FlowableDoAfterNext.DoAfterSubscriber.poll()
FlowableDoFinally.DoFinallyConditionalSubscriber.poll()
FlowableDoFinally.DoFinallySubscriber.poll()
FlowableDoOnEach.DoOnEachConditionalSubscriber.poll()
FlowableDoOnEach.DoOnEachSubscriber.poll()
FlowableFilter.FilterConditionalSubscriber.poll()
FlowableFilter.FilterSubscriber.poll()
FlowableFlatMapCompletable.FlatMapCompletableMainSubscriber.poll()
FlowableFlattenIterable.FlattenIterableSubscriber.poll()
final T
FlowableFromArray.BaseArraySubscription.poll()
final T
FlowableFromIterable.BaseRangeSubscription.poll()
FlowableGroupBy.State.poll()
FlowableIgnoreElements.IgnoreElementsSubscriber.poll()
FlowableMap.MapConditionalSubscriber.poll()
FlowableMap.MapSubscriber.poll()
FlowableObserveOn.ObserveOnConditionalSubscriber.poll()
FlowableObserveOn.ObserveOnSubscriber.poll()
FlowableOnBackpressureBuffer.BackpressureBufferSubscriber.poll()
FlowableRange.BaseRangeSubscription.poll()
FlowableRangeLong.BaseRangeSubscription.poll()
-
Uses of Nullable in io.reactivex.rxjava3.internal.operators.maybe
Methods in io.reactivex.rxjava3.internal.operators.maybe with annotations of type NullableModifier and TypeMethodDescriptionMaybeFlatMapIterableFlowable.FlatMapIterableObserver.poll()
MaybeFlatMapIterableObservable.FlatMapIterableObserver.poll()
MaybeMergeArray.ClqSimpleQueue.poll()
MaybeMergeArray.MergeMaybeObserver.poll()
MaybeMergeArray.MpscFillOnceSimpleQueue.poll()
MaybeMergeArray.SimpleQueueWithConsumerIndex.poll()
-
Uses of Nullable in io.reactivex.rxjava3.internal.operators.observable
Fields in io.reactivex.rxjava3.internal.operators.observable with annotations of type NullableModifier and TypeFieldDescription(package private) final @Nullable ObservableSource<?>[]
ObservableWithLatestFromMany.otherArray
(package private) final @Nullable Iterable
<? extends ObservableSource<?>> ObservableWithLatestFromMany.otherIterable
Methods in io.reactivex.rxjava3.internal.operators.observable with annotations of type NullableModifier and TypeMethodDescriptionObservableDistinct.DistinctObserver.poll()
ObservableDistinctUntilChanged.DistinctUntilChangedObserver.poll()
ObservableDoAfterNext.DoAfterObserver.poll()
ObservableDoFinally.DoFinallyObserver.poll()
ObservableFilter.FilterObserver.poll()
ObservableFlatMapCompletable.FlatMapCompletableMainObserver.poll()
ObservableFromArray.FromArrayDisposable.poll()
ObservableFromIterable.FromIterableDisposable.poll()
ObservableMap.MapObserver.poll()
ObservableObserveOn.ObserveOnObserver.poll()
ObservableRange.RangeDisposable.poll()
ObservableRangeLong.RangeDisposable.poll()
ObservableScalarXMap.ScalarDisposable.poll()
-
Uses of Nullable in io.reactivex.rxjava3.internal.operators.single
Methods in io.reactivex.rxjava3.internal.operators.single with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.internal.queue
Methods in io.reactivex.rxjava3.internal.queue with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.internal.schedulers
Method parameters in io.reactivex.rxjava3.internal.schedulers with annotations of type NullableModifier and TypeMethodDescriptionNewThreadWorker.scheduleActual
(Runnable run, long delayTime, @NonNull TimeUnit unit, @Nullable DisposableContainer parent) Wraps and returns the given runnable into a ScheduledRunnable and schedules it on the underlying ScheduledExecutorService. -
Uses of Nullable in io.reactivex.rxjava3.internal.subscriptions
Methods in io.reactivex.rxjava3.internal.subscriptions with annotations of type Nullable -
Uses of Nullable in io.reactivex.rxjava3.observables
Methods in io.reactivex.rxjava3.observables with annotations of type NullableModifier and TypeMethodDescriptionGroupedObservable.getKey()
Returns the key that identifies the group of items emitted by thisGroupedObservable
.Constructor parameters in io.reactivex.rxjava3.observables with annotations of type NullableModifierConstructorDescriptionprotected
GroupedObservable
(K key) Constructs a GroupedObservable with the given key. -
Uses of Nullable in io.reactivex.rxjava3.observers
Method parameters in io.reactivex.rxjava3.observers with annotations of type NullableModifier and TypeMethodDescriptionBaseTestConsumer.valueAndClass
(@Nullable Object o) Appends the class name to a non-null
value or returns"null"
.final U
BaseTestConsumer.withTag
(@Nullable CharSequence tag) Set the tag displayed along with an assertion failure's other state information. -
Uses of Nullable in io.reactivex.rxjava3.operators
Methods in io.reactivex.rxjava3.operators with annotations of type NullableModifier and TypeMethodDescriptionSpscLinkedArrayQueue.peek()
Returns the next element in this queue without removing it ornull
if this queue is emptySimplePlainQueue.poll()
SimpleQueue.poll()
Tries to dequeue a value (non-null) or returns null if the queue is empty.SpscArrayQueue.poll()
SpscLinkedArrayQueue.poll()
Tries to dequeue a value (non-null) or returns null if the queue is empty. -
Uses of Nullable in io.reactivex.rxjava3.plugins
Fields in io.reactivex.rxjava3.plugins with annotations of type NullableModifier and TypeFieldDescriptionRxJavaPlugins.errorHandler
(package private) static @Nullable BooleanSupplier
RxJavaPlugins.onBeforeBlocking
(package private) static @Nullable Function
<? super Completable, ? extends Completable> RxJavaPlugins.onCompletableAssembly
(package private) static @Nullable BiFunction
<? super Completable, @NonNull ? super CompletableObserver, @NonNull ? extends CompletableObserver> RxJavaPlugins.onCompletableSubscribe
RxJavaPlugins.onComputationHandler
(package private) static @Nullable Function
<? super ConnectableFlowable, ? extends ConnectableFlowable> RxJavaPlugins.onConnectableFlowableAssembly
(package private) static @Nullable Function
<? super ConnectableObservable, ? extends ConnectableObservable> RxJavaPlugins.onConnectableObservableAssembly
RxJavaPlugins.onFlowableAssembly
(package private) static @Nullable BiFunction
<? super Flowable, @NonNull ? super org.reactivestreams.Subscriber, @NonNull ? extends org.reactivestreams.Subscriber> RxJavaPlugins.onFlowableSubscribe
RxJavaPlugins.onInitComputationHandler
RxJavaPlugins.onInitIoHandler
RxJavaPlugins.onInitNewThreadHandler
RxJavaPlugins.onInitSingleHandler
RxJavaPlugins.onIoHandler
RxJavaPlugins.onMaybeAssembly
(package private) static @Nullable BiFunction
<? super Maybe, @NonNull ? super MaybeObserver, @NonNull ? extends MaybeObserver> RxJavaPlugins.onMaybeSubscribe
RxJavaPlugins.onNewThreadHandler
(package private) static @Nullable Function
<? super Observable, ? extends Observable> RxJavaPlugins.onObservableAssembly
(package private) static @Nullable BiFunction
<? super Observable, @NonNull ? super Observer, @NonNull ? extends Observer> RxJavaPlugins.onObservableSubscribe
(package private) static @Nullable Function
<? super ParallelFlowable, ? extends ParallelFlowable> RxJavaPlugins.onParallelAssembly
(package private) static @Nullable BiFunction
<? super ParallelFlowable, @NonNull ? super org.reactivestreams.Subscriber[], @NonNull ? extends org.reactivestreams.Subscriber[]> RxJavaPlugins.onParallelSubscribe
RxJavaPlugins.onScheduleHandler
RxJavaPlugins.onSingleAssembly
RxJavaPlugins.onSingleHandler
(package private) static @Nullable BiFunction
<? super Single, @NonNull ? super SingleObserver, @NonNull ? extends SingleObserver> RxJavaPlugins.onSingleSubscribe
Methods in io.reactivex.rxjava3.plugins with annotations of type NullableModifier and TypeMethodDescriptionRxJavaPlugins.getComputationSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getErrorHandler()
Returns the a hook consumer.RxJavaPlugins.getInitComputationSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitIoSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitNewThreadSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getInitSingleSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getIoSchedulerHandler()
Returns the current hook function.RxJavaPlugins.getNewThreadSchedulerHandler()
Returns the current hook function.static @Nullable BooleanSupplier
RxJavaPlugins.getOnBeforeBlocking()
Returns the current blocking handler or null if no custom handler is set.static @Nullable Function
<? super Completable, ? extends Completable> RxJavaPlugins.getOnCompletableAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super Completable, @NonNull ? super CompletableObserver, @NonNull ? extends CompletableObserver> RxJavaPlugins.getOnCompletableSubscribe()
Returns the current hook function.static @Nullable Function
<? super ConnectableFlowable, ? extends ConnectableFlowable> RxJavaPlugins.getOnConnectableFlowableAssembly()
Returns the current hook function.static @Nullable Function
<? super ConnectableObservable, ? extends ConnectableObservable> RxJavaPlugins.getOnConnectableObservableAssembly()
Returns the current hook function.RxJavaPlugins.getOnFlowableAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super Flowable, @NonNull ? super org.reactivestreams.Subscriber, @NonNull ? extends org.reactivestreams.Subscriber> RxJavaPlugins.getOnFlowableSubscribe()
Returns the current hook function.RxJavaPlugins.getOnMaybeAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super Maybe, @NonNull ? super MaybeObserver, @NonNull ? extends MaybeObserver> RxJavaPlugins.getOnMaybeSubscribe()
Returns the current hook function.static @Nullable Function
<? super Observable, ? extends Observable> RxJavaPlugins.getOnObservableAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super Observable, @NonNull ? super Observer, @NonNull ? extends Observer> RxJavaPlugins.getOnObservableSubscribe()
Returns the current hook function.static @Nullable Function
<? super ParallelFlowable, ? extends ParallelFlowable> RxJavaPlugins.getOnParallelAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super ParallelFlowable, @NonNull ? super org.reactivestreams.Subscriber[], @NonNull ? extends org.reactivestreams.Subscriber[]> RxJavaPlugins.getOnParallelSubscribe()
Returns the current hook function.RxJavaPlugins.getOnSingleAssembly()
Returns the current hook function.static @Nullable BiFunction
<? super Single, @NonNull ? super SingleObserver, @NonNull ? extends SingleObserver> RxJavaPlugins.getOnSingleSubscribe()
Returns the current hook function.RxJavaPlugins.getScheduleHandler()
Returns the current hook function.RxJavaPlugins.getSingleSchedulerHandler()
Returns the current hook function.Method parameters in io.reactivex.rxjava3.plugins with annotations of type NullableModifier and TypeMethodDescriptionstatic void
RxJavaPlugins.setComputationSchedulerHandler
(@Nullable Function<? super Scheduler, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setErrorHandler
(@Nullable Consumer<? super Throwable> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitComputationSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitIoSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitNewThreadSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setInitSingleSchedulerHandler
(@Nullable Function<? super Supplier<Scheduler>, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setIoSchedulerHandler
(@Nullable Function<? super Scheduler, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setNewThreadSchedulerHandler
(@Nullable Function<? super Scheduler, ? extends Scheduler> handler) Sets the specific hook function.static void
RxJavaPlugins.setOnBeforeBlocking
(@Nullable BooleanSupplier handler) 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.static void
RxJavaPlugins.setOnCompletableAssembly
(@Nullable Function<? super Completable, ? extends Completable> onCompletableAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnCompletableSubscribe
(@Nullable BiFunction<? super Completable, @NonNull ? super CompletableObserver, @NonNull ? extends CompletableObserver> onCompletableSubscribe) Sets the specific hook function.static void
RxJavaPlugins.setOnConnectableFlowableAssembly
(@Nullable Function<? super ConnectableFlowable, ? extends ConnectableFlowable> onConnectableFlowableAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnConnectableObservableAssembly
(@Nullable Function<? super ConnectableObservable, ? extends ConnectableObservable> onConnectableObservableAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnFlowableAssembly
(@Nullable Function<? super Flowable, ? extends Flowable> onFlowableAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnFlowableSubscribe
(@Nullable BiFunction<? super Flowable, @NonNull ? super org.reactivestreams.Subscriber, @NonNull ? extends org.reactivestreams.Subscriber> onFlowableSubscribe) Sets the specific hook function.static void
RxJavaPlugins.setOnMaybeAssembly
(@Nullable Function<? super Maybe, ? extends Maybe> onMaybeAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnMaybeSubscribe
(@Nullable BiFunction<? super Maybe, @NonNull MaybeObserver, @NonNull ? extends MaybeObserver> onMaybeSubscribe) Sets the specific hook function.static void
RxJavaPlugins.setOnObservableAssembly
(@Nullable Function<? super Observable, ? extends Observable> onObservableAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnObservableSubscribe
(@Nullable BiFunction<? super Observable, @NonNull ? super Observer, @NonNull ? extends Observer> onObservableSubscribe) Sets the specific hook function.static void
RxJavaPlugins.setOnParallelAssembly
(@Nullable Function<? super ParallelFlowable, ? extends ParallelFlowable> handler) Sets the specific hook function.static void
RxJavaPlugins.setOnParallelSubscribe
(@Nullable BiFunction<? super ParallelFlowable, @NonNull ? super org.reactivestreams.Subscriber[], @NonNull ? extends org.reactivestreams.Subscriber[]> handler) Sets the specific hook function.static void
RxJavaPlugins.setOnSingleAssembly
(@Nullable Function<? super Single, ? extends Single> onSingleAssembly) Sets the specific hook function.static void
RxJavaPlugins.setOnSingleSubscribe
(@Nullable BiFunction<? super Single, @NonNull ? super SingleObserver, @NonNull ? extends SingleObserver> onSingleSubscribe) Sets the specific hook function.static void
RxJavaPlugins.setScheduleHandler
(@Nullable Function<? super Runnable, ? extends Runnable> handler) Sets the specific hook function.static void
RxJavaPlugins.setSingleSchedulerHandler
(@Nullable Function<? super Scheduler, ? extends Scheduler> handler) Sets the specific hook function. -
Uses of Nullable in io.reactivex.rxjava3.processors
Methods in io.reactivex.rxjava3.processors with annotations of type NullableModifier and TypeMethodDescriptionAsyncProcessor.getThrowable()
BehaviorProcessor.getThrowable()
FlowableProcessor.getThrowable()
Returns the error that caused the FlowableProcessor to terminate or null if the FlowableProcessor hasn't terminated yet.PublishProcessor.getThrowable()
ReplayProcessor.getThrowable()
SerializedProcessor.getThrowable()
UnicastProcessor.getThrowable()
AsyncProcessor.getValue()
Returns a single value this processor currently has or null if no such value exists.BehaviorProcessor.getValue()
Returns a single value the BehaviorProcessor currently has or null if no such value exists.ReplayProcessor.ReplayBuffer.getValue()
ReplayProcessor.SizeAndTimeBoundReplayBuffer.getValue()
ReplayProcessor.UnboundedReplayBuffer.getValue()
UnicastProcessor.UnicastQueueSubscription.poll()
-
Uses of Nullable in io.reactivex.rxjava3.subjects
Methods in io.reactivex.rxjava3.subjects with annotations of type NullableModifier and TypeMethodDescriptionBehaviorSubject.getThrowable()
CompletableSubject.getThrowable()
Returns the terminal error if this CompletableSubject has been terminated with an error, null otherwise.MaybeSubject.getThrowable()
Returns the terminal error if this MaybeSubject has been terminated with an error, null otherwise.PublishSubject.getThrowable()
ReplaySubject.getThrowable()
SerializedSubject.getThrowable()
SingleSubject.getThrowable()
Returns the terminal error if this SingleSubject has been terminated with an error, null otherwise.Subject.getThrowable()
Returns the error that caused the Subject to terminate or null if the Subject hasn't terminated yet.UnicastSubject.getThrowable()
AsyncSubject.getValue()
Returns a single value the Subject currently has or null if no such value exists.BehaviorSubject.getValue()
Returns a single value the Subject currently has or null if no such value exists.MaybeSubject.getValue()
Returns the success value if this MaybeSubject was terminated with a success value.ReplaySubject.getValue()
Returns a single value the Subject currently has or null if no such value exists.ReplaySubject.ReplayBuffer.getValue()
ReplaySubject.SizeAndTimeBoundReplayBuffer.getValue()
ReplaySubject.SizeBoundReplayBuffer.getValue()
ReplaySubject.UnboundedReplayBuffer.getValue()
SingleSubject.getValue()
Returns the success value if this SingleSubject was terminated with a success value.UnicastSubject.UnicastQueueDisposable.poll()