Uses of Class
rx.Subscriber
Packages that use Subscriber
Package
Description
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
Operators that allow composing Observables to transform and
manipulate data in an asynchronous, functional and thread-safe manner.
Classes extending the Observable base reactive class, synchronous and
asynchronous event generators.
Default wrappers and implementations for the base reactive consumer classes and interfaces;
utility classes for creating them from callbacks.
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 SubscriberMethods in rx with parameters of type SubscriberModifier and TypeMethodDescriptionvoid
Observable.OnSubscribeExtend.call
(Subscriber<? super T> subscriber) final <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.final 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) final 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.final <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 final <T> void
Completable.unsafeSubscribe
(Subscriber<T> s, boolean callOnStart) Performs the actual unsafe subscription and calls the onStart if required.final 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.final 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 SubscriberModifierConstructorDescriptionprotected
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)
).protected
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.operatorsModifier and TypeClassDescription(package private) static final class
Observer of source, iterator for output.(package private) static final class
(package private) static final class
static final class
(package private) static final class
(package private) static final class
class
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 final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
The parent subscriber that forwards events and cleans up on a terminal state.(package private) static final class
(package private) static final class
(package private) final class
Observe left duration and apply termination.(package private) final class
Observe the left source.(package private) final class
Observe right duration and apply termination.(package private) final class
Observe the right source.(package private) final class
Observe activities on the window.(package private) final class
Observes the left values.(package private) final class
Observes the left duration.(package private) final class
Observes the right values.(package private) final class
Observe the right duration.(package private) static final class
(package private) static final class
(package private) static final class
The subscriber that must be used for subscribing to the upstream source.(package private) static final class
(package private) static final class
(package private) static final class
(package private) final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) final class
(package private) final class
Subscriber when exact timed chunking is required.(package private) final class
Subscriber when the buffer chunking time and length differ.(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
static final class
(package private) static final class
(package private) static final class
(package private) static class
(package private) static final class
(package private) static final class
The subscriber that observes Observables.(package private) static final class
Observe through individual queue per observer.(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
The source subscriber and sampler.(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
(package private) static final class
Subscribed to source and scheduled on a worker.(package private) final class
Subscriber returned to the upstream.(package private) static final class
(package private) static final class
Observes the boundary.(package private) static final class
Observes the source.(package private) static final class
Observes the boundary.(package private) static final class
Observes the source.(package private) static final class
(package private) static final class
(package private) static final class
(package private) final class
(package private) final class
Subscriber with exact, non-overlapping windows.(package private) final class
Subscriber with inexact, potentially overlapping or discontinuous windows.(package private) static final class
(package private) static final class
(package private) final class
(package private) final class
Fields in rx.internal.operators declared as SubscriberModifier and TypeFieldDescriptionprotected final Subscriber
<? super R> DeferredScalarSubscriber.actual
The downstream subscriber.(package private) final Subscriber
<? super R> OnSubscribeCombineLatest.LatestCoordinator.actual
(package private) final Subscriber
<? super R> OnSubscribeConcatMap.ConcatMapSubscriber.actual
(package private) final Subscriber
<? super T> OnSubscribeFilter.FilterSubscriber.actual
(package private) final Subscriber
<? super R> OnSubscribeFlattenIterable.FlattenIterableSubscriber.actual
(package private) final Subscriber
<? super T> OnSubscribeFromAsync.BaseAsyncEmitter.actual
(package private) final Subscriber
<? super R> OnSubscribeMap.MapSubscriber.actual
(package private) final Subscriber
<? super T> OnSubscribeOnAssembly.OnAssemblySubscriber.actual
(package private) final Subscriber
<? super T> OnSubscribePublishMulticast.PublishProducer.actual
The actual subscriber to receive the events.(package private) final Subscriber
<? super T> OnSubscribeReduce.ReduceSubscriber.actual
(package private) final Subscriber
<? super List<T>> OperatorBufferWithSize.BufferExact.actual
(package private) final Subscriber
<? super List<T>> OperatorBufferWithSize.BufferOverlap.actual
(package private) final Subscriber
<? super List<T>> OperatorBufferWithSize.BufferSkip.actual
(package private) final Subscriber
<? super R> OperatorCast.CastSubscriber.actual
(package private) final Subscriber
<? super R> OperatorEagerConcatMap.EagerOuterSubscriber.actual
(package private) final Subscriber
<? super GroupedObservable<K, V>> OperatorGroupBy.GroupBySubscriber.actual
(package private) final Subscriber
<? super R> OperatorMapNotification.MapNotificationSubscriber.actual
(package private) final Subscriber
<? super Observable<? extends R>> OperatorMapPair.MapPairSubscriber.actual
(package private) final Subscriber
<? super T> OperatorTakeLast.TakeLastSubscriber.actual
(package private) final Subscriber
<? super T> OperatorTakeLastTimed.TakeLastTimedSubscriber.actual
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithSize.WindowExact.actual
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithSize.WindowOverlap.actual
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithSize.WindowSkip.actual
(package private) final Subscriber
<? super R> OperatorWithLatestFromMany.WithLatestMainSubscriber.actual
(package private) final Subscriber
<? super T> CachedObservable.ReplayProducer.child
The actual child subscriber.(package private) final Subscriber
<? super T> OnSubscribeFromArray.FromArrayProducer.child
(package private) final Subscriber
<? super List<T>> OperatorBufferWithSingleObservable.BufferingSubscriber.child
(package private) final Subscriber
<? super List<T>> OperatorBufferWithStartEndObservable.BufferingSubscriber.child
(package private) final Subscriber
<? super List<T>> OperatorBufferWithTime.ExactSubscriber.child
(package private) final Subscriber
<? super List<T>> OperatorBufferWithTime.InexactSubscriber.child
private final Subscriber
<? super T> OperatorDoOnRequest.ParentSubscriber.child
private final Subscriber
<? super Notification<T>> OperatorMaterialize.ParentSubscriber.child
(package private) final Subscriber
<? super T> OperatorMerge.MergeSubscriber.child
(package private) final Subscriber
<? super T> OperatorObserveOn.ObserveOnSubscriber.child
private final Subscriber
<? super T> OperatorOnBackpressureBuffer.BufferSubscriber.child
(package private) final Subscriber
<? super T> OperatorOnBackpressureLatest.LatestEmitter.child
(package private) final Subscriber
<? super T> OperatorPublish.InnerProducer.child
The actual child subscriber.(package private) Subscriber
<? super T> OperatorReplay.InnerProducer.child
The actual child subscriber.(package private) final Subscriber
<? super T> OperatorRetryWithPredicate.SourceSubscriber.child
(package private) final Subscriber
<? super R> OperatorScan.InitialProducer.child
private final Subscriber
<? super T> OperatorSingle.ParentSubscriber.child
(package private) final Subscriber
<? super T> OperatorSwitch.SwitchSubscriber.child
private final Subscriber
<? super T> OperatorSwitchIfEmpty.AlternateSubscriber.child
private final Subscriber
<? super T> OperatorSwitchIfEmpty.ParentSubscriber.child
(package private) final Subscriber
<? super T> OperatorTakeTimed.TakeSubscriber.child
private final Subscriber
<? super T> OperatorTakeUntilPredicate.ParentSubscriber.child
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithObservable.SourceSubscriber.child
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithObservableFactory.SourceSubscriber.child
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithStartEndObservable.SourceSubscriber.child
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithTime.ExactSubscriber.child
(package private) final Subscriber
<? super Observable<T>> OperatorWindowWithTime.InexactSubscriber.child
(package private) final Subscriber
<? super R> OperatorZip.ZipSubscriber.child
private final Subscriber
<? super Integer> OnSubscribeRange.RangeProducer.childSubscriber
private final Subscriber
<? super T> OnSubscribeFromIterable.IterableProducer.o
private final Subscriber
<? super T> OnSubscribeAmb.AmbSubscriber.subscriber
(package private) final Subscriber
<? super R> OnSubscribeGroupJoin.ResultManager.subscriber
(package private) final Subscriber
<? super T> OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber.subscriber
(package private) final Subscriber
<? super R> OnSubscribeJoin.ResultSink.subscriber
private final 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 SubscriberModifier and TypeFieldDescription(package private) final AtomicReference
<Subscriber<? super T>> OnSubscribeDetach.DetachSubscriber.actual
(package private) final AtomicReference
<Subscriber<? super T>> OperatorGroupBy.State.actual
(package private) final List
<Subscriber<? super R>> OperatorMulticast.waitingForConnect
Methods in rx.internal.operators that return SubscriberModifier and TypeMethodDescriptionSubscriber
<? super T> OperatorAll.call
(Subscriber<? super Boolean> child) Subscriber
<? super T> OperatorAny.call
(Subscriber<? super Boolean> child) Subscriber
<? super T> OperatorAsObservable.call
(Subscriber<? super T> s) Subscriber
<? super T> OperatorBufferWithSingleObservable.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithSize.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithStartEndObservable.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithTime.call
(Subscriber<? super 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 Map<K, V>> subscriber) Subscriber
<? super T> OperatorToMultimap.call
(Subscriber<? super Map<K, Collection<V>>> subscriber) Subscriber
<? super T> OperatorToObservableList.call
(Subscriber<? super List<T>> o) Subscriber
<? super T> OperatorToObservableSortedList.call
(Subscriber<? super 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) 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 SubscriberModifier and TypeMethodDescriptionvoid
BufferUntilSubscriber.OnSubscribeAction.call
(Subscriber<? super T> s) void
CachedObservable.CachedSubscribe.call
(Subscriber<? super T> t) void
EmptyObservableHolder.call
(Subscriber<? super Object> child) void
NeverObservableHolder.call
(Subscriber<? super 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 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 Long> child) void
OnSubscribeTimerPeriodically.call
(Subscriber<? super Long> child) void
OnSubscribeToObservableFuture.ToObservableFuture.call
(Subscriber<? super T> subscriber) void
OnSubscribeUsing.call
(Subscriber<? super T> subscriber) Subscriber
<? super T> OperatorAll.call
(Subscriber<? super Boolean> child) Subscriber
<? super T> OperatorAny.call
(Subscriber<? super Boolean> child) Subscriber
<? super T> OperatorAsObservable.call
(Subscriber<? super T> s) Subscriber
<? super T> OperatorBufferWithSingleObservable.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithSize.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithStartEndObservable.call
(Subscriber<? super List<T>> child) Subscriber
<? super T> OperatorBufferWithTime.call
(Subscriber<? super 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 Map<K, V>> subscriber) Subscriber
<? super T> OperatorToMultimap.call
(Subscriber<? super Map<K, Collection<V>>> subscriber) Subscriber
<? super T> OperatorToObservableList.call
(Subscriber<? super List<T>> o) Subscriber
<? super T> OperatorToObservableSortedList.call
(Subscriber<? super 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, Queue<?> q, boolean delayError) (package private) boolean
OnSubscribeFlattenIterable.FlattenIterableSubscriber.checkTerminated
(boolean d, boolean empty, Subscriber<?> a, Queue<?> q) (package private) boolean
OperatorGroupBy.GroupBySubscriber.checkTerminated
(boolean d, boolean empty, Subscriber<? super GroupedObservable<K, V>> a, 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, Queue<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, Throwable localError, SpscLinkedArrayQueue<Object> localQueue, Subscriber<? super T> localChild, boolean empty) (package private) boolean
OperatorWindowWithSize.WindowOverlap.checkTerminated
(boolean d, boolean empty, Subscriber<? super Subject<T, T>> a, 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, Queue<?> q, Throwable ex) private Action1
<Subscription> OnSubscribeRefCount.onSubscribe
(Subscriber<? super T> subscriber, AtomicBoolean writeLocked) 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.(package private) static <T,
R> void BackpressureUtils.postCompleteDrain
(AtomicLong requested, 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> 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.Constructors in rx.internal.operators with parameters of type SubscriberModifierConstructorDescription(package private)
AlternateSubscriber
(Subscriber<? super T> child, ProducerArbiter arbiter) (package private)
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 List<T>> actual, int count) BufferingSubscriber
(Subscriber<? super List<T>> child) BufferingSubscriber
(Subscriber<? super List<T>> child) BufferOverlap
(Subscriber<? super List<T>> actual, int count, int skip) BufferSkip
(Subscriber<? super List<T>> actual, int count, int skip) BufferSubscriber
(Subscriber<? super T> child, Long capacity, Action0 onOverflow, BackpressureOverflow.Strategy overflowStrategy) CastSubscriber
(Subscriber<? super R> actual, 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 List<T>> child, Scheduler.Worker inner) ExactSubscriber
(Subscriber<? super Observable<T>> child, Scheduler.Worker worker) FilterSubscriber
(Subscriber<? super T> actual, Func1<? super T, Boolean> predicate) FlattenIterableSubscriber
(Subscriber<? super R> actual, Func1<? super T, ? extends 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>, Map<K, Object>> mapFactory) InexactSubscriber
(Subscriber<? super 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) (package private)
IterableProducer
(Subscriber<? super T> o, 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 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, String stacktrace) (package private)
ParentSubscriber
(Subscriber<? super T> child) (package private)
ParentSubscriber
(Subscriber<? super Notification<T>> child) (package private)
ParentSubscriber
(Subscriber<? super T> child, boolean hasDefaultValue, T defaultValue) (package private)
ParentSubscriber
(Subscriber<? super T> child, SerialSubscription ssub, ProducerArbiter arbiter, Observable<? extends T> alternate) (package private)
ParentSubscriber
(Subscriber<? super T> child) PublishProducer
(Subscriber<? super T> actual, OnSubscribePublishMulticast<T> parent) (package private)
RangeProducer
(Subscriber<? super 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<Integer, Throwable, 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) (package private)
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 SubscriberModifierConstructorDescriptionprivate
OperatorMulticast
(Object guard, AtomicReference<Subject<? super T, ? extends R>> connectedSubject, 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 SubscriberModifier and TypeFieldDescription(package private) final Subscriber
<? super T> ProducerObserverArbiter.child
(package private) final Subscriber
<? super T> QueuedProducer.child
(package private) final Subscriber
<? super T> QueuedValueProducer.child
(package private) final Subscriber
<? super T> SingleDelayedProducer.child
The child to emit the value and completion once possible.(package private) final Subscriber
<? super T> SingleProducer.child
The child subscriber.Methods in rx.internal.producers with parameters of type SubscriberModifier and TypeMethodDescriptionprivate 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 SubscriberModifierConstructorDescriptionProducerObserverArbiter
(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 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, Queue<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.utilModifier and TypeClassDescriptionfinal class
A Subscriber that forwards the onXXX method calls to callbacks.final class
Wraps an Observer and forwards the onXXX method calls to it.Fields in rx.internal.util declared as SubscriberModifier and TypeFieldDescription(package private) final Subscriber
<? super T> ScalarSynchronousObservable.ScalarAsyncProducer.actual
(package private) final Subscriber
<? super T> ScalarSynchronousObservable.WeakSingleProducer.actual
Methods in rx.internal.util with parameters of type SubscriberModifier and TypeMethodDescriptionvoid
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 SubscriberModifierConstructorDescriptionScalarAsyncProducer
(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 SubscriberModifier and TypeFieldDescriptionprivate final Subscriber
<? super T> SyncOnSubscribe.SubscriptionProducer.actualSubscriber
(package private) Subscriber
<? super T> AsyncOnSubscribe.UnicastSubject.State.subscriber
Methods in rx.observables with parameters of type SubscriberModifier and TypeMethodDescriptionfinal void
AsyncOnSubscribe.call
(Subscriber<? super T> actualSubscriber) void
AsyncOnSubscribe.UnicastSubject.State.call
(Subscriber<? super T> s) final void
SyncOnSubscribe.call
(Subscriber<? super T> subscriber) private void
SyncOnSubscribe.SubscriptionProducer.handleThrownError
(Subscriber<? super T> a, 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 SubscriberModifierConstructorDescription(package private)
SubscriptionProducer
(Subscriber<? super T> subscriber, SyncOnSubscribe<S, T> parent, S state) -
Uses of Subscriber in rx.observers
Subclasses of Subscriber in rx.observersModifier and TypeClassDescriptionclass
SafeSubscriber
is a wrapper aroundSubscriber
that ensures that theSubscriber
complies with the Observable contract.class
Enforces single-threaded, serialized, ordered execution ofSerializedSubscriber.onNext(T)
,SerializedSubscriber.onCompleted()
, andSerializedSubscriber.onError(java.lang.Throwable)
.class
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 SubscriberMethods in rx.observers that return SubscriberModifier and TypeMethodDescriptionstatic <T> Subscriber
<T> 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> Creates anSubscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
notification but ignores anonCompleted
notification.static <T> Subscriber
<T> 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> 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 SubscriberModifier and TypeMethodDescriptionstatic <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 SubscriberModifierConstructorDescriptionSafeSubscriber
(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 SubscriberModifier and TypeFieldDescription(package private) final Subscriber
<? super T> ReplaySubject.ReplayProducer.actual
The wrapped Subscriber instance.(package private) final Subscriber
<? super T> SubjectSubscriptionManager.SubjectObserver.actual
The actual Observer.Fields in rx.subjects with type parameters of type SubscriberModifier and TypeFieldDescription(package private) final AtomicReference
<Subscriber<? super T>> UnicastSubject.State.subscriber
The single subscriber.Methods in rx.subjects with parameters of type SubscriberModifier and TypeMethodDescription(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 SubscriberModifierConstructorDescriptionReplayProducer
(Subscriber<? super T> actual, ReplaySubject.ReplayState<T> state) SubjectObserver
(Subscriber<? super T> actual)