Uses of Interface
rx.Observer
-
Packages that use Observer Package Description rx Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.rx.exceptions Exception handling utilities, safe subscriber exception classes, lifecycle exception classes.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.schedulers 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 Observer in rx
Subinterfaces of Observer in rx Modifier and Type Interface Description interface
AsyncEmitter<T>
Abstraction over a RxJava Subscriber that allows associating a resource with it and exposes the current number of downstream requested amount.Classes in rx that implement Observer Modifier and Type Class Description class
Subscriber<T>
Provides a mechanism for receiving push-based notifications from Observables, and permits manual unsubscribing from these Observables.Methods in rx with parameters of type Observer Modifier and Type Method Description void
Notification. accept(Observer<? super T> observer)
Forwards this notification on to a specifiedObserver
.Observable<T>
Observable. doOnEach(Observer<? super T> observer)
Modifies the source Observable so that it notifies an Observer for each item and terminal event it emits.Subscription
Observable. subscribe(Observer<? super T> observer)
Subscribes to an Observable and provides an Observer that implements functions to handle the items the Observable emits and any error or completion notification it issues.Subscription
Single. subscribe(Observer<? super T> observer)
Subscribes an Observer to this single and returns a Subscription that allows unsubscription. -
Uses of Observer in rx.exceptions
Methods in rx.exceptions with parameters of type Observer Modifier and Type Method Description static void
Exceptions. throwOrReport(java.lang.Throwable t, Observer<?> o)
Forwards a fatal exception or reports it to the given Observer.static void
Exceptions. throwOrReport(java.lang.Throwable t, Observer<?> o, java.lang.Object value)
Forwards a fatal exception or reports it along with the value caused it to the given Observer. -
Uses of Observer in rx.internal.operators
Classes in rx.internal.operators that implement Observer 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>
class
BufferUntilSubscriber<T>
A solution to the "time gap" problem that occurs withgroupBy
andpivot
.(package private) static class
CachedObservable.CacheState<T>
Contains the active child producers and the values to replay.(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) static class
OnSubscribeFromAsync.BaseAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.BufferAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.DropAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.ErrorAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.LatestAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.NoneAsyncEmitter<T>
(package private) static class
OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter<T>
(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>
class
OnSubscribePublishMulticast<T>
Multicasts notifications coming through its input Subscriber view to its client Subscribers via lockstep backpressure mode.(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.LatestEmitter<T>
A terminable producer which emits the latest items on request.(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
OperatorScan.InitialProducer<R>
(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 Observer Modifier and Type Field Description (package private) Observer<? super R>
OperatorZip.Zip. child
(package private) Observer<T>
OperatorWindowWithObservable.SourceSubscriber. consumer
Accessed from the serialized part.(package private) Observer<T>
OperatorWindowWithObservableFactory.SourceSubscriber. consumer
Accessed from the serialized part.(package private) Observer<T>
OperatorWindowWithStartEndObservable.SerializedSubject. consumer
(package private) Observer<T>
OperatorWindowWithTime.CountedSerializedSubject. consumer
(package private) Observer<T>
OperatorWindowWithTime.State. consumer
(package private) Observer<? super T>
OperatorDoOnEach. doOnEachObserver
(package private) static Observer
BufferUntilSubscriber. EMPTY_OBSERVER
Fields in rx.internal.operators with type parameters of type Observer Modifier and Type Field Description (package private) java.util.Map<java.lang.Integer,Observer<T2>>
OnSubscribeGroupJoin.ResultManager. leftMap
Guarded by guard.Methods in rx.internal.operators with parameters of type Observer Modifier and Type Method Description boolean
NotificationLite. accept(Observer<? super T> o, java.lang.Object n)
Unwraps the lite notification and calls the appropriate method on theObserver
.(package private) boolean
BufferUntilSubscriber.State. casObserverRef(Observer<? super T> expected, Observer<? super T> next)
OperatorWindowWithTime.State<T>
OperatorWindowWithTime.State. create(Observer<T> consumer, Observable<T> producer)
Method parameters in rx.internal.operators with type arguments of type Observer Modifier and Type Method Description (package private) void
OnSubscribeGroupJoin.ResultManager. complete(java.util.List<Observer<T2>> list)
Constructors in rx.internal.operators with parameters of type Observer Constructor Description CountedSerializedSubject(Observer<T> consumer, Observable<T> producer)
OperatorDoOnEach(Observer<? super T> doOnEachObserver)
SerializedSubject(Observer<T> consumer, Observable<T> producer)
State(Observer<T> consumer, Observable<T> producer, int count)
-
Uses of Observer in rx.internal.producers
Classes in rx.internal.producers that implement Observer Modifier and Type Class Description class
ProducerObserverArbiter<T>
Producer that serializes any event emission with requesting and producer changes.class
QueuedProducer<T>
Producer that holds an unbounded (or custom) queue, handles terminal events, enqueues values and relays them to a child subscriber on request. -
Uses of Observer in rx.internal.schedulers
Fields in rx.internal.schedulers declared as Observer Modifier and Type Field Description private Observer<Observable<Completable>>
SchedulerWhen. workerObserver
-
Uses of Observer in rx.internal.util
Classes in rx.internal.util that implement Observer Modifier and Type Class Description class
ActionNotificationObserver<T>
An Observer that forwards the onXXX method calls to a notification callback by transforming each signal type into Notifications.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 Observer Modifier and Type Field Description (package private) Observer<? super T>
ObserverSubscriber. observer
Methods in rx.internal.util with parameters of type Observer Modifier and Type Method Description boolean
RxRingBuffer. accept(java.lang.Object o, Observer child)
Constructors in rx.internal.util with parameters of type Observer Constructor Description ObserverSubscriber(Observer<? super T> observer)
-
Uses of Observer in rx.observables
Classes in rx.observables that implement Observer Modifier and Type Class Description (package private) static class
AsyncOnSubscribe.AsyncOuterManager<S,T>
(package private) static class
AsyncOnSubscribe.UnicastSubject<T>
(package private) static class
SyncOnSubscribe.SubscriptionProducer<S,T>
Contains the producer loop that reacts to downstream requests of work.Fields in rx.observables with type parameters of type Observer Modifier and Type Field Description private Func3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>,? extends S>
AsyncOnSubscribe.AsyncOnSubscribeImpl. next
private Func2<? super S,? super Observer<? super T>,? extends S>
SyncOnSubscribe.SyncOnSubscribeImpl. next
Methods in rx.observables with parameters of type Observer Modifier and Type Method Description protected S
AsyncOnSubscribe.AsyncOnSubscribeImpl. next(S state, long requested, Observer<Observable<? extends T>> observer)
protected abstract S
AsyncOnSubscribe. next(S state, long requested, Observer<Observable<? extends T>> observer)
Called to produce data to the downstream subscribers.protected abstract S
SyncOnSubscribe. next(S state, Observer<? super T> observer)
Called to produce data to the downstream subscribers.protected S
SyncOnSubscribe.SyncOnSubscribeImpl. next(S state, Observer<? super T> observer)
void
BlockingObservable. subscribe(Observer<? super T> observer)
Subscribes to the source and calls back the Observer methods on the current thread.Method parameters in rx.observables with type arguments of type Observer Modifier and Type Method Description static <S,T>
AsyncOnSubscribe<S,T>AsyncOnSubscribe. createSingleState(Func0<? extends S> generator, Action3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>> next)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
AsyncOnSubscribe<S,T>AsyncOnSubscribe. createSingleState(Func0<? extends S> generator, Action3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>> next, Action1<? super S> onUnsubscribe)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
SyncOnSubscribe<S,T>SyncOnSubscribe. createSingleState(Func0<? extends S> generator, Action2<? super S,? super Observer<? super T>> next)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
SyncOnSubscribe<S,T>SyncOnSubscribe. createSingleState(Func0<? extends S> generator, Action2<? super S,? super Observer<? super T>> next, Action1<? super S> onUnsubscribe)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
AsyncOnSubscribe<S,T>AsyncOnSubscribe. createStateful(Func0<? extends S> generator, Func3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>,? extends S> next)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
AsyncOnSubscribe<S,T>AsyncOnSubscribe. createStateful(Func0<? extends S> generator, Func3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>,? extends S> next, Action1<? super S> onUnsubscribe)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
SyncOnSubscribe<S,T>SyncOnSubscribe. createStateful(Func0<? extends S> generator, Func2<? super S,? super Observer<? super T>,? extends S> next)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <S,T>
SyncOnSubscribe<S,T>SyncOnSubscribe. createStateful(Func0<? extends S> generator, Func2<? super S,? super Observer<? super T>,? extends S> next, Action1<? super S> onUnsubscribe)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <T> AsyncOnSubscribe<java.lang.Void,T>
AsyncOnSubscribe. createStateless(Action2<java.lang.Long,? super Observer<Observable<? extends T>>> next)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <T> AsyncOnSubscribe<java.lang.Void,T>
AsyncOnSubscribe. createStateless(Action2<java.lang.Long,? super Observer<Observable<? extends T>>> next, Action0 onUnsubscribe)
Generates a synchronousAsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <T> SyncOnSubscribe<java.lang.Void,T>
SyncOnSubscribe. createStateless(Action1<? super Observer<? super T>> next)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.static <T> SyncOnSubscribe<java.lang.Void,T>
SyncOnSubscribe. createStateless(Action1<? super Observer<? super T>> next, Action0 onUnsubscribe)
Generates a synchronousSyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers.Constructor parameters in rx.observables with type arguments of type Observer Constructor Description AsyncOnSubscribeImpl(Func0<? extends S> generator, Func3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>,? extends S> next)
AsyncOnSubscribeImpl(Func0<? extends S> generator, Func3<? super S,java.lang.Long,? super Observer<Observable<? extends T>>,? extends S> next, Action1<? super S> onUnsubscribe)
AsyncOnSubscribeImpl(Func3<S,java.lang.Long,Observer<Observable<? extends T>>,S> nextFunc)
AsyncOnSubscribeImpl(Func3<S,java.lang.Long,Observer<Observable<? extends T>>,S> next, Action1<? super S> onUnsubscribe)
SyncOnSubscribeImpl(Func0<? extends S> generator, Func2<? super S,? super Observer<? super T>,? extends S> next)
SyncOnSubscribeImpl(Func0<? extends S> generator, Func2<? super S,? super Observer<? super T>,? extends S> next, Action1<? super S> onUnsubscribe)
SyncOnSubscribeImpl(Func2<S,Observer<? super T>,S> nextFunc)
SyncOnSubscribeImpl(Func2<S,Observer<? super T>,S> next, Action1<? super S> onUnsubscribe)
-
Uses of Observer in rx.observers
Classes in rx.observers that implement Observer Modifier and Type Class Description class
SafeSubscriber<T>
SafeSubscriber
is a wrapper aroundSubscriber
that ensures that theSubscriber
complies with the Observable contract.class
SerializedObserver<T>
Enforces single-threaded, serialized, ordered execution ofSerializedObserver.onNext(T)
,SerializedObserver.onCompleted()
, andSerializedObserver.onError(java.lang.Throwable)
.class
SerializedSubscriber<T>
Enforces single-threaded, serialized, ordered execution ofSerializedSubscriber.onNext(T)
,SerializedSubscriber.onCompleted()
, andSerializedSubscriber.onError(java.lang.Throwable)
.class
TestObserver<T>
Deprecated.use theTestSubscriber
insteand.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 Observer Modifier and Type Field Description private Observer<? super T>
SerializedObserver. actual
private Observer<T>
TestObserver. delegate
Deprecated.private Observer<T>
TestSubscriber. delegate
private static Observer<java.lang.Object>
Observers. EMPTY
private static Observer<java.lang.Object>
TestObserver. INERT
Deprecated.private static Observer<java.lang.Object>
TestSubscriber. INERT
The shared no-op observer.private Observer<T>
SerializedSubscriber. s
Methods in rx.observers that return Observer Modifier and Type Method Description static <T> Observer<T>
Observers. create(Action1<? super T> onNext)
Creates anObserver
that receives the emissions of anyObservable
it subscribes to viaonNext
but ignoresonCompleted
notifications; it will throw anOnErrorNotImplementedException
ifonError
is invoked.static <T> Observer<T>
Observers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError)
Creates anObserver
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
notification but ignores anonCompleted
notification.static <T> Observer<T>
Observers. create(Action1<? super T> onNext, Action1<java.lang.Throwable> onError, Action0 onComplete)
Creates anObserver
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications.static <T> Observer<T>
Observers. empty()
Methods in rx.observers with parameters of type Observer Modifier and Type Method Description static <T> TestSubscriber<T>
TestSubscriber. create(Observer<T> delegate)
Factory method to construct a TestSubscriber which delegates events to the given Observer and an issues an initial request of Long.MAX_VALUE.static <T> TestSubscriber<T>
TestSubscriber. create(Observer<T> delegate, long initialRequest)
Factory method to construct a TestSubscriber which delegates events to the given Observer and issues the given initial request amount.static <T> Subscriber<T>
Subscribers. from(Observer<? super T> o)
Converts anObserver
into aSubscriber
.Constructors in rx.observers with parameters of type Observer Constructor Description SerializedObserver(Observer<? super T> s)
TestObserver(Observer<T> delegate)
Deprecated.TestSubscriber(Observer<T> delegate)
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to the given Observer.TestSubscriber(Observer<T> delegate, long initialRequest)
Constructs a TestSubscriber with the initial request to be requested from upstream and a delegate Observer to wrap. -
Uses of Observer in rx.subjects
Classes in rx.subjects that implement Observer Modifier and Type Class Description class
AsyncSubject<T>
Subject that publishes only the last item observed to eachObserver
once the sourceObservable
has completed.class
BehaviorSubject<T>
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribedObserver
.class
PublishSubject<T>
Subject that, once anObserver
has subscribed, emits all subsequently observed items to the subscriber.class
ReplaySubject<T>
Subject that buffers all items it observes and replays them to anyObserver
that subscribes.(package private) static class
ReplaySubject.ReplayState<T>
Holds onto the array of Subscriber-wrapping ReplayProducers and the buffer that holds values to be replayed; it manages subscription and signal dispatching.class
SerializedSubject<T,R>
Wraps aSubject
so that it is safe to call its variouson
methods from different threads.class
Subject<T,R>
Represents an object that is both an Observable and an Observer.protected static class
SubjectSubscriptionManager.SubjectObserver<T>
Observer wrapping the actual Subscriber and providing various emission facilities.class
TestSubject<T>
A variety of Subject that is useful for testing purposes.class
UnicastSubject<T>
A Subject variant which buffers events until a single Subscriber arrives and replays them to it and potentially switches to direct delivery once the Subscriber caught up and requested an unlimited amount.(package private) static class
UnicastSubject.State<T>
The single-consumption replaying state.Methods in rx.subjects that return Observer Modifier and Type Method Description (package private) Observer<? super T>
SubjectSubscriptionManager.SubjectObserver. getActual()
-