Uses of Class
rx.Subscriber
-
Packages that use Subscriber Package Description rx Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.rx.internal.operators Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.rx.internal.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.rx.subjects Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables). -
-
Uses of Subscriber in rx
Fields in rx declared as Subscriber Modifier and Type Field Description private Subscriber<?>
Subscriber. subscriber
Methods in rx with parameters of type Subscriber Modifier and Type Method Description void
Observable.OnSubscribeExtend. call(Subscriber<? super T> subscriber)
<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
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.(package private) static <T> Subscription
Observable. subscribe(Subscriber<? super T> subscriber, Observable<T> observable)
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.<T> void
Completable. unsafeSubscribe(Subscriber<T> s)
Subscribes a regular Subscriber to this Completable instance which will receive only an onError or onComplete event.private <T> void
Completable. unsafeSubscribe(Subscriber<T> s, boolean callOnStart)
Performs the actual unsafe subscription and calls the onStart if required.Subscription
Observable. unsafeSubscribe(Subscriber<? super T> subscriber)
Subscribes to an Observable and invokesObservable.OnSubscribe
function without any contract protection, error handling, unsubscribe, or execution hooks.Subscription
Single. unsafeSubscribe(Subscriber<? super T> subscriber)
Subscribes to a Single and invokes theSingle.OnSubscribe
function without any contract protection, error handling, unsubscribe, or execution hooks.Constructors in rx with parameters of type Subscriber Constructor Description Subscriber(Subscriber<?> subscriber)
Construct a Subscriber by using another Subscriber for backpressure and for holding the subscription list (whenthis.add(sub)
is called this will in fact callsubscriber.add(sub)
).Subscriber(Subscriber<?> subscriber, boolean shareSubscriptions)
Construct a Subscriber by using another Subscriber for backpressure and optionally for holding the subscription list (ifshareSubscriptions
istrue
then whenthis.add(sub)
is called this will in fact callsubscriber.add(sub)
). -
Uses of Subscriber in rx.internal.operators
Subclasses of Subscriber in rx.internal.operators Modifier and Type Class Description (package private) static class
BlockingOperatorLatest.LatestObserverIterator<T>
Observer of source, iterator for output.(package private) static class
BlockingOperatorMostRecent.MostRecentObserver<T>
(package private) static class
BlockingOperatorNext.NextObserver<T>
static class
BlockingOperatorToIterator.SubscriberIterator<T>
(package private) static class
CompletableOnSubscribeConcat.CompletableConcatSubscriber
(package private) static class
CompletableOnSubscribeMerge.CompletableMergeSubscriber
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.(package private) static class
OnSubscribeAmb.AmbSubscriber<T>
(package private) static class
OnSubscribeCollect.CollectSubscriber<T,R>
(package private) static class
OnSubscribeCombineLatest.CombinerSubscriber<T,R>
(package private) static class
OnSubscribeConcatMap.ConcatMapInnerSubscriber<T,R>
(package private) static class
OnSubscribeConcatMap.ConcatMapSubscriber<T,R>
(package private) static class
OnSubscribeDetach.DetachSubscriber<T>
The parent subscriber that forwards events and cleans up on a terminal state.(package private) static class
OnSubscribeFilter.FilterSubscriber<T>
(package private) static class
OnSubscribeFlattenIterable.FlattenIterableSubscriber<T,R>
(package private) class
OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
Observe left duration and apply termination.(package private) class
OnSubscribeGroupJoin.ResultManager.LeftObserver
Observe the left source.(package private) class
OnSubscribeGroupJoin.ResultManager.RightDurationObserver
Observe right duration and apply termination.(package private) class
OnSubscribeGroupJoin.ResultManager.RightObserver
Observe the right source.(package private) class
OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
Observe activities on the window.(package private) class
OnSubscribeJoin.ResultSink.LeftSubscriber
Observes the left values.(package private) class
OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
Observes the left duration.(package private) class
OnSubscribeJoin.ResultSink.RightSubscriber
Observes the right values.(package private) class
OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
Observe the right duration.(package private) static class
OnSubscribeMap.MapSubscriber<T,R>
(package private) static class
OnSubscribeOnAssembly.OnAssemblySubscriber<T>
(package private) static class
OnSubscribePublishMulticast.ParentSubscriber<T>
The subscriber that must be used for subscribing to the upstream source.(package private) static class
OnSubscribeReduce.ReduceSubscriber<T>
(package private) static class
OnSubscribeReduceSeed.ReduceSeedSubscriber<T,R>
(package private) static class
OnSubscribeTakeLastOne.TakeLastOneSubscriber<T>
(package private) class
OperatorBufferWithSingleObservable.BufferingSubscriber
(package private) static class
OperatorBufferWithSize.BufferExact<T>
(package private) static class
OperatorBufferWithSize.BufferOverlap<T>
(package private) static class
OperatorBufferWithSize.BufferSkip<T>
(package private) class
OperatorBufferWithStartEndObservable.BufferingSubscriber
(package private) class
OperatorBufferWithTime.ExactSubscriber
Subscriber when exact timed chunking is required.(package private) class
OperatorBufferWithTime.InexactSubscriber
Subscriber when the buffer chunking time and length differ.(package private) static class
OperatorCast.CastSubscriber<T,R>
(package private) static class
OperatorDoOnRequest.ParentSubscriber<T>
(package private) static class
OperatorEagerConcatMap.EagerInnerSubscriber<T>
(package private) static class
OperatorEagerConcatMap.EagerOuterSubscriber<T,R>
static class
OperatorGroupBy.GroupBySubscriber<T,K,V>
(package private) static class
OperatorMapNotification.MapNotificationSubscriber<T,R>
(package private) static class
OperatorMapPair.MapPairSubscriber<T,U,R>
(package private) static class
OperatorMaterialize.ParentSubscriber<T>
(package private) static class
OperatorMerge.InnerSubscriber<T>
(package private) static class
OperatorMerge.MergeSubscriber<T>
The subscriber that observes Observables.(package private) static class
OperatorObserveOn.ObserveOnSubscriber<T>
Observe through individual queue per observer.(package private) static class
OperatorOnBackpressureBuffer.BufferSubscriber<T>
(package private) static class
OperatorOnBackpressureLatest.LatestSubscriber<T>
(package private) static class
OperatorPublish.PublishSubscriber<T>
(package private) static class
OperatorReplay.ReplaySubscriber<T>
(package private) static class
OperatorRetryWithPredicate.SourceSubscriber<T>
(package private) static class
OperatorSampleWithTime.SamplerSubscriber<T>
The source subscriber and sampler.(package private) static class
OperatorSingle.ParentSubscriber<T>
(package private) static class
OperatorSwitch.InnerSubscriber<T>
(package private) static class
OperatorSwitch.SwitchSubscriber<T>
(package private) static class
OperatorSwitchIfEmpty.AlternateSubscriber<T>
(package private) static class
OperatorSwitchIfEmpty.ParentSubscriber<T>
(package private) static class
OperatorTakeLast.TakeLastSubscriber<T>
(package private) static class
OperatorTakeLastTimed.TakeLastTimedSubscriber<T>
(package private) static class
OperatorTakeTimed.TakeSubscriber<T>
Subscribed to source and scheduled on a worker.(package private) class
OperatorTakeUntilPredicate.ParentSubscriber
Subscriber returned to the upstream.(package private) static class
OperatorTimeoutBase.TimeoutSubscriber<T>
(package private) static class
OperatorWindowWithObservable.BoundarySubscriber<T,U>
Observes the boundary.(package private) static class
OperatorWindowWithObservable.SourceSubscriber<T>
Observes the source.(package private) static class
OperatorWindowWithObservableFactory.BoundarySubscriber<T,U>
Observes the boundary.(package private) static class
OperatorWindowWithObservableFactory.SourceSubscriber<T,U>
Observes the source.(package private) static class
OperatorWindowWithSize.WindowExact<T>
(package private) static class
OperatorWindowWithSize.WindowOverlap<T>
(package private) static class
OperatorWindowWithSize.WindowSkip<T>
(package private) class
OperatorWindowWithStartEndObservable.SourceSubscriber
(package private) class
OperatorWindowWithTime.ExactSubscriber
Subscriber with exact, non-overlapping windows.(package private) class
OperatorWindowWithTime.InexactSubscriber
Subscriber with inexact, potentially overlapping or discontinuous windows.(package private) static class
OperatorWithLatestFromMany.WithLatestMainSubscriber<T,R>
(package private) static class
OperatorWithLatestFromMany.WithLatestOtherSubscriber
(package private) class
OperatorZip.Zip.InnerSubscriber
(package private) class
OperatorZip.ZipSubscriber
Fields in rx.internal.operators declared as Subscriber Modifier and Type Field Description protected Subscriber<? super R>
DeferredScalarSubscriber. actual
The downstream subscriber.(package private) Subscriber<? super R>
OnSubscribeCombineLatest.LatestCoordinator. actual
(package private) Subscriber<? super R>
OnSubscribeConcatMap.ConcatMapSubscriber. actual
(package private) Subscriber<? super T>
OnSubscribeFilter.FilterSubscriber. actual
(package private) Subscriber<? super R>
OnSubscribeFlattenIterable.FlattenIterableSubscriber. actual
(package private) Subscriber<? super T>
OnSubscribeFromAsync.BaseAsyncEmitter. actual
(package private) Subscriber<? super R>
OnSubscribeMap.MapSubscriber. actual
(package private) Subscriber<? super T>
OnSubscribeOnAssembly.OnAssemblySubscriber. actual
(package private) Subscriber<? super T>
OnSubscribePublishMulticast.PublishProducer. actual
The actual subscriber to receive the events.(package private) Subscriber<? super T>
OnSubscribeReduce.ReduceSubscriber. actual
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithSize.BufferExact. actual
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithSize.BufferOverlap. actual
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithSize.BufferSkip. actual
(package private) Subscriber<? super R>
OperatorCast.CastSubscriber. actual
(package private) Subscriber<? super R>
OperatorEagerConcatMap.EagerOuterSubscriber. actual
(package private) Subscriber<? super GroupedObservable<K,V>>
OperatorGroupBy.GroupBySubscriber. actual
(package private) Subscriber<? super R>
OperatorMapNotification.MapNotificationSubscriber. actual
(package private) Subscriber<? super Observable<? extends R>>
OperatorMapPair.MapPairSubscriber. actual
(package private) Subscriber<? super T>
OperatorTakeLast.TakeLastSubscriber. actual
(package private) Subscriber<? super T>
OperatorTakeLastTimed.TakeLastTimedSubscriber. actual
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithSize.WindowExact. actual
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithSize.WindowOverlap. actual
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithSize.WindowSkip. actual
(package private) Subscriber<? super R>
OperatorWithLatestFromMany.WithLatestMainSubscriber. actual
(package private) Subscriber<? super T>
CachedObservable.ReplayProducer. child
The actual child subscriber.(package private) Subscriber<? super T>
OnSubscribeFromArray.FromArrayProducer. child
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithSingleObservable.BufferingSubscriber. child
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithStartEndObservable.BufferingSubscriber. child
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithTime.ExactSubscriber. child
(package private) Subscriber<? super java.util.List<T>>
OperatorBufferWithTime.InexactSubscriber. child
private Subscriber<? super T>
OperatorDoOnRequest.ParentSubscriber. child
private Subscriber<? super Notification<T>>
OperatorMaterialize.ParentSubscriber. child
(package private) Subscriber<? super T>
OperatorMerge.MergeSubscriber. child
(package private) Subscriber<? super T>
OperatorObserveOn.ObserveOnSubscriber. child
private Subscriber<? super T>
OperatorOnBackpressureBuffer.BufferSubscriber. child
(package private) Subscriber<? super T>
OperatorOnBackpressureLatest.LatestEmitter. child
(package private) Subscriber<? super T>
OperatorPublish.InnerProducer. child
The actual child subscriber.(package private) Subscriber<? super T>
OperatorReplay.InnerProducer. child
The actual child subscriber.(package private) Subscriber<? super T>
OperatorRetryWithPredicate.SourceSubscriber. child
(package private) Subscriber<? super R>
OperatorScan.InitialProducer. child
private Subscriber<? super T>
OperatorSingle.ParentSubscriber. child
(package private) Subscriber<? super T>
OperatorSwitch.SwitchSubscriber. child
private Subscriber<? super T>
OperatorSwitchIfEmpty.AlternateSubscriber. child
private Subscriber<? super T>
OperatorSwitchIfEmpty.ParentSubscriber. child
(package private) Subscriber<? super T>
OperatorTakeTimed.TakeSubscriber. child
private Subscriber<? super T>
OperatorTakeUntilPredicate.ParentSubscriber. child
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithObservable.SourceSubscriber. child
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithObservableFactory.SourceSubscriber. child
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithStartEndObservable.SourceSubscriber. child
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithTime.ExactSubscriber. child
(package private) Subscriber<? super Observable<T>>
OperatorWindowWithTime.InexactSubscriber. child
(package private) Subscriber<? super R>
OperatorZip.ZipSubscriber. child
private Subscriber<? super java.lang.Integer>
OnSubscribeRange.RangeProducer. childSubscriber
private Subscriber<? super T>
OnSubscribeFromIterable.IterableProducer. o
private Subscriber<? super T>
OnSubscribeAmb.AmbSubscriber. subscriber
(package private) Subscriber<? super R>
OnSubscribeGroupJoin.ResultManager. subscriber
(package private) Subscriber<? super T>
OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber. subscriber
(package private) Subscriber<? super R>
OnSubscribeJoin.ResultSink. subscriber
private Subscriber<? super T>
OperatorSampleWithTime.SamplerSubscriber. subscriber
(package private) Subscriber<T>
OperatorMulticast. subscription
Guarded by guard.Fields in rx.internal.operators with type parameters of type Subscriber Modifier and Type Field Description (package private) java.util.concurrent.atomic.AtomicReference<Subscriber<? super T>>
OnSubscribeDetach.DetachSubscriber. actual
(package private) java.util.concurrent.atomic.AtomicReference<Subscriber<? super T>>
OperatorGroupBy.State. actual
(package private) java.util.List<Subscriber<? super R>>
OperatorMulticast. waitingForConnect
Methods in rx.internal.operators that return Subscriber Modifier and Type Method Description Subscriber<? super T>
OperatorAll. call(Subscriber<? super java.lang.Boolean> child)
Subscriber<? super T>
OperatorAny. call(Subscriber<? super java.lang.Boolean> child)
Subscriber<? super T>
OperatorAsObservable. call(Subscriber<? super T> s)
Subscriber<? super T>
OperatorBufferWithSingleObservable. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithSize. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithStartEndObservable. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithTime. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorCast. call(Subscriber<? super R> o)
Subscriber<? super T>
OperatorDebounceWithSelector. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDebounceWithTime. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDelay. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDelayWithSelector. call(Subscriber<? super T> _child)
Subscriber<? super Notification<T>>
OperatorDematerialize. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDistinct. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDistinctUntilChanged. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoAfterTerminate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnEach. call(Subscriber<? super T> observer)
Subscriber<? super T>
OperatorDoOnRequest. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnSubscribe. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnUnsubscribe. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorEagerConcatMap. call(Subscriber<? super R> t)
Subscriber<? super T>
OperatorElementAt. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorGroupBy. call(Subscriber<? super GroupedObservable<K,V>> child)
Subscriber<? super T>
OperatorIgnoreElements. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorMapNotification. call(Subscriber<? super R> child)
Subscriber<? super T>
OperatorMapPair. call(Subscriber<? super Observable<? extends R>> o)
Subscriber<? super T>
OperatorMaterialize. call(Subscriber<? super Notification<T>> child)
Subscriber<Observable<? extends T>>
OperatorMerge. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorObserveOn. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureBuffer. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureDrop. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureLatest. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnErrorResumeNextViaFunction. call(Subscriber<? super T> child)
Subscriber<? super Observable<T>>
OperatorRetryWithPredicate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSampleWithObservable. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSampleWithTime. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorScan. call(Subscriber<? super R> child)
Subscriber<? super T>
OperatorSerialize. call(Subscriber<? super T> s)
Subscriber<? super T>
OperatorSingle. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkip. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipLast. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorSkipLastTimed. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorSkipTimed. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipUntil. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipWhile. call(Subscriber<? super T> child)
Subscriber<? super Observable<? extends T>>
OperatorSwitch. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSwitchIfEmpty. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTake. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeLast. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTakeLastTimed. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTakeTimed. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeUntil. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeUntilPredicate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeWhile. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorThrottleFirst. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTimeInterval. call(Subscriber<? super TimeInterval<T>> subscriber)
Subscriber<? super T>
OperatorTimeoutBase. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTimestamp. call(Subscriber<? super Timestamped<T>> o)
Subscriber<? super T>
OperatorToMap. call(Subscriber<? super java.util.Map<K,V>> subscriber)
Subscriber<? super T>
OperatorToMultimap. call(Subscriber<? super java.util.Map<K,java.util.Collection<V>>> subscriber)
Subscriber<? super T>
OperatorToObservableList. call(Subscriber<? super java.util.List<T>> o)
Subscriber<? super T>
OperatorToObservableSortedList. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorUnsubscribeOn. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorWindowWithObservable. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithObservableFactory. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithSize. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithStartEndObservable. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithTime. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWithLatestFrom. call(Subscriber<? super R> child)
Subscriber<? super Observable[]>
OperatorZip. call(Subscriber<? super R> child)
Subscriber<? super T1>
OperatorZipIterable. call(Subscriber<? super R> subscriber)
Subscriber<T>
OnSubscribePublishMulticast. subscriber()
Returns the input subscriber of this class that must be subscribed to the upstream source.Methods in rx.internal.operators with parameters of type Subscriber Modifier and Type Method Description void
BufferUntilSubscriber.OnSubscribeAction. call(Subscriber<? super T> s)
void
CachedObservable.CachedSubscribe. call(Subscriber<? super T> t)
void
EmptyObservableHolder. call(Subscriber<? super java.lang.Object> child)
void
NeverObservableHolder. call(Subscriber<? super java.lang.Object> child)
void
OnSubscribeAmb. call(Subscriber<? super T> subscriber)
void
OnSubscribeAutoConnect. call(Subscriber<? super T> child)
void
OnSubscribeCollect. call(Subscriber<? super R> t)
void
OnSubscribeCombineLatest. call(Subscriber<? super R> s)
void
OnSubscribeConcatMap. call(Subscriber<? super R> child)
void
OnSubscribeDefer. call(Subscriber<? super T> s)
void
OnSubscribeDelaySubscription. call(Subscriber<? super T> s)
void
OnSubscribeDelaySubscriptionOther. call(Subscriber<? super T> t)
void
OnSubscribeDelaySubscriptionWithSelector. call(Subscriber<? super T> child)
void
OnSubscribeDetach. call(Subscriber<? super T> t)
void
OnSubscribeFilter. call(Subscriber<? super T> child)
void
OnSubscribeFlattenIterable. call(Subscriber<? super R> t)
void
OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable. call(Subscriber<? super R> t)
void
OnSubscribeFromArray. call(Subscriber<? super T> child)
void
OnSubscribeFromAsync. call(Subscriber<? super T> t)
void
OnSubscribeFromCallable. call(Subscriber<? super T> subscriber)
void
OnSubscribeFromIterable. call(Subscriber<? super T> o)
void
OnSubscribeGroupJoin. call(Subscriber<? super R> child)
void
OnSubscribeGroupJoin.WindowObservableFunc. call(Subscriber<? super T> t1)
void
OnSubscribeJoin. call(Subscriber<? super R> t1)
void
OnSubscribeLift. call(Subscriber<? super R> o)
void
OnSubscribeMap. call(Subscriber<? super R> o)
void
OnSubscribeOnAssembly. call(Subscriber<? super T> t)
void
OnSubscribePublishMulticast. call(Subscriber<? super T> t)
void
OnSubscribeRange. call(Subscriber<? super java.lang.Integer> childSubscriber)
void
OnSubscribeRedo. call(Subscriber<? super T> child)
void
OnSubscribeReduce. call(Subscriber<? super T> t)
void
OnSubscribeReduceSeed. call(Subscriber<? super R> t)
void
OnSubscribeRefCount. call(Subscriber<? super T> subscriber)
void
OnSubscribeTakeLastOne. call(Subscriber<? super T> t)
void
OnSubscribeThrow. call(Subscriber<? super T> observer)
void
OnSubscribeTimerOnce. call(Subscriber<? super java.lang.Long> child)
void
OnSubscribeTimerPeriodically. call(Subscriber<? super java.lang.Long> child)
void
OnSubscribeToObservableFuture.ToObservableFuture. call(Subscriber<? super T> subscriber)
void
OnSubscribeUsing. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorAll. call(Subscriber<? super java.lang.Boolean> child)
Subscriber<? super T>
OperatorAny. call(Subscriber<? super java.lang.Boolean> child)
Subscriber<? super T>
OperatorAsObservable. call(Subscriber<? super T> s)
Subscriber<? super T>
OperatorBufferWithSingleObservable. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithSize. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithStartEndObservable. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorBufferWithTime. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorCast. call(Subscriber<? super R> o)
Subscriber<? super T>
OperatorDebounceWithSelector. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDebounceWithTime. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDelay. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDelayWithSelector. call(Subscriber<? super T> _child)
Subscriber<? super Notification<T>>
OperatorDematerialize. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDistinct. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDistinctUntilChanged. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoAfterTerminate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnEach. call(Subscriber<? super T> observer)
Subscriber<? super T>
OperatorDoOnRequest. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnSubscribe. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorDoOnUnsubscribe. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorEagerConcatMap. call(Subscriber<? super R> t)
Subscriber<? super T>
OperatorElementAt. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorGroupBy. call(Subscriber<? super GroupedObservable<K,V>> child)
void
OperatorGroupBy.State. call(Subscriber<? super T> s)
Subscriber<? super T>
OperatorIgnoreElements. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorMapNotification. call(Subscriber<? super R> child)
Subscriber<? super T>
OperatorMapPair. call(Subscriber<? super Observable<? extends R>> o)
Subscriber<? super T>
OperatorMaterialize. call(Subscriber<? super Notification<T>> child)
Subscriber<Observable<? extends T>>
OperatorMerge. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorObserveOn. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureBuffer. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureDrop. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnBackpressureLatest. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorOnErrorResumeNextViaFunction. call(Subscriber<? super T> child)
Subscriber<? super Observable<T>>
OperatorRetryWithPredicate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSampleWithObservable. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSampleWithTime. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorScan. call(Subscriber<? super R> child)
Subscriber<? super T>
OperatorSerialize. call(Subscriber<? super T> s)
Subscriber<? super T>
OperatorSingle. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkip. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipLast. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorSkipLastTimed. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorSkipTimed. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipUntil. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSkipWhile. call(Subscriber<? super T> child)
void
OperatorSubscribeOn. call(Subscriber<? super T> subscriber)
Subscriber<? super Observable<? extends T>>
OperatorSwitch. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorSwitchIfEmpty. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTake. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeLast. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTakeLastTimed. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTakeTimed. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeUntil. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeUntilPredicate. call(Subscriber<? super T> child)
Subscriber<? super T>
OperatorTakeWhile. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorThrottleFirst. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTimeInterval. call(Subscriber<? super TimeInterval<T>> subscriber)
Subscriber<? super T>
OperatorTimeoutBase. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorTimestamp. call(Subscriber<? super Timestamped<T>> o)
Subscriber<? super T>
OperatorToMap. call(Subscriber<? super java.util.Map<K,V>> subscriber)
Subscriber<? super T>
OperatorToMultimap. call(Subscriber<? super java.util.Map<K,java.util.Collection<V>>> subscriber)
Subscriber<? super T>
OperatorToObservableList. call(Subscriber<? super java.util.List<T>> o)
Subscriber<? super T>
OperatorToObservableSortedList. call(Subscriber<? super java.util.List<T>> child)
Subscriber<? super T>
OperatorUnsubscribeOn. call(Subscriber<? super T> subscriber)
Subscriber<? super T>
OperatorWindowWithObservable. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithObservableFactory. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithSize. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithStartEndObservable. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWindowWithTime. call(Subscriber<? super Observable<T>> child)
Subscriber<? super T>
OperatorWithLatestFrom. call(Subscriber<? super R> child)
void
OperatorWithLatestFromMany. call(Subscriber<? super R> t)
Subscriber<? super Observable[]>
OperatorZip. call(Subscriber<? super R> child)
Subscriber<? super T1>
OperatorZipIterable. call(Subscriber<? super R> subscriber)
(package private) boolean
OnSubscribeCombineLatest.LatestCoordinator. checkTerminated(boolean mainDone, boolean queueEmpty, Subscriber<?> childSubscriber, java.util.Queue<?> q, boolean delayError)
(package private) boolean
OnSubscribeFlattenIterable.FlattenIterableSubscriber. checkTerminated(boolean d, boolean empty, Subscriber<?> a, java.util.Queue<?> q)
(package private) boolean
OperatorGroupBy.GroupBySubscriber. checkTerminated(boolean d, boolean empty, Subscriber<? super GroupedObservable<K,V>> a, java.util.Queue<?> q)
(package private) boolean
OperatorGroupBy.State. checkTerminated(boolean d, boolean empty, Subscriber<? super T> a, boolean delayError)
(package private) boolean
OperatorObserveOn.ObserveOnSubscriber. checkTerminated(boolean done, boolean isEmpty, Subscriber<? super T> a, java.util.Queue<java.lang.Object> q)
(package private) boolean
OperatorScan.InitialProducer. checkTerminated(boolean d, boolean empty, Subscriber<? super R> child)
protected boolean
OperatorSwitch.SwitchSubscriber. checkTerminated(boolean localMainDone, boolean localInnerActive, java.lang.Throwable localError, SpscLinkedArrayQueue<java.lang.Object> localQueue, Subscriber<? super T> localChild, boolean empty)
(package private) boolean
OperatorWindowWithSize.WindowOverlap. checkTerminated(boolean d, boolean empty, Subscriber<? super Subject<T,T>> a, java.util.Queue<Subject<T,T>> q)
(package private) void
OnSubscribeRefCount. doSubscribe(Subscriber<? super T> subscriber, CompositeSubscription currentBase)
void
OperatorDebounceWithTime.DebounceState. emit(int index, Subscriber<T> onNextAndComplete, Subscriber<?> onError)
void
OperatorDebounceWithTime.DebounceState. emitAndComplete(Subscriber<T> onNextAndComplete, Subscriber<?> onError)
(package private) void
OperatorGroupBy.GroupBySubscriber. errorAll(Subscriber<? super GroupedObservable<K,V>> a, java.util.Queue<?> q, java.lang.Throwable ex)
private Action1<Subscription>
OnSubscribeRefCount. onSubscribe(Subscriber<? super T> subscriber, java.util.concurrent.atomic.AtomicBoolean writeLocked)
static <T,R>
voidBackpressureUtils. postCompleteDone(java.util.concurrent.atomic.AtomicLong requested, java.util.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(java.util.concurrent.atomic.AtomicLong requested, java.util.Queue<T> queue, Subscriber<? super T> actual)
Signals the completion of the main sequence and switches to post-completion replay mode.(package private) static <T,R>
voidBackpressureUtils. postCompleteDrain(java.util.concurrent.atomic.AtomicLong requested, java.util.Queue<T> queue, Subscriber<? super R> subscriber, Func1<? super T,? extends R> exitTransform)
Drains the queue based on the outstanding requests in post-completed mode (only!) and allows exit transformation on the queued values.static <T,R>
booleanBackpressureUtils. postCompleteRequest(java.util.concurrent.atomic.AtomicLong requested, long n, java.util.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(java.util.concurrent.atomic.AtomicLong requested, long n, java.util.Queue<T> queue, Subscriber<? super T> actual)
Accumulates requests (validated) and handles the completed mode draining of the queue based on the requests.Constructors in rx.internal.operators with parameters of type Subscriber Constructor Description AlternateSubscriber(Subscriber<? super T> child, ProducerArbiter arbiter)
AmbSubscriber(long requested, Subscriber<? super T> subscriber, OnSubscribeAmb.Selection<T> selection)
BaseAsyncEmitter(Subscriber<? super T> actual)
BufferAsyncEmitter(Subscriber<? super T> actual, int capacityHint)
BufferExact(Subscriber<? super java.util.List<T>> actual, int count)
BufferingSubscriber(Subscriber<? super java.util.List<T>> child)
BufferingSubscriber(Subscriber<? super java.util.List<T>> child)
BufferOverlap(Subscriber<? super java.util.List<T>> actual, int count, int skip)
BufferSkip(Subscriber<? super java.util.List<T>> actual, int count, int skip)
BufferSubscriber(Subscriber<? super T> child, java.lang.Long capacity, Action0 onOverflow, BackpressureOverflow.Strategy overflowStrategy)
CastSubscriber(Subscriber<? super R> actual, java.lang.Class<R> castClass)
CollectSubscriber(Subscriber<? super R> actual, R initialValue, Action2<R,? super T> collector)
ConcatMapSubscriber(Subscriber<? super R> actual, Func1<? super T,? extends Observable<? extends R>> mapper, int prefetch, int delayErrorMode)
DeferredScalarSubscriber(Subscriber<? super R> actual)
DetachSubscriber(Subscriber<? super T> actual)
DropAsyncEmitter(Subscriber<? super T> actual)
EagerOuterSubscriber(Func1<? super T,? extends Observable<? extends R>> mapper, int bufferSize, int maxConcurrent, Subscriber<? super R> actual)
ErrorAsyncEmitter(Subscriber<? super T> actual)
ExactSubscriber(Subscriber<? super java.util.List<T>> child, Scheduler.Worker inner)
ExactSubscriber(Subscriber<? super Observable<T>> child, Scheduler.Worker worker)
FilterSubscriber(Subscriber<? super T> actual, Func1<? super T,java.lang.Boolean> predicate)
FlattenIterableSubscriber(Subscriber<? super R> actual, Func1<? super T,? extends java.lang.Iterable<? extends R>> mapper, int prefetch)
FromArrayProducer(Subscriber<? super T> child, T[] array)
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>,java.util.Map<K,java.lang.Object>> mapFactory)
InexactSubscriber(Subscriber<? super java.util.List<T>> child, Scheduler.Worker inner)
InexactSubscriber(Subscriber<? super Observable<T>> child, Scheduler.Worker worker)
InitialProducer(R initialValue, Subscriber<? super R> child)
InnerProducer(OperatorPublish.PublishSubscriber<T> parent, Subscriber<? super T> child)
InnerProducer(OperatorReplay.ReplaySubscriber<T> parent, Subscriber<? super T> child)
IterableProducer(Subscriber<? super T> o, java.util.Iterator<? extends T> it)
LatestAsyncEmitter(Subscriber<? super T> actual)
LatestCoordinator(Subscriber<? super R> actual, FuncN<? extends R> combiner, int count, int bufferSize, boolean delayError)
LatestEmitter(Subscriber<? super T> child)
MapNotificationSubscriber(Subscriber<? super R> actual, Func1<? super T,? extends R> onNext, Func1<? super java.lang.Throwable,? extends R> onError, Func0<? extends R> onCompleted)
MapPairSubscriber(Subscriber<? super Observable<? extends R>> actual, Func1<? super T,? extends Observable<? extends U>> collectionSelector, Func2<? super T,? super U,? extends R> resultSelector)
MapSubscriber(Subscriber<? super R> actual, Func1<? super T,? extends R> mapper)
MergeSubscriber(Subscriber<? super T> child, boolean delayErrors, int maxConcurrent)
NoneAsyncEmitter(Subscriber<? super T> actual)
NoOverflowBaseAsyncEmitter(Subscriber<? super T> actual)
ObserveOnSubscriber(Scheduler scheduler, Subscriber<? super T> child, boolean delayError, int bufferSize)
OnAssemblySubscriber(Subscriber<? super T> actual, java.lang.String stacktrace)
ParentSubscriber(Subscriber<? super T> child)
ParentSubscriber(Subscriber<? super Notification<T>> child)
ParentSubscriber(Subscriber<? super T> child, boolean hasDefaultValue, T defaultValue)
ParentSubscriber(Subscriber<? super T> child, SerialSubscription ssub, ProducerArbiter arbiter, Observable<? extends T> alternate)
ParentSubscriber(Subscriber<? super T> child)
PublishProducer(Subscriber<? super T> actual, OnSubscribePublishMulticast<T> parent)
RangeProducer(Subscriber<? super java.lang.Integer> childSubscriber, int startIndex, int endIndex)
ReduceSeedSubscriber(Subscriber<? super R> actual, R initialValue, Func2<R,? super T,R> reducer)
ReduceSubscriber(Subscriber<? super T> actual, Func2<T,T,T> reducer)
ReplayProducer(Subscriber<? super T> child, CachedObservable.CacheState<T> state)
ResultManager(Subscriber<? super R> subscriber)
ResultSink(Subscriber<? super R> subscriber)
SamplerSubscriber(Subscriber<? super T> subscriber)
SourceSubscriber(Subscriber<? super T> child, Func2<java.lang.Integer,java.lang.Throwable,java.lang.Boolean> predicate, Scheduler.Worker inner, SerialSubscription serialSubscription, ProducerArbiter pa)
SourceSubscriber(Subscriber<? super Observable<T>> child)
SourceSubscriber(Subscriber<? super Observable<T>> child, Func0<? extends Observable<? extends U>> otherFactory)
SourceSubscriber(Subscriber<? super Observable<T>> child, CompositeSubscription csub)
SwitchSubscriber(Subscriber<? super T> child, boolean delayError)
TakeLastOneSubscriber(Subscriber<? super T> actual)
TakeLastSubscriber(Subscriber<? super T> actual, int count)
TakeLastTimedSubscriber(Subscriber<? super T> actual, int count, long ageMillis, Scheduler scheduler)
TakeSubscriber(Subscriber<? super T> child)
WindowExact(Subscriber<? super Observable<T>> actual, int size)
WindowOverlap(Subscriber<? super Observable<T>> actual, int size, int skip)
WindowSkip(Subscriber<? super Observable<T>> actual, int size, int skip)
WindowSubscriber(Subscriber<? super T> subscriber, Subscription ref)
WithLatestMainSubscriber(Subscriber<? super R> actual, FuncN<R> combiner, int n)
Zip(Subscriber<? super R> child, FuncN<? extends R> zipFunction)
ZipSubscriber(Subscriber<? super R> child, OperatorZip.Zip<R> zipper, OperatorZip.ZipProducer<R> producer)
Constructor parameters in rx.internal.operators with type arguments of type Subscriber Constructor Description OperatorMulticast(java.lang.Object guard, java.util.concurrent.atomic.AtomicReference<Subject<? super T,? extends R>> connectedSubject, java.util.List<Subscriber<? super R>> waitingForConnect, Observable<? extends T> source, Func0<? extends Subject<? super T,? extends R>> subjectFactory)
-
Uses of Subscriber in rx.internal.producers
Fields in rx.internal.producers declared as Subscriber Modifier and Type Field Description (package private) Subscriber<? super T>
ProducerObserverArbiter. child
(package private) Subscriber<? super T>
QueuedProducer. child
(package private) Subscriber<? super T>
QueuedValueProducer. child
(package private) Subscriber<? super T>
SingleDelayedProducer. child
The child to emit the value and completion once possible.(package private) Subscriber<? super T>
SingleProducer. child
The child subscriber.Methods in rx.internal.producers with parameters of type Subscriber Modifier and Type Method Description private static <T> void
SingleDelayedProducer. emit(Subscriber<? super T> c, T v)
Emits the given value to the child subscriber and completes it and checks for unsubscriptions eagerly.Constructors in rx.internal.producers with parameters of type Subscriber Constructor 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, java.util.Queue<java.lang.Object> queue)
Constructs an instance with the target child subscriber and a custom queue implementationQueuedValueProducer(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, java.util.Queue<java.lang.Object> queue)
Constructs an instance with the target child subscriber and a custom queue implementationSingleDelayedProducer(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. -
Uses of Subscriber in rx.internal.util
Subclasses of Subscriber in rx.internal.util Modifier and Type Class 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.Fields in rx.internal.util declared as Subscriber Modifier and Type Field Description (package private) Subscriber<? super T>
ScalarSynchronousObservable.ScalarAsyncProducer. actual
(package private) Subscriber<? super T>
ScalarSynchronousObservable.WeakSingleProducer. actual
Methods in rx.internal.util with parameters of type Subscriber Modifier and Type Method Description void
ScalarSynchronousObservable.JustOnSubscribe. call(Subscriber<? super T> s)
void
ScalarSynchronousObservable.ScalarAsyncOnSubscribe. call(Subscriber<? super T> s)
(package private) static <T> Producer
ScalarSynchronousObservable. createProducer(Subscriber<? super T> s, T v)
Creates a scalar producer depending on the state of STRONG_MODE.Constructors in rx.internal.util with parameters of type Subscriber Constructor Description ScalarAsyncProducer(Subscriber<? super T> actual, T value, Func1<Action0,Subscription> onSchedule)
WeakSingleProducer(Subscriber<? super T> actual, T value)
-
Uses of Subscriber in rx.observables
Fields in rx.observables declared as Subscriber Modifier and Type Field Description private Subscriber<? super T>
SyncOnSubscribe.SubscriptionProducer. actualSubscriber
(package private) Subscriber<? super T>
AsyncOnSubscribe.UnicastSubject.State. subscriber
Methods in rx.observables with parameters of type Subscriber Modifier and Type Method Description void
AsyncOnSubscribe. call(Subscriber<? super T> actualSubscriber)
void
AsyncOnSubscribe.UnicastSubject.State. call(Subscriber<? super T> s)
void
SyncOnSubscribe. call(Subscriber<? super T> subscriber)
private void
SyncOnSubscribe.SubscriptionProducer. handleThrownError(Subscriber<? super T> a, java.lang.Throwable ex)
void
BlockingObservable. subscribe(Subscriber<? super T> subscriber)
Subscribes to the source and calls the Subscriber methods on the current thread.Constructors in rx.observables with parameters of type Subscriber Constructor Description SubscriptionProducer(Subscriber<? super T> subscriber, SyncOnSubscribe<S,T> parent, S state)
-
Uses of Subscriber in rx.observers
Subclasses of Subscriber in rx.observers Modifier and Type Class Description class
SafeSubscriber<T>
SafeSubscriber
is a wrapper aroundSubscriber
that ensures that theSubscriber
complies with the Observable contract.class
SerializedSubscriber<T>
Enforces single-threaded, serialized, ordered execution ofSerializedSubscriber.onNext(T)
,SerializedSubscriber.onCompleted()
, andSerializedSubscriber.onError(java.lang.Throwable)
.class
TestSubscriber<T>
ATestSubscriber
is a variety ofSubscriber
that you can use for unit testing, to perform assertions, inspect received events, or wrap a mockedSubscriber
.Fields in rx.observers declared as Subscriber Modifier and Type Field Description private Subscriber<? super T>
SafeSubscriber. actual
Methods in rx.observers that return Subscriber Modifier and Type Method Description static <T> Subscriber<T>
Subscribers. create(Action1<? super T> onNext)
Creates aSubscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
but ignoresonCompleted
notifications; it will throw anOnErrorNotImplementedException
ifonError
is invoked.static <T> Subscriber<T>
Subscribers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError)
Creates anSubscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
notification but ignores anonCompleted
notification.static <T> Subscriber<T>
Subscribers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onComplete)
Creates anSubscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications.static <T> Subscriber<T>
Subscribers. empty()
Returns an inertSubscriber
that does nothing in response to the emissions or notifications from anyObservable
it subscribes to.static <T> Subscriber<T>
Subscribers. from(Observer<? super T> o)
Converts anObserver
into aSubscriber
.Subscriber<? super T>
SafeSubscriber. getActual()
Returns theSubscriber
underlying thisSafeSubscriber
.static <T> Subscriber<T>
Subscribers. wrap(Subscriber<? super T> subscriber)
Returns a newSubscriber
that passes all events tosubscriber
, has backpressure controlled bysubscriber
and uses the subscription list ofsubscriber
whenadd(rx.Subscription)
is called.Methods in rx.observers with parameters of type Subscriber Modifier and Type Method 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 newSubscriber
that passes all events tosubscriber
, has backpressure controlled bysubscriber
and uses the subscription list ofsubscriber
whenadd(rx.Subscription)
is called.Constructors in rx.observers with parameters of type Subscriber Constructor 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. -
Uses of Subscriber in rx.subjects
Fields in rx.subjects declared as Subscriber Modifier and Type Field Description (package private) Subscriber<? super T>
ReplaySubject.ReplayProducer. actual
The wrapped Subscriber instance.(package private) Subscriber<? super T>
SubjectSubscriptionManager.SubjectObserver. actual
The actual Observer.Fields in rx.subjects with type parameters of type Subscriber Modifier and Type Field Description (package private) java.util.concurrent.atomic.AtomicReference<Subscriber<? super T>>
UnicastSubject.State. subscriber
The single subscriber.Methods in rx.subjects with parameters of type Subscriber Modifier and Type Method Description (package private) void
SubjectSubscriptionManager. addUnsubscriber(Subscriber<? super T> child, SubjectSubscriptionManager.SubjectObserver<T> bo)
Registers the unsubscribe action for the given subscriber.void
ReplaySubject.ReplayState. call(Subscriber<? super T> t)
void
SubjectSubscriptionManager. call(Subscriber<? super T> child)
void
UnicastSubject.State. call(Subscriber<? super T> subscriber)
Tries to set the given subscriber if not already set, sending an IllegalStateException to the subscriber otherwise.(package private) boolean
UnicastSubject.State. checkTerminated(boolean done, boolean empty, Subscriber<? super T> s)
Checks if one of the terminal conditions have been met: child unsubscribed, an error happened or the source terminated and the queue is emptyConstructors in rx.subjects with parameters of type Subscriber Constructor Description ReplayProducer(Subscriber<? super T> actual, ReplaySubject.ReplayState<T> state)
SubjectObserver(Subscriber<? super T> actual)
-