Package | Description |
---|---|
rx |
Base reactive classes: Observable, Single and Completable; base reactive consumers;
other common base interfaces.
|
rx.functions |
Functional interfaces of functions and actions of arity 0 to 9 and related
utility classes.
|
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.observers |
Default wrappers and implementations for the base reactive consumer classes and interfaces;
utility classes for creating them from callbacks.
|
rx.plugins |
Callback types and a central plugin handler class to hook into the lifecycle
of the base reactive types and schedulers.
|
Modifier and Type | Interface and Description |
---|---|
static interface |
Completable.OnSubscribe
Callback used for building deferred computations that takes a CompletableSubscriber.
|
static interface |
Observable.OnSubscribe<T>
Invoked when Observable.subscribe is called.
|
static interface |
Single.OnSubscribe<T>
Invoked when Single.execute is called.
|
Modifier and Type | Method and Description |
---|---|
static <T> Observable<T> |
Observable.create(Action1<Emitter<T>> emitter,
Emitter.BackpressureMode backpressure)
Provides an API (via a cold Observable) that bridges the reactive world with the callback-style,
generally non-backpressured world.
|
Single<T> |
Single.doOnEach(Action1<Notification<? extends T>> onNotification)
|
Observable<T> |
Observable.doOnEach(Action1<Notification<? super T>> onNotification)
Modifies the source Observable so that it invokes an action for each item and terminal event it emits.
|
Completable |
Completable.doOnEach(Action1<Notification<Object>> onNotification)
Returns a Completable which calls the given onNotification callback when this Completable emits an error or completes.
|
Observable<T> |
Observable.doOnError(Action1<? super Throwable> onError)
Modifies the source Observable so that it invokes an action if it calls
onError . |
Completable |
Completable.doOnError(Action1<? super Throwable> onError)
Returns a Completable which calls the given onError callback if this Completable emits an error.
|
Single<T> |
Single.doOnError(Action1<Throwable> onError)
Modifies the source
Single so that it invokes an action if it calls onError . |
protected Completable |
Completable.doOnLifecycle(Action1<? super Subscription> onSubscribe,
Action1<? super Throwable> onError,
Action0 onComplete,
Action0 onAfterTerminate,
Action0 onUnsubscribe)
Returns a Completable instance that calls the various callbacks on the specific
lifecycle events.
|
protected Completable |
Completable.doOnLifecycle(Action1<? super Subscription> onSubscribe,
Action1<? super Throwable> onError,
Action0 onComplete,
Action0 onAfterTerminate,
Action0 onUnsubscribe)
Returns a Completable instance that calls the various callbacks on the specific
lifecycle events.
|
Observable<T> |
Observable.doOnNext(Action1<? super T> onNext)
Modifies the source Observable so that it invokes an action when it calls
onNext . |
Observable<T> |
Observable.doOnRequest(Action1<? super Long> onRequest)
Modifies the source
Observable so that it invokes the given action when it receives a
request for more items. |
Completable |
Completable.doOnSubscribe(Action1<? super Subscription> onSubscribe)
Returns a Completable instance that calls the given onSubscribe callback with the disposable
that child subscribers receive on subscription.
|
Single<T> |
Single.doOnSuccess(Action1<? super T> onSuccess)
Modifies the source
Single so that it invokes an action when it calls onSuccess . |
void |
Observable.forEach(Action1<? super T> onNext)
Subscribes to the
Observable and receives notifications for each element. |
void |
Observable.forEach(Action1<? super T> onNext,
Action1<Throwable> onError)
Subscribes to the
Observable and receives notifications for each element and error events. |
void |
Observable.forEach(Action1<? super T> onNext,
Action1<Throwable> onError)
Subscribes to the
Observable and receives notifications for each element and error events. |
void |
Observable.forEach(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Subscribes to the
Observable and receives notifications for each element and the terminal events. |
void |
Observable.forEach(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Subscribes to the
Observable and receives notifications for each element and the terminal events. |
static Completable |
Completable.fromEmitter(Action1<CompletableEmitter> producer)
Provides an API (in a cold Completable) that bridges the Completable-reactive world
with the callback-based world.
|
static <T> Single<T> |
Single.fromEmitter(Action1<SingleEmitter<T>> producer)
Provides an API (in a cold Single) that bridges the Single-reactive world
with the callback-based world.
|
Observable<T> |
Observable.onBackpressureDrop(Action1<? super T> onDrop)
Instructs an Observable that is emitting items faster than its observer can consume them to discard,
rather than emit, those items that its observer is not prepared to observe.
|
Subscription |
Completable.subscribe(Action0 onComplete,
Action1<? super Throwable> onError)
Subscribes to this Completable and calls back either the onError or onComplete functions.
|
Subscription |
Single.subscribe(Action1<? super T> onSuccess)
Subscribes to a Single and provides a callback to handle the item it emits.
|
Subscription |
Observable.subscribe(Action1<? super T> onNext)
Subscribes to an Observable and provides a callback to handle the items it emits.
|
Subscription |
Single.subscribe(Action1<? super T> onSuccess,
Action1<Throwable> onError)
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it
issues.
|
Subscription |
Single.subscribe(Action1<? super T> onSuccess,
Action1<Throwable> onError)
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it
issues.
|
Subscription |
Observable.subscribe(Action1<? super T> onNext,
Action1<Throwable> onError)
Subscribes to an Observable and provides callbacks to handle the items it emits and any error
notification it issues.
|
Subscription |
Observable.subscribe(Action1<? super T> onNext,
Action1<Throwable> onError)
Subscribes to an Observable and provides callbacks to handle the items it emits and any error
notification it issues.
|
Subscription |
Observable.subscribe(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onCompleted)
Subscribes to an Observable and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
Subscription |
Observable.subscribe(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onCompleted)
Subscribes to an Observable and provides callbacks to handle the items it emits and any error or
completion notification it issues.
|
static <R> Completable |
Completable.using(Func0<R> resourceFunc0,
Func1<? super R,? extends Completable> completableFunc1,
Action1<? super R> disposer)
Returns a Completable instance which manages a resource along
with a custom Completable instance while the subscription is active.
|
static <R> Completable |
Completable.using(Func0<R> resourceFunc0,
Func1<? super R,? extends Completable> completableFunc1,
Action1<? super R> disposer,
boolean eager)
Returns a Completable instance which manages a resource along
with a custom Completable instance while the subscription is active and performs eager or lazy
resource disposition.
|
static <T,Resource> |
Observable.using(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Observable<? extends T>> observableFactory,
Action1<? super Resource> disposeAction)
Constructs an Observable that creates a dependent resource object which is disposed of on unsubscription.
|
static <T,Resource> |
Observable.using(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Observable<? extends T>> observableFactory,
Action1<? super Resource> disposeAction,
boolean disposeEagerly)
Constructs an Observable that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and unsubscription does not occur
before termination. |
static <T,Resource> |
Single.using(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Single<? extends T>> singleFactory,
Action1<? super Resource> disposeAction)
Constructs a Single that creates a dependent resource object which is disposed of on unsubscription.
|
static <T,Resource> |
Single.using(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Single<? extends T>> singleFactory,
Action1<? super Resource> disposeAction,
boolean disposeEagerly)
Constructs a Single that creates a dependent resource object which is disposed of just before
termination if you have set
disposeEagerly to true and unsubscription does not occur
before termination. |
Modifier and Type | Method and Description |
---|---|
<K,R> Observable<GroupedObservable<K,R>> |
Observable.groupBy(Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends R> elementSelector,
Func1<Action1<K>,Map<K,Object>> evictingMapFactory)
Deprecated.
since 1.3.7, use
Observable.groupBy(Func1, Func1, int, boolean, Func1)
instead which uses much less memory. Please take note of the
usage difference involving the evicting action which now expects
the value from the map instead of the key. |
<K,R> Observable<GroupedObservable<K,R>> |
Observable.groupBy(Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends R> elementSelector,
int bufferSize,
boolean delayError,
Func1<Action1<Object>,Map<K,Object>> evictingMapFactory)
Groups the items emitted by an
Observable according to a specified criterion, and emits these
grouped items as GroupedObservable s. |
Modifier and Type | Method and Description |
---|---|
static Action1<Throwable> |
Actions.errorNotImplemented()
Returns an action which throws OnErrorNotImplementedException.
|
static <T> Action1<T> |
Actions.toAction1(Action0 action)
Wraps an Action0 instance into an Action1 instance where the latter calls
the former.
|
Modifier and Type | Method and Description |
---|---|
static <T0> FuncN<Void> |
Functions.fromAction(Action1<? super T0> f)
|
static <T1> Func1<T1,Void> |
Actions.toFunc(Action1<T1> action)
Converts an
Action1 to a function that calls the action and returns null . |
static <T1,R> Func1<T1,R> |
Actions.toFunc(Action1<T1> action,
R result)
Converts an
Action1 to a function that calls the action and returns a specified value. |
Modifier and Type | Class and Description |
---|---|
class |
CompletableFlatMapSingleToCompletable<T> |
class |
CompletableFromEmitter
Allows push-based emission of terminal events to a CompletableSubscriber.
|
class |
CompletableOnSubscribeConcat |
class |
CompletableOnSubscribeConcatArray |
class |
CompletableOnSubscribeConcatIterable |
class |
CompletableOnSubscribeMerge |
class |
CompletableOnSubscribeMergeArray |
class |
CompletableOnSubscribeMergeDelayErrorArray |
class |
CompletableOnSubscribeMergeDelayErrorIterable |
class |
CompletableOnSubscribeMergeIterable |
class |
CompletableOnSubscribeTimeout |
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 multiple
Observable 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 |
OnSubscribeCreate<T> |
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 |
OnSubscribeDoOnEach<T>
Calls specified actions for each notification.
|
class |
OnSubscribeFilter<T>
Filters an Observable by discarding any items it emits that do not meet some test.
|
class |
OnSubscribeFlatMapCompletable<T>
Maps upstream values to Completables and merges them, up to a given
number of them concurrently, optionally delaying errors.
|
class |
OnSubscribeFlatMapSingle<T,R>
Maps upstream values to Singles and merges them, up to a given
number of them concurrently, optionally delaying errors.
|
class |
OnSubscribeFlattenIterable<T,R>
Flattens a sequence if Iterable sources, generated via a function, into a single sequence.
|
class |
OnSubscribeFromArray<T> |
class |
OnSubscribeFromCallable<T>
Do not invoke the function until an Observer subscribes; Invokes function on each
subscription.
|
class |
OnSubscribeFromIterable<T>
Converts an
Iterable sequence into an Observable . |
class |
OnSubscribeGroupJoin<T1,T2,D1,D2,R>
Correlates two sequences when they overlap and groups the results.
|
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 an
Observable , and emits the results of
this transformation as a new Observable . |
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 |
OnSubscribeOnAssemblyCompletable<T>
Captures the current stack when it is instantiated, makes
it available through a field and attaches it to all
passing exception.
|
class |
OnSubscribeOnAssemblySingle<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 integers 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 |
OnSubscribeSingle<T>
Allows conversion of an Observable to a Single ensuring that exactly one item is emitted - no more and no less.
|
class |
OnSubscribeSkipTimed<T>
Skips elements until a specified time elapses.
|
class |
OnSubscribeSwitchIfEmpty<T>
If the Observable completes without emitting any items, subscribe to an alternate Observable.
|
class |
OnSubscribeTakeLastOne<T> |
class |
OnSubscribeThrow<T>
|
class |
OnSubscribeTimeoutSelectorWithFallback<T,U,V>
Switches to the fallback Observable if: the first upstream item doesn't arrive before
the first timeout Observable signals an item or completes; or the Observable generated from
the previous upstream item signals its item or completes before the upstream signals the next item
of its own.
|
class |
OnSubscribeTimeoutTimedWithFallback<T>
Switches to consuming a fallback Observable if the main source doesn't signal an onNext event
within the given time frame after subscription or the previous onNext event.
|
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.
|
class |
OnSubscribeToMap<T,K,V>
Maps the elements of the source observable into a java.util.Map instance and
emits that once the source observable completes.
|
class |
OnSubscribeToMultimap<T,K,V>
Maps the elements of the source observable into a multimap
(Map<K, Collection<V>>) where each
key entry has a collection of the source's values.
|
class |
OnSubscribeUsing<T,Resource>
Constructs an observable sequence that depends on a resource object.
|
class |
OperatorSubscribeOn<T>
Subscribes Observers on the specified
Scheduler . |
class |
OperatorWithLatestFromMany<T,R> |
class |
SingleDelay<T>
Signal the success or error value on the Scheduler's thread.
|
class |
SingleDoAfterTerminate<T>
Execute an action after onSuccess or onError has been delivered.
|
class |
SingleDoOnEvent<T> |
class |
SingleDoOnSubscribe<T>
Call an Action0 when the subscription happens to the source.
|
class |
SingleDoOnUnsubscribe<T>
Call an Action0 when the subscription happens to the source.
|
class |
SingleFromCallable<T>
Execute a callable and emit its resulting value.
|
class |
SingleFromEmitter<T>
Calls an action with a SingleEmitter instance for each individual subscribers that
generates a terminal signal (eventually).
|
class |
SingleFromFuture<T>
Wait and emit the value of the Future.
|
class |
SingleFromObservable<T>
Wrap an Observable.OnSubscribe and expose it as a Single.OnSubscribe.
|
class |
SingleLiftObservableOperator<T,R>
Lift an Observable.Operator into the Single sequence.
|
class |
SingleObserveOn<T>
Signal the success or error value on the Scheduler's thread.
|
class |
SingleOnErrorReturn<T>
Signal a value returned by a resumeFunction when the source signals a Throwable.
|
class |
SingleOnSubscribeDelaySubscriptionOther<T>
Delays the subscription to the Single until the Observable
fires an event or completes.
|
class |
SingleOnSubscribeMap<T,R>
Applies a function of your choosing to every item emitted by an
Single , and emits the results of
this transformation as a new Single . |
class |
SingleOnSubscribeUsing<T,Resource>
Generates a resource, derives a Single from it and disposes that resource once the
Single terminates.
|
class |
SingleOperatorOnErrorResumeNext<T> |
class |
SingleTakeUntilCompletable<T>
Relay the source signals if the other doesn't terminate before.
|
class |
SingleTakeUntilObservable<T,U>
Relay the source signals if the other doesn't terminate before.
|
class |
SingleTakeUntilSingle<T,U>
Relay the source signals if the other doesn't terminate before.
|
class |
SingleTimeout<T> |
class |
SingleToObservable<T>
Expose a Single.OnSubscribe as an Observable.OnSubscribe.
|
Modifier and Type | Method and Description |
---|---|
void |
OperatorReplay.connect(Action1<? super Subscription> connection) |
void |
OperatorPublish.connect(Action1<? super Subscription> connection) |
void |
OperatorMulticast.connect(Action1<? super Subscription> connection) |
Constructor and Description |
---|
CompletableFromEmitter(Action1<CompletableEmitter> producer) |
OnSubscribeAutoConnect(ConnectableObservable<? extends T> source,
int numberOfSubscribers,
Action1<? super Subscription> connection) |
OnSubscribeCreate(Action1<Emitter<T>> Emitter,
Emitter.BackpressureMode backpressure) |
OnSubscribeUsing(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Observable<? extends T>> observableFactory,
Action1<? super Resource> dispose,
boolean disposeEagerly) |
OperatorDoOnRequest(Action1<? super Long> request) |
OperatorOnBackpressureDrop(Action1<? super T> onDrop) |
SingleDoOnEvent(Single<T> source,
Action1<? super T> onSuccess,
Action1<Throwable> onError) |
SingleDoOnEvent(Single<T> source,
Action1<? super T> onSuccess,
Action1<Throwable> onError) |
SingleFromEmitter(Action1<SingleEmitter<T>> producer) |
SingleOnSubscribeUsing(Func0<Resource> resourceFactory,
Func1<? super Resource,? extends Single<? extends T>> observableFactory,
Action1<? super Resource> disposeAction,
boolean disposeEagerly) |
Constructor and Description |
---|
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) |
OperatorGroupBy(Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends V> valueSelector,
Func1<Action1<K>,Map<K,Object>> mapFactory)
Deprecated.
|
OperatorGroupBy(Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends V> valueSelector,
int bufferSize,
boolean delayError,
Func1<Action1<K>,Map<K,Object>> mapFactory)
Deprecated.
|
OperatorGroupByEvicting(Func1<? super T,? extends K> keySelector,
Func1<? super T,? extends V> valueSelector,
int bufferSize,
boolean delayError,
Func1<Action1<Object>,Map<K,Object>> mapFactory) |
Modifier and Type | Field and Description |
---|---|
static Action1<Throwable> |
InternalObservableUtils.ERROR_NOT_IMPLEMENTED
Throws an OnErrorNotImplementedException when called.
|
Modifier and Type | Method and Description |
---|---|
void |
OpenHashSet.clear(Action1<? super T> clearAction) |
Constructor and Description |
---|
ActionNotificationObserver(Action1<Notification<? super T>> onNotification) |
ActionObserver(Action1<? super T> onNext,
Action1<? super Throwable> onError,
Action0 onCompleted) |
ActionObserver(Action1<? super T> onNext,
Action1<? super Throwable> onError,
Action0 onCompleted) |
ActionSubscriber(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onCompleted) |
ActionSubscriber(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onCompleted) |
Modifier and Type | Class and Description |
---|---|
class |
AsyncOnSubscribe<S,T>
A utility class to create
OnSubscribe<T> functions that respond correctly to back
pressure requests from subscribers. |
class |
SyncOnSubscribe<S,T>
A utility class to create
OnSubscribe<T> functions that responds correctly to back
pressure requests from subscribers. |
Modifier and Type | Method and Description |
---|---|
Observable<T> |
ConnectableObservable.autoConnect(int numberOfSubscribers,
Action1<? super Subscription> connection)
Returns an Observable that automatically connects to this ConnectableObservable
when the specified number of Subscribers subscribe to it and calls the
specified callback with the Subscription associated with the established connection.
|
abstract void |
ConnectableObservable.connect(Action1<? super Subscription> connection)
Instructs the
ConnectableObservable to begin emitting the items from its underlying
Observable to its Subscriber s. |
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 synchronous
SyncOnSubscribe that calls the provided next function
to generate data to downstream subscribers. |
static <S,T> AsyncOnSubscribe<S,T> |
AsyncOnSubscribe.createSingleState(Func0<? extends S> generator,
Action3<? super S,Long,? super Observer<Observable<? extends T>>> next,
Action1<? super S> onUnsubscribe)
Generates a synchronous
AsyncOnSubscribe that calls the provided next
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 synchronous
SyncOnSubscribe that calls the provided next function
to generate data to downstream subscribers. |
static <S,T> AsyncOnSubscribe<S,T> |
AsyncOnSubscribe.createStateful(Func0<? extends S> generator,
Func3<? super S,Long,? super Observer<Observable<? extends T>>,? extends S> next,
Action1<? super S> onUnsubscribe)
Generates a synchronous
AsyncOnSubscribe that calls the provided next
function to generate data to downstream subscribers. |
static <T> SyncOnSubscribe<Void,T> |
SyncOnSubscribe.createStateless(Action1<? super Observer<? super T>> next)
Generates a synchronous
SyncOnSubscribe that calls the provided next function
to generate data to downstream subscribers. |
static <T> SyncOnSubscribe<Void,T> |
SyncOnSubscribe.createStateless(Action1<? super Observer<? super T>> next,
Action0 onUnsubscribe)
Generates a synchronous
SyncOnSubscribe that calls the provided next function
to generate data to downstream subscribers. |
void |
BlockingObservable.forEach(Action1<? super T> onNext)
Invokes a method on each item emitted by this
BlockingObservable and blocks until the Observable
completes. |
void |
BlockingObservable.subscribe(Action1<? super T> onNext)
Subscribes to the source and calls the given action on the current thread and rethrows any exception wrapped
into OnErrorNotImplementedException.
|
void |
BlockingObservable.subscribe(Action1<? super T> onNext,
Action1<? super Throwable> onError)
Subscribes to the source and calls the given actions on the current thread.
|
void |
BlockingObservable.subscribe(Action1<? super T> onNext,
Action1<? super Throwable> onError)
Subscribes to the source and calls the given actions on the current thread.
|
void |
BlockingObservable.subscribe(Action1<? super T> onNext,
Action1<? super Throwable> onError,
Action0 onCompleted)
Subscribes to the source and calls the given actions on the current thread.
|
void |
BlockingObservable.subscribe(Action1<? super T> onNext,
Action1<? super Throwable> onError,
Action0 onCompleted)
Subscribes to the source and calls the given actions on the current thread.
|
Modifier and Type | Method and Description |
---|---|
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext)
Creates a
Subscriber that receives the emissions of any Observable it subscribes to via
onNext but ignores onCompleted notifications;
it will throw an OnErrorNotImplementedException if onError is invoked. |
static <T> Observer<T> |
Observers.create(Action1<? super T> onNext)
Creates an
Observer that receives the emissions of any Observable it subscribes to via
onNext but ignores onCompleted notifications;
it will throw an OnErrorNotImplementedException if onError is invoked. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError notification but
ignores an onCompleted notification. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError notification but
ignores an onCompleted notification. |
static <T> Observer<T> |
Observers.create(Action1<? super T> onNext,
Action1<Throwable> onError)
Creates an
Observer that receives the emissions of any Observable it subscribes to via
onNext and handles any onError notification but ignores
an onCompleted notification. |
static <T> Observer<T> |
Observers.create(Action1<? super T> onNext,
Action1<Throwable> onError)
Creates an
Observer that receives the emissions of any Observable it subscribes to via
onNext and handles any onError notification but ignores
an onCompleted notification. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError or
onCompleted notifications. |
static <T> Subscriber<T> |
Subscribers.create(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Creates an
Subscriber that receives the emissions of any Observable it subscribes to via
onNext and handles any onError or
onCompleted notifications. |
static <T> Observer<T> |
Observers.create(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Creates an
Observer that receives the emissions of any Observable it subscribes to via
onNext and handles any onError or
onCompleted notifications. |
static <T> Observer<T> |
Observers.create(Action1<? super T> onNext,
Action1<Throwable> onError,
Action0 onComplete)
Creates an
Observer that receives the emissions of any Observable it subscribes to via
onNext and handles any onError or
onCompleted notifications. |
Modifier and Type | Method and Description |
---|---|
static Action1<Throwable> |
RxJavaHooks.getOnError()
Returns the current global error handler hook action or null if it is
set to the default one that signals errors to the current threads
UncaughtExceptionHandler.
|
Modifier and Type | Method and Description |
---|---|
static void |
RxJavaHooks.setOnError(Action1<Throwable> onError)
Sets the global error consumer action unless a lockdown is in effect.
|
Copyright © 2018. All rights reserved.