Package | Description |
---|---|
rx |
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
|
rx.internal.observers | |
rx.internal.operators |
Operators that allow composing Observables to transform and
manipulate data in an asynchronous, functional and thread-safe manner.
|
rx.internal.producers | |
rx.internal.util | |
rx.observables |
Classes extending the Observable base reactive class, synchronous and
asynchronous event generators.
|
rx.observers |
Default wrappers and implementations for the base reactive consumer classes and interfaces;
utility classes for creating them from callbacks.
|
Modifier and Type | Method and Description |
---|---|
Subscription |
Single.subscribe(Subscriber<? super T> subscriber)
Subscribes to a Single and provides a Subscriber that implements functions to handle the item the Single
emits or any error notification it issues.
|
Subscription |
Observable.subscribe(Subscriber<? super T> subscriber)
Subscribes to an Observable and provides a Subscriber that implements functions to handle the items the
Observable emits and any error or completion notification it issues.
|
<T> void |
Completable.subscribe(Subscriber<T> s)
Subscribes a regular Subscriber to this Completable instance which
will receive only an onError or onComplete event
and handles exceptions thrown by its onXXX methods.
|
Subscription |
Single.unsafeSubscribe(Subscriber<? super T> subscriber)
Subscribes to a Single and invokes the
Single.OnSubscribe function without any contract protection,
error handling, unsubscribe, or execution hooks. |
Subscription |
Observable.unsafeSubscribe(Subscriber<? super T> subscriber)
Subscribes to an Observable and invokes
Observable.OnSubscribe function without any contract protection,
error handling, unsubscribe, or execution hooks. |
<T> void |
Completable.unsafeSubscribe(Subscriber<T> s)
Subscribes a regular Subscriber to this Completable instance which
will receive only an onError or onComplete event.
|
Constructor and Description |
---|
Subscriber(Subscriber<?> subscriber)
Construct a Subscriber by using another Subscriber for backpressure and
for holding the subscription list (when
this.add(sub) is
called this will in fact call subscriber.add(sub) ). |
Subscriber(Subscriber<?> subscriber,
boolean shareSubscriptions)
Construct a Subscriber by using another Subscriber for backpressure and
optionally for holding the subscription list (if
shareSubscriptions is true then when
this.add(sub) is called this will in fact call
subscriber.add(sub) ). |
Modifier and Type | Class and Description |
---|---|
class |
AssertableSubscriberObservable<T>
A
AssertableSubscriber is a variety of Subscriber that you can use
for unit testing, to perform assertions or inspect received events. |
Modifier and Type | Class and Description |
---|---|
static class |
BlockingOperatorToIterator.SubscriberIterator<T> |
class |
DeferredScalarSubscriber<T,R>
Base class for Subscribers that consume the entire upstream and signal
zero or one element (or an error) in a backpressure honoring fashion.
|
class |
DeferredScalarSubscriberSafe<T,R>
Supplements
DeferredScalarSubscriber with defensive behaviour that ensures no emissions
occur after a terminal event. |
static class |
OperatorGroupBy.GroupBySubscriber<T,K,V> |
Modifier and Type | Field and Description |
---|---|
protected Subscriber<? super R> |
DeferredScalarSubscriber.actual
The downstream subscriber.
|
Modifier and Type | Method and Description |
---|---|
Subscriber<? super T> |
OperatorAny.call(Subscriber<? super Boolean> child) |
Subscriber<? super T> |
OperatorAll.call(Subscriber<? super Boolean> child) |
Subscriber<? super T> |
OperatorGroupBy.call(Subscriber<? super GroupedObservable<K,V>> child) |
Subscriber<? super T> |
OperatorBufferWithTime.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorBufferWithSingleObservable.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorBufferWithStartEndObservable.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorToObservableSortedList.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorToObservableList.call(Subscriber<? super List<T>> o) |
Subscriber<? super T> |
OperatorBufferWithSize.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorMaterialize.call(Subscriber<? super Notification<T>> child) |
Subscriber<? super T> |
OperatorMapPair.call(Subscriber<? super Observable<? extends R>> o) |
Subscriber<? super T> |
OperatorWindowWithObservableFactory.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithSize.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithObservable.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithTime.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithStartEndObservable.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T1> |
OperatorZipIterable.call(Subscriber<? super R> subscriber) |
Subscriber<? super T> |
OperatorWithLatestFrom.call(Subscriber<? super R> child) |
Subscriber<? super T> |
OperatorEagerConcatMap.call(Subscriber<? super R> t) |
Subscriber<? super Observable[]> |
OperatorZip.call(Subscriber<? super R> child) |
Subscriber<? super T> |
OperatorMapNotification.call(Subscriber<? super R> child) |
Subscriber<? super T> |
OperatorCast.call(Subscriber<? super R> o) |
Subscriber<? super T> |
OperatorScan.call(Subscriber<? super R> child) |
Subscriber<? super T> |
OperatorTakeLast.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoOnUnsubscribe.call(Subscriber<? super T> child) |
Subscriber<? super Observable<T>> |
OperatorRetryWithPredicate.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorThrottleFirst.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoOnSubscribe.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipLast.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorTakeUntilPredicate.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkip.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipUntil.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDebounceWithSelector.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeWhile.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorAsObservable.call(Subscriber<? super T> s) |
Subscriber<? super T> |
OperatorUnsubscribeOn.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDelayWithSelector.call(Subscriber<? super T> _child) |
Subscriber<? super T> |
OperatorTakeTimed.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSampleWithTime.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDelay.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipWhile.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeLastTimed.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDebounceWithTime.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureBuffer.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSampleWithObservable.call(Subscriber<? super T> child) |
Subscriber<? super Observable<? extends T>> |
OperatorSwitch.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureDrop.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSingle.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDoOnRequest.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnErrorResumeNextViaFunction.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorElementAt.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureLatest.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDistinctUntilChanged.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorIgnoreElements.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeUntil.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorObserveOn.call(Subscriber<? super T> child) |
Subscriber<Observable<? extends T>> |
OperatorMerge.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSerialize.call(Subscriber<? super T> s) |
Subscriber<? super T> |
OperatorTake.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDistinct.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipLastTimed.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoAfterTerminate.call(Subscriber<? super T> child) |
Subscriber<? super Notification<T>> |
OperatorDematerialize.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTimeInterval.call(Subscriber<? super TimeInterval<T>> subscriber) |
Subscriber<? super T> |
OperatorTimestamp.call(Subscriber<? super Timestamped<T>> o) |
Subscriber<T> |
OnSubscribePublishMulticast.subscriber()
Returns the input subscriber of this class that must be subscribed
to the upstream source.
|
Modifier and Type | Method and Description |
---|---|
Subscriber<? super T> |
OperatorAny.call(Subscriber<? super Boolean> child) |
Subscriber<? super T> |
OperatorAll.call(Subscriber<? super Boolean> child) |
Subscriber<? super T> |
OperatorGroupBy.call(Subscriber<? super GroupedObservable<K,V>> child) |
void |
OnSubscribeRange.call(Subscriber<? super Integer> childSubscriber) |
Subscriber<? super T> |
OperatorBufferWithTime.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorBufferWithSingleObservable.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorBufferWithStartEndObservable.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorToObservableSortedList.call(Subscriber<? super List<T>> child) |
Subscriber<? super T> |
OperatorToObservableList.call(Subscriber<? super List<T>> o) |
Subscriber<? super T> |
OperatorBufferWithSize.call(Subscriber<? super List<T>> child) |
void |
OnSubscribeTimerOnce.call(Subscriber<? super Long> child) |
void |
OnSubscribeTimerPeriodically.call(Subscriber<? super Long> child) |
void |
OnSubscribeToMultimap.call(Subscriber<? super Map<K,Collection<V>>> subscriber) |
void |
OnSubscribeToMap.call(Subscriber<? super Map<K,V>> subscriber) |
Subscriber<? super T> |
OperatorMaterialize.call(Subscriber<? super Notification<T>> child) |
void |
EmptyObservableHolder.call(Subscriber<? super Object> child) |
void |
NeverObservableHolder.call(Subscriber<? super Object> child) |
Subscriber<? super T> |
OperatorMapPair.call(Subscriber<? super Observable<? extends R>> o) |
Subscriber<? super T> |
OperatorWindowWithObservableFactory.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithSize.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithObservable.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithTime.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T> |
OperatorWindowWithStartEndObservable.call(Subscriber<? super Observable<T>> child) |
Subscriber<? super T1> |
OperatorZipIterable.call(Subscriber<? super R> subscriber) |
Subscriber<? super T> |
OperatorWithLatestFrom.call(Subscriber<? super R> child) |
void |
OnSubscribeFlattenIterable.call(Subscriber<? super R> t) |
void |
OnSubscribeConcatMap.call(Subscriber<? super R> child) |
void |
OperatorWithLatestFromMany.call(Subscriber<? super R> t) |
void |
OnSubscribeCollect.call(Subscriber<? super R> t) |
Subscriber<? super T> |
OperatorEagerConcatMap.call(Subscriber<? super R> t) |
Subscriber<? super Observable[]> |
OperatorZip.call(Subscriber<? super R> child) |
void |
OnSubscribeLift.call(Subscriber<? super R> o) |
void |
OnSubscribeMap.call(Subscriber<? super R> o) |
void |
OnSubscribeFlatMapSingle.call(Subscriber<? super R> child) |
void |
OnSubscribeReduceSeed.call(Subscriber<? super R> t) |
Subscriber<? super T> |
OperatorMapNotification.call(Subscriber<? super R> child) |
void |
OnSubscribeCombineLatest.call(Subscriber<? super R> s) |
void |
OnSubscribeJoin.call(Subscriber<? super R> t1) |
Subscriber<? super T> |
OperatorCast.call(Subscriber<? super R> o) |
Subscriber<? super T> |
OperatorScan.call(Subscriber<? super R> child) |
void |
OnSubscribeGroupJoin.call(Subscriber<? super R> child) |
Subscriber<? super T> |
OperatorTakeLast.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoOnUnsubscribe.call(Subscriber<? super T> child) |
Subscriber<? super Observable<T>> |
OperatorRetryWithPredicate.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorThrottleFirst.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeDoOnEach.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeReduce.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorDoOnSubscribe.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipLast.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeAutoConnect.call(Subscriber<? super T> child) |
void |
OnSubscribeRefCount.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeThrow.call(Subscriber<? super T> observer)
|
void |
OnSubscribeFilter.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeUntilPredicate.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkip.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSkipUntil.call(Subscriber<? super T> child) |
void |
OnSubscribeSwitchIfEmpty.call(Subscriber<? super T> child) |
void |
OperatorSubscribeOn.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDebounceWithSelector.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeWhile.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeUsing.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorAsObservable.call(Subscriber<? super T> s) |
Subscriber<? super T> |
OperatorUnsubscribeOn.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDelayWithSelector.call(Subscriber<? super T> _child) |
Subscriber<? super T> |
OperatorTakeTimed.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSampleWithTime.call(Subscriber<? super T> child) |
void |
OnSubscribeSkipTimed.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDelay.call(Subscriber<? super T> child) |
void |
OnSubscribeOnAssembly.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorSkipWhile.call(Subscriber<? super T> child) |
void |
SingleToObservable.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorTakeLastTimed.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeAmb.call(Subscriber<? super T> subscriber) |
void |
OnSubscribeDelaySubscription.call(Subscriber<? super T> s) |
void |
OnSubscribeCreate.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorDebounceWithTime.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureBuffer.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSampleWithObservable.call(Subscriber<? super T> child) |
void |
OnSubscribeRedo.call(Subscriber<? super T> child) |
Subscriber<? super Observable<? extends T>> |
OperatorSwitch.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureDrop.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSingle.call(Subscriber<? super T> child) |
void |
OnSubscribePublishMulticast.call(Subscriber<? super T> t) |
void |
OnSubscribeFromCallable.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoOnRequest.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnErrorResumeNextViaFunction.call(Subscriber<? super T> child) |
void |
OnSubscribeDelaySubscriptionOther.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorElementAt.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorOnBackpressureLatest.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDistinctUntilChanged.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorIgnoreElements.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTakeUntil.call(Subscriber<? super T> child) |
void |
OnSubscribeDetach.call(Subscriber<? super T> t) |
Subscriber<? super T> |
OperatorObserveOn.call(Subscriber<? super T> child) |
Subscriber<Observable<? extends T>> |
OperatorMerge.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorSerialize.call(Subscriber<? super T> s) |
void |
OnSubscribeDelaySubscriptionWithSelector.call(Subscriber<? super T> child) |
void |
OnSubscribeFlatMapCompletable.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTake.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorDistinct.call(Subscriber<? super T> child) |
void |
OnSubscribeFromIterable.call(Subscriber<? super T> o) |
void |
OnSubscribeDefer.call(Subscriber<? super T> s) |
Subscriber<? super T> |
OperatorSkipLastTimed.call(Subscriber<? super T> subscriber) |
Subscriber<? super T> |
OperatorDoAfterTerminate.call(Subscriber<? super T> child) |
void |
OnSubscribeFromArray.call(Subscriber<? super T> child) |
void |
OnSubscribeTakeLastOne.call(Subscriber<? super T> t) |
Subscriber<? super Notification<T>> |
OperatorDematerialize.call(Subscriber<? super T> child) |
Subscriber<? super T> |
OperatorTimeInterval.call(Subscriber<? super TimeInterval<T>> subscriber) |
Subscriber<? super T> |
OperatorTimestamp.call(Subscriber<? super Timestamped<T>> o) |
static <T,R> void |
BackpressureUtils.postCompleteDone(AtomicLong requested,
Queue<T> queue,
Subscriber<? super R> actual,
Func1<? super T,? extends R> exitTransform)
Signals the completion of the main sequence and switches to post-completion replay mode
and allows exit transformation on the queued values.
|
static <T> void |
BackpressureUtils.postCompleteDone(AtomicLong requested,
Queue<T> queue,
Subscriber<? super T> actual)
Signals the completion of the main sequence and switches to post-completion replay mode.
|
static <T,R> boolean |
BackpressureUtils.postCompleteRequest(AtomicLong requested,
long n,
Queue<T> queue,
Subscriber<? super R> actual,
Func1<? super T,? extends R> exitTransform)
Accumulates requests (validated) and handles the completed mode draining of the queue based on the requests
and allows exit transformation on the queued values.
|
static <T> boolean |
BackpressureUtils.postCompleteRequest(AtomicLong requested,
long n,
Queue<T> queue,
Subscriber<? super T> actual)
Accumulates requests (validated) and handles the completed mode draining of the queue based on the requests.
|
static <T> SingleSubscriber<T> |
SingleLiftObservableOperator.wrap(Subscriber<T> subscriber) |
Constructor and Description |
---|
DeferredScalarSubscriber(Subscriber<? super R> actual) |
DeferredScalarSubscriberSafe(Subscriber<? super R> actual) |
GroupBySubscriber(Subscriber<? super GroupedObservable<K,V>> actual,
Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends V> valueSelector,
int bufferSize,
boolean delayError,
Func1<Action1<K>,Map<K,Object>> mapFactory) |
Constructor and Description |
---|
ProducerObserverArbiter(Subscriber<? super T> child) |
QueuedProducer(Subscriber<? super T> child)
Constructs an instance with the target child subscriber and an Spsc Linked (Atomic) Queue
as the queue implementation.
|
QueuedProducer(Subscriber<? super T> child,
Queue<Object> queue)
Constructs an instance with the target child subscriber and a custom queue implementation
|
QueuedValueProducer(Subscriber<? super T> child)
Constructs an instance with the target child subscriber and an Spsc Linked (Atomic) Queue
as the queue implementation.
|
QueuedValueProducer(Subscriber<? super T> child,
Queue<Object> queue)
Constructs an instance with the target child subscriber and a custom queue implementation
|
SingleDelayedProducer(Subscriber<? super T> child)
Constructor, wraps the target child subscriber.
|
SingleProducer(Subscriber<? super T> child,
T value)
Constructs the producer with the given target child and value to be emitted.
|
Modifier and Type | Class and Description |
---|---|
class |
ActionSubscriber<T>
A Subscriber that forwards the onXXX method calls to callbacks.
|
class |
ObserverSubscriber<T>
Wraps an Observer and forwards the onXXX method calls to it.
|
Modifier and Type | Method and Description |
---|---|
void |
AsyncOnSubscribe.call(Subscriber<? super T> actualSubscriber) |
void |
SyncOnSubscribe.call(Subscriber<? super T> subscriber) |
void |
BlockingObservable.subscribe(Subscriber<? super T> subscriber)
Subscribes to the source and calls the Subscriber methods on the current thread.
|
Modifier and Type | Class and Description |
---|---|
class |
SafeSubscriber<T>
SafeSubscriber is a wrapper around Subscriber that ensures that the Subscriber
complies with the Observable contract. |
class |
SerializedSubscriber<T>
Enforces single-threaded, serialized, ordered execution of
SerializedSubscriber.onNext(T) , SerializedSubscriber.onCompleted() , and
SerializedSubscriber.onError(java.lang.Throwable) . |
class |
TestSubscriber<T>
A
TestSubscriber is a variety of Subscriber that you can use for unit testing, to perform
assertions, inspect received events, or wrap a mocked Subscriber . |
Modifier and Type | Method and Description |
---|---|
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext)
Creates a
Subscriber that receives the emissions of any Observable it subscribes to via
onNext but ignores onCompleted notifications;
it will throw an OnErrorNotImplementedException if onError is invoked. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError notification but
ignores an onCompleted notification. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError or
onCompleted notifications. |
static <T> Subscriber<T> |
Subscribers.empty()
Returns an inert
Subscriber that does nothing in response to the emissions or notifications
from any Observable it subscribes to. |
static <T> Subscriber<T> |
Subscribers.from(Observer<? super T> o)
Converts an
Observer into a Subscriber . |
Subscriber<? super T> |
SafeSubscriber.getActual()
Returns the
Subscriber underlying this SafeSubscriber . |
static <T> Subscriber<T> |
Subscribers.wrap(Subscriber<? super T> subscriber)
Returns a new
Subscriber that passes all events to
subscriber , has backpressure controlled by
subscriber and uses the subscription list of
subscriber when add(rx.Subscription) is
called. |
Modifier and Type | Method and Description |
---|---|
static <T> TestSubscriber<T> |
TestSubscriber.create(Subscriber<T> delegate)
Factory method to construct a TestSubscriber which delegates events to the given Subscriber and
an issues an initial request of Long.MAX_VALUE.
|
static <T> Subscriber<T> |
Subscribers.wrap(Subscriber<? super T> subscriber)
Returns a new
Subscriber that passes all events to
subscriber , has backpressure controlled by
subscriber and uses the subscription list of
subscriber when add(rx.Subscription) is
called. |
Constructor and Description |
---|
SafeSubscriber(Subscriber<? super T> actual) |
SerializedSubscriber(Subscriber<? super T> s) |
SerializedSubscriber(Subscriber<? super T> s,
boolean shareSubscriptions)
Constructor for wrapping and serializing a subscriber optionally sharing the same underlying subscription
list.
|
TestSubscriber(Subscriber<T> delegate)
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to
the given Subscriber.
|
Copyright © 2018. All rights reserved.