Uses of Interface
rx.Observable.OnSubscribe
-
Packages that use Observable.OnSubscribe 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.util rx.observables Classes extending the Observable base reactive class, synchronous and asynchronous event generators.rx.plugins Callback types and a central plugin handler class to hook into the lifecycle of the base reactive types and schedulers.rx.subjects Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables). -
-
Uses of Observable.OnSubscribe in rx
Classes in rx that implement Observable.OnSubscribe Modifier and Type Class Description (package private) static class
Observable.OnSubscribeExtend<T>
Transforms a OnSubscribe.call() into an Observable.subscribe() call.Fields in rx declared as Observable.OnSubscribe Modifier and Type Field Description (package private) Observable.OnSubscribe<T>
Observable. onSubscribe
(package private) Observable.OnSubscribe<T>
Single. onSubscribe
Methods in rx with parameters of type Observable.OnSubscribe Modifier and Type Method Description static <T> Observable<T>
Observable. create(Observable.OnSubscribe<T> f)
This method requires advanced knowledge about building operators and data sources; please consider other standard methods first; Returns an Observable that will execute the specified function when aSubscriber
subscribes to it.Method parameters in rx with type arguments of type Observable.OnSubscribe Modifier and Type Method Description <R> R
Observable. extend(Func1<? super Observable.OnSubscribe<T>,? extends R> conversion)
Passes all emitted values from this Observable to the provided conversion function to be collected and returned as a single value.Constructors in rx with parameters of type Observable.OnSubscribe Constructor Description Observable(Observable.OnSubscribe<T> f)
Creates an Observable with a Function to execute when it is subscribed to.Single(Observable.OnSubscribe<T> f)
-
Uses of Observable.OnSubscribe in rx.internal.operators
Classes in rx.internal.operators that implement Observable.OnSubscribe Modifier and Type Class Description (package private) static class
BufferUntilSubscriber.OnSubscribeAction<T>
(package private) static class
CachedObservable.CachedSubscribe<T>
Manages the subscription of child subscribers by setting up a replay producer and performs auto-connection of the very first subscription.class
EmptyObservableHolder
Holds a singleton instance of an empty Observable which is stateless and completes the child subscriber immediately.class
NeverObservableHolder
Holds a singleton instance of a never Observable which is stateless doesn't call any of the Subscriber's methods.class
OnSubscribeAmb<T>
Given multipleObservable
s, propagates the one that first emits an item.class
OnSubscribeAutoConnect<T>
Wraps a ConnectableObservable and calls its connect() method once the specified number of Subscribers have subscribed.class
OnSubscribeCollect<T,R>
class
OnSubscribeCombineLatest<T,R>
class
OnSubscribeConcatMap<T,R>
Maps a source sequence into Observables and concatenates them in order, subscribing to one at a time.class
OnSubscribeDefer<T>
Do not create the Observable until an Observer subscribes; create a fresh Observable on each subscription.class
OnSubscribeDelaySubscription<T>
Delays the subscription to the source by the given amount, running on the given scheduler.class
OnSubscribeDelaySubscriptionOther<T,U>
Delays the subscription to the main source until the other observable fires an event or completes.class
OnSubscribeDelaySubscriptionWithSelector<T,U>
Delays the subscription until the Observable emits an event.class
OnSubscribeDetach<T>
Nulls out references to upstream data structures when the source terminates or the child unsubscribes.class
OnSubscribeFilter<T>
Filters an Observable by discarding any items it emits that do not meet some test.class
OnSubscribeFlattenIterable<T,R>
Flattens a sequence if Iterable sources, generated via a function, into a single sequence.(package private) static class
OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable<T,R>
A custom flattener that works from a scalar value and computes the iterable during subscription time.class
OnSubscribeFromArray<T>
class
OnSubscribeFromAsync<T>
class
OnSubscribeFromCallable<T>
Do not invoke the function until an Observer subscribes; Invokes function on each subscription.class
OnSubscribeFromIterable<T>
Converts anIterable
sequence into anObservable
.class
OnSubscribeGroupJoin<T1,T2,D1,D2,R>
Correlates two sequences when they overlap and groups the results.(package private) static class
OnSubscribeGroupJoin.WindowObservableFunc<T>
The reference-counted window observable.class
OnSubscribeJoin<TLeft,TRight,TLeftDuration,TRightDuration,R>
Correlates the elements of two sequences based on overlapping durations.class
OnSubscribeLift<T,R>
Transforms the downstream Subscriber into a Subscriber via an operator callback and calls the parent OnSubscribe.call() method with it.class
OnSubscribeMap<T,R>
Applies a function of your choosing to every item emitted by anObservable
, and emits the results of this transformation as a newObservable
.class
OnSubscribeOnAssembly<T>
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.class
OnSubscribePublishMulticast<T>
Multicasts notifications coming through its input Subscriber view to its client Subscribers via lockstep backpressure mode.class
OnSubscribeRange
Emit ints from start to end inclusive.class
OnSubscribeRedo<T>
class
OnSubscribeReduce<T>
class
OnSubscribeReduceSeed<T,R>
class
OnSubscribeRefCount<T>
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.class
OnSubscribeTakeLastOne<T>
class
OnSubscribeThrow<T>
class
OnSubscribeTimerOnce
Timer that emits a single 0L and completes after the specified time.class
OnSubscribeTimerPeriodically
Emit 0L after the initial period and ever increasing number after each period.(package private) static class
OnSubscribeToObservableFuture.ToObservableFuture<T>
class
OnSubscribeUsing<T,Resource>
Constructs an observable sequence that depends on a resource object.(package private) static class
OperatorGroupBy.State<T,K>
class
OperatorSubscribeOn<T>
Subscribes Observers on the specifiedScheduler
.class
OperatorWithLatestFromMany<T,R>
Fields in rx.internal.operators declared as Observable.OnSubscribe Modifier and Type Field Description (package private) Observable.OnSubscribe<T>
OnSubscribeLift. parent
(package private) Observable.OnSubscribe<T>
OnSubscribeOnAssembly. source
Methods in rx.internal.operators that return Observable.OnSubscribe Modifier and Type Method Description static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(java.lang.Iterable<? extends Observable<? extends T>> sources)
Given a set ofObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2)
Given twoObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3)
Given threeObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4)
Given fourObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4, Observable<? extends T> o5)
Given fiveObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4, Observable<? extends T> o5, Observable<? extends T> o6)
Given sixObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4, Observable<? extends T> o5, Observable<? extends T> o6, Observable<? extends T> o7)
Given sevenObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4, Observable<? extends T> o5, Observable<? extends T> o6, Observable<? extends T> o7, Observable<? extends T> o8)
Given eightObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeAmb. amb(Observable<? extends T> o1, Observable<? extends T> o2, Observable<? extends T> o3, Observable<? extends T> o4, Observable<? extends T> o5, Observable<? extends T> o6, Observable<? extends T> o7, Observable<? extends T> o8, Observable<? extends T> o9)
Given nineObservable
s, propagates the one that first emits an item.static <T> Observable.OnSubscribe<T>
OnSubscribeToObservableFuture. toObservableFuture(java.util.concurrent.Future<? extends T> that)
static <T> Observable.OnSubscribe<T>
OnSubscribeToObservableFuture. toObservableFuture(java.util.concurrent.Future<? extends T> that, long time, java.util.concurrent.TimeUnit unit)
Constructors in rx.internal.operators with parameters of type Observable.OnSubscribe Constructor Description CachedObservable(Observable.OnSubscribe<T> onSubscribe, CachedObservable.CacheState<T> state)
Private constructor because state needs to be shared between the Observable body and the onSubscribe function.OnSubscribeLift(Observable.OnSubscribe<T> parent, Observable.Operator<? extends R,? super T> operator)
OnSubscribeOnAssembly(Observable.OnSubscribe<T> source)
OperatorPublish(Observable.OnSubscribe<T> onSubscribe, Observable<? extends T> source, java.util.concurrent.atomic.AtomicReference<OperatorPublish.PublishSubscriber<T>> current)
OperatorReplay(Observable.OnSubscribe<T> onSubscribe, Observable<? extends T> source, java.util.concurrent.atomic.AtomicReference<OperatorReplay.ReplaySubscriber<T>> current, Func0<? extends OperatorReplay.ReplayBuffer<T>> bufferFactory)
-
Uses of Observable.OnSubscribe in rx.internal.util
Classes in rx.internal.util that implement Observable.OnSubscribe Modifier and Type Class Description (package private) static class
ScalarSynchronousObservable.JustOnSubscribe<T>
The OnSubscribe callback for the Observable constructor.(package private) static class
ScalarSynchronousObservable.ScalarAsyncOnSubscribe<T>
The OnSubscribe implementation that creates the ScalarAsyncProducer for each incoming subscriber. -
Uses of Observable.OnSubscribe in rx.observables
Classes in rx.observables that implement Observable.OnSubscribe Modifier and Type Class Description class
AsyncOnSubscribe<S,T>
A utility class to createOnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers.(package private) static class
AsyncOnSubscribe.AsyncOnSubscribeImpl<S,T>
An implementation of AsyncOnSubscribe that delegatesAsyncOnSubscribe.next(Object, long, Observer)
,AsyncOnSubscribe.generateState()
, andAsyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures.(package private) static class
AsyncOnSubscribe.UnicastSubject.State<T>
class
SyncOnSubscribe<S,T>
A utility class to createOnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers.(package private) static class
SyncOnSubscribe.SyncOnSubscribeImpl<S,T>
An implementation of SyncOnSubscribe that delegatesSyncOnSubscribe#next(Object, Subscriber)
,SyncOnSubscribe.generateState()
, andSyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures.Methods in rx.observables with parameters of type Observable.OnSubscribe Modifier and Type Method Description static <K,T>
GroupedObservable<K,T>GroupedObservable. create(K key, Observable.OnSubscribe<T> f)
Returns an Observable that will execute the specified function when aSubscriber
subscribes to it.Constructors in rx.observables with parameters of type Observable.OnSubscribe Constructor Description ConnectableObservable(Observable.OnSubscribe<T> onSubscribe)
GroupedObservable(K key, Observable.OnSubscribe<T> onSubscribe)
-
Uses of Observable.OnSubscribe in rx.plugins
Fields in rx.plugins with type parameters of type Observable.OnSubscribe Modifier and Type Field Description (package private) static Func1<Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onObservableCreate
(package private) static Func1<Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onObservableCreate
(package private) static Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onObservableStart
(package private) static Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onObservableStart
(package private) static Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onSingleStart
(package private) static Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. onSingleStart
Methods in rx.plugins that return Observable.OnSubscribe Modifier and Type Method Description static <T> Observable.OnSubscribe<T>
RxJavaHooks. onCreate(Observable.OnSubscribe<T> onSubscribe)
Hook to call when an Observable is created.<T> Observable.OnSubscribe<T>
RxJavaObservableExecutionHook. onCreate(Observable.OnSubscribe<T> f)
Deprecated.static <T> Observable.OnSubscribe<T>
RxJavaHooks. onObservableStart(Observable<T> instance, Observable.OnSubscribe<T> onSubscribe)
Hook to call before the child subscriber is subscribed to the OnSubscribe action.static <T> Observable.OnSubscribe<T>
RxJavaHooks. onSingleStart(Single<T> instance, Observable.OnSubscribe<T> onSubscribe)
Hook to call before the child subscriber is subscribed to the OnSubscribe action.<T> Observable.OnSubscribe<T>
RxJavaObservableExecutionHook. onSubscribeStart(Observable<? extends T> observableInstance, Observable.OnSubscribe<T> onSubscribe)
Deprecated.<T> Observable.OnSubscribe<T>
RxJavaSingleExecutionHook. onSubscribeStart(Single<? extends T> singleInstance, Observable.OnSubscribe<T> onSubscribe)
Deprecated.Methods in rx.plugins that return types with arguments of type Observable.OnSubscribe Modifier and Type Method Description static Func1<Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnObservableCreate()
Returns the current Observable onCreate hook function or null if it is set to the default pass-through.static Func1<Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnObservableCreate()
Returns the current Observable onCreate hook function or null if it is set to the default pass-through.static Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnObservableStart()
Returns the current Observable onStart hook function or null if it is set to the default pass-through.static Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnObservableStart()
Returns the current Observable onStart hook function or null if it is set to the default pass-through.static Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnSingleStart()
Returns the current Single onStart hook function or null if it is set to the default pass-through.static Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe>
RxJavaHooks. getOnSingleStart()
Returns the current Single onStart hook function or null if it is set to the default pass-through.Methods in rx.plugins with parameters of type Observable.OnSubscribe Modifier and Type Method Description static <T> Observable.OnSubscribe<T>
RxJavaHooks. onCreate(Observable.OnSubscribe<T> onSubscribe)
Hook to call when an Observable is created.<T> Observable.OnSubscribe<T>
RxJavaObservableExecutionHook. onCreate(Observable.OnSubscribe<T> f)
Deprecated.static <T> Observable.OnSubscribe<T>
RxJavaHooks. onObservableStart(Observable<T> instance, Observable.OnSubscribe<T> onSubscribe)
Hook to call before the child subscriber is subscribed to the OnSubscribe action.static <T> Observable.OnSubscribe<T>
RxJavaHooks. onSingleStart(Single<T> instance, Observable.OnSubscribe<T> onSubscribe)
Hook to call before the child subscriber is subscribed to the OnSubscribe action.<T> Observable.OnSubscribe<T>
RxJavaObservableExecutionHook. onSubscribeStart(Observable<? extends T> observableInstance, Observable.OnSubscribe<T> onSubscribe)
Deprecated.<T> Observable.OnSubscribe<T>
RxJavaSingleExecutionHook. onSubscribeStart(Single<? extends T> singleInstance, Observable.OnSubscribe<T> onSubscribe)
Deprecated.Method parameters in rx.plugins with type arguments of type Observable.OnSubscribe Modifier and Type Method Description static void
RxJavaHooks. setOnObservableCreate(Func1<Observable.OnSubscribe,Observable.OnSubscribe> onObservableCreate)
Sets the Observable onCreate hook function unless a lockdown is in effect.static void
RxJavaHooks. setOnObservableCreate(Func1<Observable.OnSubscribe,Observable.OnSubscribe> onObservableCreate)
Sets the Observable onCreate hook function unless a lockdown is in effect.static void
RxJavaHooks. setOnObservableStart(Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe> onObservableStart)
Sets the hook function that is called when a subscriber subscribes to a Observable unless a lockdown is in effect.static void
RxJavaHooks. setOnObservableStart(Func2<Observable,Observable.OnSubscribe,Observable.OnSubscribe> onObservableStart)
Sets the hook function that is called when a subscriber subscribes to a Observable unless a lockdown is in effect.static void
RxJavaHooks. setOnSingleStart(Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe> onSingleStart)
Sets the hook function that is called when a subscriber subscribes to a Single unless a lockdown is in effect.static void
RxJavaHooks. setOnSingleStart(Func2<Single,Observable.OnSubscribe,Observable.OnSubscribe> onSingleStart)
Sets the hook function that is called when a subscriber subscribes to a Single unless a lockdown is in effect. -
Uses of Observable.OnSubscribe in rx.subjects
Classes in rx.subjects that implement Observable.OnSubscribe Modifier and Type Class Description (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.(package private) class
SubjectSubscriptionManager<T>
Represents the typical state and OnSubscribe logic for a Subject implementation.(package private) static class
UnicastSubject.State<T>
The single-consumption replaying state.Constructors in rx.subjects with parameters of type Observable.OnSubscribe Constructor Description AsyncSubject(Observable.OnSubscribe<T> onSubscribe, SubjectSubscriptionManager<T> state)
BehaviorSubject(Observable.OnSubscribe<T> onSubscribe, SubjectSubscriptionManager<T> state)
PublishSubject(Observable.OnSubscribe<T> onSubscribe, SubjectSubscriptionManager<T> state)
Subject(Observable.OnSubscribe<R> onSubscribe)
TestSubject(Observable.OnSubscribe<T> onSubscribe, SubjectSubscriptionManager<T> state, TestScheduler scheduler)
-