A B C D E F G H I J K L M N O P Q R S T U V W X Z _
All Classes All Packages
All Classes All Packages
All Classes All Packages
A
- accept(Object) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- accept(Object) - Method in interface rx.internal.util.BackpressureDrainManager.BackpressureQueueCallback
-
Override this method to deliver an element to downstream.
- accept(Object, NotificationLite<T>) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Dispatches a NotificationLite value to the actual Observer.
- accept(Object, Observer) - Method in class rx.internal.util.RxRingBuffer
- accept(Observer<? super T>) - Method in class rx.Notification
-
Forwards this notification on to a specified
Observer
. - accept(Observer<? super T>, Object) - Method in class rx.internal.operators.NotificationLite
-
Unwraps the lite notification and calls the appropriate method on the
Observer
. - accountProduced() - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- accumulator - Variable in class rx.internal.operators.OperatorScan
- action - Variable in class rx.functions.Actions.Action1CallsAction0
- action - Variable in class rx.internal.operators.OperatorDoAfterTerminate
- action - Variable in class rx.internal.operators.SingleDoAfterTerminate
- action - Variable in class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- action - Variable in class rx.internal.schedulers.ScheduledAction
- action - Variable in class rx.internal.schedulers.SchedulerWhen.DelayedAction
- action - Variable in class rx.internal.schedulers.SchedulerWhen.ImmediateAction
- action - Variable in class rx.internal.schedulers.TrampolineScheduler.TimedAction
- action - Variable in class rx.schedulers.TestScheduler.TimedAction
- Action - Interface in rx.functions
-
All Action interfaces extend from this.
- Action0 - Interface in rx.functions
-
A zero-argument action.
- Action1<T> - Interface in rx.functions
-
A one-argument action.
- Action1CallsAction0(Action0) - Constructor for class rx.functions.Actions.Action1CallsAction0
- Action2<T1,T2> - Interface in rx.functions
-
A two-argument action.
- Action3<T1,T2,T3> - Interface in rx.functions
-
A three-argument action.
- Action4<T1,T2,T3,T4> - Interface in rx.functions
-
A four-argument action.
- Action5<T1,T2,T3,T4,T5> - Interface in rx.functions
-
A five-argument action.
- Action6<T1,T2,T3,T4,T5,T6> - Interface in rx.functions
-
A six-argument action.
- Action7<T1,T2,T3,T4,T5,T6,T7> - Interface in rx.functions
-
A seven-argument action.
- Action8<T1,T2,T3,T4,T5,T6,T7,T8> - Interface in rx.functions
-
An eight-argument action.
- Action9<T1,T2,T3,T4,T5,T6,T7,T8,T9> - Interface in rx.functions
-
A nine-argument action.
- ActionN - Interface in rx.functions
-
A vector-argument action.
- ActionNotificationObserver<T> - Class in rx.internal.util
-
An Observer that forwards the onXXX method calls to a notification callback by transforming each signal type into Notifications.
- ActionNotificationObserver(Action1<Notification<? super T>>) - Constructor for class rx.internal.util.ActionNotificationObserver
- actionRef - Variable in class rx.subscriptions.BooleanSubscription
- Actions - Class in rx.functions
-
Utility class for the Action interfaces.
- Actions() - Constructor for class rx.functions.Actions
- Actions.Action1CallsAction0<T> - Class in rx.functions
- Actions.EmptyAction<T0,T1,T2,T3,T4,T5,T6,T7,T8> - Class in rx.functions
- ActionSubscriber<T> - Class in rx.internal.util
-
A Subscriber that forwards the onXXX method calls to callbacks.
- ActionSubscriber(Action1<? super T>, Action1<Throwable>, Action0) - Constructor for class rx.internal.util.ActionSubscriber
- active - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- active - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- active - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- active - Variable in class rx.subjects.SubjectSubscriptionManager
-
Indicates that the subject is active (cheaper than checking the state).
- actual - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- actual - Variable in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- actual - Variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- actual - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- actual - Variable in class rx.internal.operators.DeferredScalarSubscriber
-
The downstream subscriber.
- actual - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- actual - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- actual - Variable in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber
- actual - Variable in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
-
The actual subscriber to receive the events.
- actual - Variable in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- actual - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- actual - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- actual - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- actual - Variable in class rx.internal.operators.OperatorCast.CastSubscriber
- actual - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- actual - Variable in class rx.internal.operators.OperatorElementAt.InnerProducer
- actual - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- actual - Variable in class rx.internal.operators.OperatorGroupBy.State
- actual - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- actual - Variable in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- actual - Variable in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- actual - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- actual - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
-
Guarded by this.
- actual - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- actual - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- actual - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- actual - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- actual - Variable in class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- actual - Variable in class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- actual - Variable in class rx.internal.util.BackpressureDrainManager
-
The callbacks to manage the drain.
- actual - Variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- actual - Variable in class rx.internal.util.ScalarSynchronousObservable.WeakSingleProducer
- actual - Variable in class rx.observers.SafeCompletableSubscriber
- actual - Variable in class rx.observers.SafeSubscriber
- actual - Variable in class rx.observers.SerializedObserver
- actual - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
The wrapped Subscriber instance.
- actual - Variable in class rx.subjects.SerializedSubject
- actual - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
The actual Observer.
- actual - Variable in class rx.subscriptions.RefCountSubscription
- actualScheduler - Variable in class rx.internal.schedulers.SchedulerWhen
- actualSubscriber - Variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- add(E) - Method in class rx.internal.util.IndexedRingBuffer
-
Add an element and return the index where it was added to allow removal.
- add(Object) - Method in class rx.internal.util.LinkedArrayList
-
Adds a new element to this list.
- add(Object) - Method in class rx.observers.SerializedObserver.FastList
- add(Future<?>) - Method in class rx.internal.schedulers.ScheduledAction
-
Adds the given Future to the unsubscription composite in order to support cancelling the underlying task in the executor framework.
- add(OnSubscribePublishMulticast.PublishProducer<T>) - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Atomically adds the given wrapper of a child Subscriber to the subscribers array.
- add(OperatorPublish.InnerProducer<T>) - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Atomically try adding a new InnerProducer to this Subscriber or return false if this Subscriber was terminated.
- add(OperatorReplay.InnerProducer<T>) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Atomically try adding a new InnerProducer to this Subscriber or return false if this Subscriber was terminated.
- add(ReplaySubject.ReplayProducer<T>) - Method in class rx.subjects.ReplaySubject.ReplayState
- add(SubjectSubscriptionManager.SubjectObserver) - Method in class rx.subjects.SubjectSubscriptionManager.State
- add(SubjectSubscriptionManager.SubjectObserver<T>) - Method in class rx.subjects.SubjectSubscriptionManager
-
Try to atomically add a SubjectObserver to the active state.
- add(Subscription) - Method in class rx.internal.schedulers.ScheduledAction
-
Adds a general Subscription to this
ScheduledAction
that will be unsubscribed if the underlyingaction
completes or the this scheduled action is cancelled. - add(Subscription) - Method in class rx.internal.util.SubscriptionList
- add(Subscription) - Method in class rx.SingleSubscriber
-
Adds a
Subscription
to this Subscriber's list of subscriptions if this list is not marked as unsubscribed. - add(Subscription) - Method in class rx.Subscriber
-
Adds a
Subscription
to this Subscriber's list of subscriptions if this list is not marked as unsubscribed. - add(Subscription) - Method in class rx.subscriptions.CompositeSubscription
-
Adds a new
Subscription
to thisCompositeSubscription
if theCompositeSubscription
is not yet unsubscribed. - add(T) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- add(T) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- add(T) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- add(T) - Method in class rx.internal.util.OpenHashSet
- add(T) - Method in class rx.internal.util.SynchronizedQueue
- addAll(Collection<? extends T>) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- addAll(Collection<? extends T>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- addAll(Collection<? extends T>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- addAll(Collection<? extends T>) - Method in class rx.internal.util.SynchronizedQueue
- addAll(Subscription...) - Method in class rx.subscriptions.CompositeSubscription
-
Adds collection of
Subscription
to thisCompositeSubscription
if theCompositeSubscription
is not yet unsubscribed. - addCap(long, long) - Static method in class rx.internal.operators.BackpressureUtils
-
Adds two positive longs and caps the result at Long.MAX_VALUE.
- addCause(Throwable, Throwable) - Static method in class rx.exceptions.Exceptions
-
Adds a
Throwable
to a causality-chain of Throwables, as an additional cause (if it does not already appear in the chain among the causes). - addChild() - Method in class rx.subscriptions.RefCountSubscription.State
- addInner(OperatorMerge.InnerSubscriber<T>) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- addLast(OperatorReplay.Node) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Add a new node to the linked list.
- addParent(SubscriptionList) - Method in class rx.internal.schedulers.ScheduledAction
-
Adds a parent
CompositeSubscription
to thisScheduledAction
so when the action is cancelled or terminates, it can remove itself from this parent. - addParent(CompositeSubscription) - Method in class rx.internal.schedulers.ScheduledAction
-
Adds a parent
CompositeSubscription
to thisScheduledAction
so when the action is cancelled or terminates, it can remove itself from this parent. - addProducer(CachedObservable.ReplayProducer<T>) - Method in class rx.internal.operators.CachedObservable.CacheState
-
Adds a ReplayProducer to the producers array atomically.
- addressOf(Class<?>, String) - Static method in class rx.internal.util.unsafe.UnsafeAccess
-
Returns the address of the specific field on the class and wraps a NoSuchFieldException into an internal error.
- addThrowable(AtomicReference<Throwable>, Throwable) - Static method in enum rx.internal.util.ExceptionsUtils
-
Atomically sets or combines the error with the contents of the field, wrapping multiple errors into CompositeException if necessary.
- addToRequested(long) - Method in class rx.Subscriber
- addTotalRequested(long) - Method in class rx.internal.operators.OperatorReplay.InnerProducer
-
Increments the total requested amount.
- addUnsubscriber(Subscriber<? super T>, SubjectSubscriptionManager.SubjectObserver<T>) - Method in class rx.subjects.SubjectSubscriptionManager
-
Registers the unsubscribe action for the given subscriber.
- addValueAsLastCause(Throwable, Object) - Static method in exception rx.exceptions.OnErrorThrowable
-
Adds the given item as the final cause of the given
Throwable
, wrapped inOnNextValue
(which extendsRuntimeException
). - adjustLookAheadStep(int) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- adjustLookAheadStep(int) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- adjustLookAheadStep(int) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- advanceTimeBy(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
-
Moves the Scheduler's clock forward by a specified amount of time.
- advanceTimeTo(long, TimeUnit) - Method in class rx.schedulers.TestScheduler
-
Moves the Scheduler's clock to a particular moment in time.
- ageMillis - Variable in class rx.internal.operators.OperatorTakeLastTimed
- ageMillis - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- all(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits a Boolean that indicates whether all of the items emitted by the source Observable satisfy a condition.
- allWorkers - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- alternate - Variable in class rx.internal.operators.OperatorSwitchIfEmpty
- alternate - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- AlternateSubscriber(Subscriber<? super T>, ProducerArbiter) - Constructor for class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- alwaysFalse() - Static method in class rx.internal.util.UtilityFunctions
-
Returns a function that always returns
false
. - AlwaysFalse() - Constructor for enum rx.internal.util.UtilityFunctions.AlwaysFalse
- alwaysTrue() - Static method in class rx.internal.util.UtilityFunctions
-
Returns a function that always returns
true
. - AlwaysTrue() - Constructor for enum rx.internal.util.UtilityFunctions.AlwaysTrue
- amb(Iterable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
- amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given a set of
Observable
s, propagates the one that first emits an item. - amb(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Mirrors the one Observable in an Iterable of several Observables that first either emits an item or sends a termination notification.
- amb(Completable...) - Static method in class rx.Completable
-
Returns a Completable which terminates as soon as one of the source Completables terminates (normally or with an error) and cancels all other Completables.
- amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given two
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given two Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given three
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given three Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given four
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given four Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given five
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given five Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given six
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given six Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given seven
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given seven Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given eight
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given eight Observables, mirrors the one that first either emits an item or sends a termination notification.
- amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.internal.operators.OnSubscribeAmb
-
Given nine
Observable
s, propagates the one that first emits an item. - amb(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Given nine Observables, mirrors the one that first either emits an item or sends a termination notification.
- AmbSubscriber(long, Subscriber<? super T>, OnSubscribeAmb.Selection<T>) - Constructor for class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- ambSubscribers - Variable in class rx.internal.operators.OnSubscribeAmb.Selection
- ambWith(Completable) - Method in class rx.Completable
-
Returns a Completable that emits the a terminated event of either this Completable or the other Completable whichever fires first.
- ambWith(Observable<? extends T>) - Method in class rx.Observable
-
Mirrors the Observable (current or provided) that first either emits an item or sends a termination notification.
- ANDROID_API_VERSION - Static variable in class rx.internal.util.PlatformDependent
- ANDROID_API_VERSION_IS_NOT_ANDROID - Static variable in class rx.internal.util.PlatformDependent
-
Possible value of
PlatformDependent.getAndroidApiVersion()
which means that the current platform is not Android. - andThen(Completable) - Method in class rx.Completable
-
Returns a completable that first runs this Completable and then the other completable.
- andThen(Observable<T>) - Method in class rx.Completable
-
Returns an Observable which will subscribe to this Completable and once that is completed then will subscribe to the
next
Observable. - andThen(Single<T>) - Method in class rx.Completable
-
Returns a Single which will subscribe to this Completable and once that is completed then will subscribe to the
next
Single. - appendStackTrace(StringBuilder, Throwable, String) - Method in exception rx.exceptions.CompositeException
- arbiter - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- arbiter - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- arbiter - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- arbiter - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- array - Variable in class rx.internal.operators.OnSubscribeFromArray
- array - Variable in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- array - Variable in class rx.internal.util.IndexedRingBuffer.ElementSection
- array - Variable in class rx.observers.SerializedObserver.FastList
- ARRAY_BASE - Static variable in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- asError(Object) - Method in class rx.internal.util.RxRingBuffer
- asObservable() - Method in class rx.Observable
-
Portrays a object of an Observable subclass as a simple Observable object.
- asObservable(Single<T>) - Static method in class rx.Single
-
- AssemblyStackTraceException - Exception in rx.exceptions
-
A RuntimeException that is stackless but holds onto a textual stacktrace from tracking the assembly location of operators.
- AssemblyStackTraceException(String) - Constructor for exception rx.exceptions.AssemblyStackTraceException
-
Constructs an AssemblyStackTraceException with the given message.
- assertCapacity() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- assertCompleted() - Method in class rx.observers.TestSubscriber
-
Asserts that there is exactly one completion event.
- assertError(Class<? extends Throwable>) - Method in class rx.observers.TestSubscriber
-
Asserts that there is exactly one error event which is a subclass of the given class.
- assertError(Throwable) - Method in class rx.observers.TestSubscriber
-
Asserts that there is a single onError event with the exact exception.
- assertionError(String) - Method in class rx.observers.TestObserver
-
Deprecated.Combines an assertion error message with the current completion and error state of this TestSubscriber, giving more information when some assertXXX check fails.
- assertionError(String) - Method in class rx.observers.TestSubscriber
-
Combines an assertion error message with the current completion and error state of this TestSubscriber, giving more information when some assertXXX check fails.
- assertNoErrors() - Method in class rx.observers.TestSubscriber
-
Asserts that this
Subscriber
has received noonError
notifications. - assertNotCompleted() - Method in class rx.observers.TestSubscriber
-
Asserts that there is no completion event.
- assertNoTerminalEvent() - Method in class rx.observers.TestSubscriber
-
Asserts that there are no onError and onCompleted events.
- assertNoValues() - Method in class rx.observers.TestSubscriber
-
Asserts that there are no onNext events received.
- assertReceivedOnNext(List<T>) - Method in class rx.observers.TestObserver
-
Deprecated.Assert that a particular sequence of items was received in order.
- assertReceivedOnNext(List<T>) - Method in class rx.observers.TestSubscriber
-
Asserts that a particular sequence of items was received by this
Subscriber
in order. - assertTerminalEvent() - Method in class rx.observers.TestObserver
-
Deprecated.Assert that a single terminal event occurred, either
TestObserver.onCompleted()
orTestObserver.onError(java.lang.Throwable)
. - assertTerminalEvent() - Method in class rx.observers.TestSubscriber
-
Asserts that a single terminal event occurred, either
TestSubscriber.onCompleted()
orTestSubscriber.onError(java.lang.Throwable)
. - assertUnsubscribed() - Method in class rx.observers.TestSubscriber
-
Asserts that this
Subscriber
is unsubscribed. - assertValue(T) - Method in class rx.observers.TestSubscriber
-
Asserts that there is only a single received onNext event and that it marks the emission of a specific item.
- assertValueCount(int) - Method in class rx.observers.TestSubscriber
-
Asserts that the given number of onNext events are received.
- assertValues(T...) - Method in class rx.observers.TestSubscriber
-
Asserts that the received onNext events, in order, are the specified items.
- AsyncCompletableSubscriber - Class in rx.observers
-
An abstract base class for CompletableSubscriber implementations that want to expose an unsubscription capability.
- AsyncCompletableSubscriber() - Constructor for class rx.observers.AsyncCompletableSubscriber
- AsyncCompletableSubscriber.Unsubscribed - Class in rx.observers
- asyncEmitter - Variable in class rx.internal.operators.OnSubscribeFromAsync
- AsyncEmitter<T> - Interface in rx
-
Abstraction over a RxJava Subscriber that allows associating a resource with it and exposes the current number of downstream requested amount.
- AsyncEmitter.BackpressureMode - Enum in rx
-
Options to handle backpressure in the emitter.
- AsyncEmitter.Cancellable - Interface in rx
-
A functional interface that has a single close method that can throw.
- AsyncOnSubscribe<S,T> - Class in rx.observables
-
A utility class to create
OnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers. - AsyncOnSubscribe() - Constructor for class rx.observables.AsyncOnSubscribe
- AsyncOnSubscribe.AsyncOnSubscribeImpl<S,T> - Class in rx.observables
-
An implementation of AsyncOnSubscribe that delegates
AsyncOnSubscribe.next(Object, long, Observer)
,AsyncOnSubscribe.generateState()
, andAsyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures. - AsyncOnSubscribe.AsyncOuterManager<S,T> - Class in rx.observables
- AsyncOnSubscribe.UnicastSubject<T> - Class in rx.observables
- AsyncOnSubscribe.UnicastSubject.State<T> - Class in rx.observables
- AsyncOnSubscribeImpl(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>) - Constructor for class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- AsyncOnSubscribeImpl(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>, Action1<? super S>) - Constructor for class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- AsyncOnSubscribeImpl(Func3<S, Long, Observer<Observable<? extends T>>, S>) - Constructor for class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- AsyncOnSubscribeImpl(Func3<S, Long, Observer<Observable<? extends T>>, S>, Action1<? super S>) - Constructor for class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- AsyncOuterManager(AsyncOnSubscribe<S, T>, S, AsyncOnSubscribe.UnicastSubject<Observable<T>>) - Constructor for class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- AsyncSubject<T> - Class in rx.subjects
-
Subject that publishes only the last item observed to each
Observer
once the sourceObservable
has completed. - AsyncSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.AsyncSubject
- AtomicReferenceArrayQueue<E> - Class in rx.internal.util.atomic
- AtomicReferenceArrayQueue(int) - Constructor for class rx.internal.util.atomic.AtomicReferenceArrayQueue
- attachTo(Throwable) - Method in exception rx.exceptions.AssemblyStackTraceException
-
Finds an empty cause slot and assigns itself to it.
- attempts - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- autoConnect() - Method in class rx.observables.ConnectableObservable
-
Returns an Observable that automatically connects to this ConnectableObservable when the first Subscriber subscribes.
- autoConnect(int) - Method in class rx.observables.ConnectableObservable
-
Returns an Observable that automatically connects to this ConnectableObservable when the specified number of Subscribers subscribe to it.
- autoConnect(int, Action1<? super Subscription>) - Method in class rx.observables.ConnectableObservable
-
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.
- available() - Method in class rx.internal.util.RxRingBuffer
- await() - Method in class rx.Completable
-
Subscribes to and awaits the termination of this Completable instance in a blocking manner and rethrows any exception emitted.
- await(long, TimeUnit) - Method in class rx.Completable
-
Subscribes to and awaits the termination of this Completable instance in a blocking manner with a specific timeout and rethrows any exception emitted within the timeout window.
- awaitForComplete(CountDownLatch, Subscription) - Static method in class rx.internal.util.BlockingUtils
-
Blocks and waits for a
Subscription
to complete. - awaitTerminalEvent() - Method in class rx.observers.TestSubscriber
-
Blocks until this
Subscriber
receives a notification that theObservable
is complete (either anonCompleted
oronError
notification). - awaitTerminalEvent(long, TimeUnit) - Method in class rx.observers.TestSubscriber
-
Blocks until this
Subscriber
receives a notification that theObservable
is complete (either anonCompleted
oronError
notification), or until a timeout expires. - awaitTerminalEventAndUnsubscribeOnTimeout(long, TimeUnit) - Method in class rx.observers.TestSubscriber
-
Blocks until this
Subscriber
receives a notification that theObservable
is complete (either anonCompleted
oronError
notification), or until a timeout expires; if the Subscriber is interrupted before either of these events take place, this method unsubscribes the Subscriber from the Observable). - awaitValueCount(int, long, TimeUnit) - Method in class rx.observers.TestSubscriber
-
Wait until the current committed value count is less than the expected amount by sleeping 1 unit at most timeout times and return true if at least the required amount of onNext values have been received.
B
- backpressure - Variable in class rx.internal.operators.OnSubscribeFromAsync
- BackpressureDrainManager - Class in rx.internal.util
-
Manages the producer-backpressure-consumer interplay by matching up available elements with requested elements and/or terminal events.
- BackpressureDrainManager(BackpressureDrainManager.BackpressureQueueCallback) - Constructor for class rx.internal.util.BackpressureDrainManager
-
Constructs a backpressure drain manager with 0 requestedCount, no terminal event and not emitting.
- BackpressureDrainManager.BackpressureQueueCallback - Interface in rx.internal.util
-
Interface representing the minimal callbacks required to operate the drain part of a backpressure system.
- BackpressureMode() - Constructor for enum rx.AsyncEmitter.BackpressureMode
- BackpressureOverflow - Class in rx
-
Generic strategy and default implementations to deal with backpressure buffer overflows.
- BackpressureOverflow() - Constructor for class rx.BackpressureOverflow
- BackpressureOverflow.DropLatest - Class in rx
-
Drop most recent items, but not
onError
nor unsubscribe from source (as {code OperatorOnBackpressureDrop}). - BackpressureOverflow.DropOldest - Class in rx
-
Drop oldest items from the buffer making room for newer ones.
- BackpressureOverflow.Error - Class in rx
-
onError
a MissingBackpressureException and unsubscribe from source. - BackpressureOverflow.Strategy - Interface in rx
-
Represents a callback called when a value is about to be dropped due to lack of downstream requests.
- BackpressureUtils - Class in rx.internal.operators
-
Utility functions for use with backpressure.
- BackpressureUtils() - Constructor for class rx.internal.operators.BackpressureUtils
-
Utility class, no instances.
- BaseAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- BaseLinkedAtomicQueue<E> - Class in rx.internal.util.atomic
- BaseLinkedAtomicQueue() - Constructor for class rx.internal.util.atomic.BaseLinkedAtomicQueue
- BaseLinkedQueue<E> - Class in rx.internal.util.unsafe
-
A base data structure for concurrent linked queues.
- BaseLinkedQueue() - Constructor for class rx.internal.util.unsafe.BaseLinkedQueue
- BaseLinkedQueueConsumerNodeRef<E> - Class in rx.internal.util.unsafe
- BaseLinkedQueueConsumerNodeRef() - Constructor for class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- BaseLinkedQueuePad0<E> - Class in rx.internal.util.unsafe
- BaseLinkedQueuePad0() - Constructor for class rx.internal.util.unsafe.BaseLinkedQueuePad0
- BaseLinkedQueuePad1<E> - Class in rx.internal.util.unsafe
- BaseLinkedQueuePad1() - Constructor for class rx.internal.util.unsafe.BaseLinkedQueuePad1
- BaseLinkedQueueProducerNodeRef<E> - Class in rx.internal.util.unsafe
- BaseLinkedQueueProducerNodeRef() - Constructor for class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- baseSubscription - Variable in class rx.internal.operators.OnSubscribeRefCount
- beginWindow(U) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- BehaviorSubject<T> - Class in rx.subjects
-
Subject that emits the most recent item it has observed and all subsequent observed items to each subscribed
Observer
. - BehaviorSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.BehaviorSubject
- Beta - Annotation Type in rx.annotations
-
Signifies that a public API (public class, method or field) is subject to incompatible changes, or even removal, in a future release.
- blockForSingle(Observable<? extends T>) - Method in class rx.observables.BlockingObservable
-
Helper method which handles the actual blocking for a single response.
- BlockingObservable<T> - Class in rx.observables
-
BlockingObservable
is a variety ofObservable
that provides blocking operators. - BlockingObservable(Observable<? extends T>) - Constructor for class rx.observables.BlockingObservable
- BlockingOperatorLatest - Class in rx.internal.operators
-
Wait for and iterate over the latest values of the source observable.
- BlockingOperatorLatest() - Constructor for class rx.internal.operators.BlockingOperatorLatest
-
Utility class.
- BlockingOperatorLatest.LatestObserverIterator<T> - Class in rx.internal.operators
-
Observer of source, iterator for output.
- BlockingOperatorMostRecent - Class in rx.internal.operators
-
Returns an Iterable that always returns the item most recently emitted by an Observable, or a seed value if no item has yet been emitted.
- BlockingOperatorMostRecent() - Constructor for class rx.internal.operators.BlockingOperatorMostRecent
- BlockingOperatorMostRecent.MostRecentObserver<T> - Class in rx.internal.operators
- BlockingOperatorNext - Class in rx.internal.operators
-
Returns an Iterable that blocks until the Observable emits another item, then returns that item.
- BlockingOperatorNext() - Constructor for class rx.internal.operators.BlockingOperatorNext
- BlockingOperatorNext.NextIterator<T> - Class in rx.internal.operators
- BlockingOperatorNext.NextObserver<T> - Class in rx.internal.operators
- BlockingOperatorToFuture - Class in rx.internal.operators
-
Returns a Future representing the single value emitted by an Observable.
- BlockingOperatorToFuture() - Constructor for class rx.internal.operators.BlockingOperatorToFuture
- BlockingOperatorToIterator - Class in rx.internal.operators
-
Returns an Iterator that iterates over all items emitted by a specified Observable.
- BlockingOperatorToIterator() - Constructor for class rx.internal.operators.BlockingOperatorToIterator
- BlockingOperatorToIterator.SubscriberIterator<T> - Class in rx.internal.operators
- BlockingSingle<T> - Class in rx.singles
-
BlockingSingle
is a blocking "version" ofSingle
that provides blocking operators. - BlockingSingle(Single<? extends T>) - Constructor for class rx.singles.BlockingSingle
- BlockingUtils - Class in rx.internal.util
-
Utility functions relating to blocking types.
- BlockingUtils() - Constructor for class rx.internal.util.BlockingUtils
- BooleanSubscription - Class in rx.subscriptions
-
Subscription that can be checked for status such as in a loop inside an
Observable
to exit the loop if unsubscribed. - BooleanSubscription() - Constructor for class rx.subscriptions.BooleanSubscription
- BooleanSubscription(Action0) - Constructor for class rx.subscriptions.BooleanSubscription
- borrowObject() - Method in class rx.internal.util.ObjectPool
-
Gets the next free object from the pool.
- both - Variable in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- BOUNDARY - Static variable in class rx.internal.operators.OnSubscribeConcatMap
-
Whenever the main fires an error, wait until the inner terminates.
- BoundarySubscriber(OperatorWindowWithObservable.SourceSubscriber<T>) - Constructor for class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- BoundarySubscriber(OperatorWindowWithObservableFactory.SourceSubscriber<T, U>) - Constructor for class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- BoundedReplayBuffer() - Constructor for class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- buf - Variable in class rx.internal.operators.BlockingOperatorNext.NextObserver
- buf - Variable in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- buffer - Variable in class rx.internal.operators.BufferUntilSubscriber.State
- buffer - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- buffer - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- buffer - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Holds notifications from upstream.
- buffer - Variable in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- buffer - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- buffer - Variable in class rx.subjects.ReplaySubject.ReplayState
- buffer(int) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(int, int) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, TimeUnit, int) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
-
Returns an Observable that emits buffers of items it collects from the source Observable.
- buffer(Observable<B>) - Method in class rx.Observable
-
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.
- buffer(Observable<B>, int) - Method in class rx.Observable
-
Returns an Observable that emits non-overlapping buffered items from the source Observable each time the specified boundary Observable emits an item.
- BUFFER - rx.AsyncEmitter.BackpressureMode
- BUFFER_PAD - Static variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- BufferAsyncEmitter(Subscriber<? super T>, int) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- bufferClosing - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable
- bufferClosingSelector - Variable in class rx.internal.operators.OperatorBufferWithSingleObservable
- BufferExact(Subscriber<? super List<T>>, int) - Constructor for class rx.internal.operators.OperatorBufferWithSize.BufferExact
- bufferFactory - Variable in class rx.internal.operators.OperatorReplay
-
A factory that creates the appropriate buffer for the ReplaySubscriber.
- BufferingSubscriber(Subscriber<? super List<T>>) - Constructor for class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- BufferingSubscriber(Subscriber<? super List<T>>) - Constructor for class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- bufferOpening - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable
- BufferOverlap(Subscriber<? super List<T>>, int, int) - Constructor for class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- BufferOverlapProducer() - Constructor for class rx.internal.operators.OperatorBufferWithSize.BufferOverlap.BufferOverlapProducer
- bufferSize - Variable in class rx.internal.operators.OnSubscribeCombineLatest
- bufferSize - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- bufferSize - Variable in class rx.internal.operators.OperatorEagerConcatMap
- bufferSize - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- bufferSize - Variable in class rx.internal.operators.OperatorGroupBy
- bufferSize - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- bufferSize - Variable in class rx.internal.operators.OperatorObserveOn
- bufferSize - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBuffer
- bufferSize - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- BufferSkip(Subscriber<? super List<T>>, int, int) - Constructor for class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- BufferSkipProducer() - Constructor for class rx.internal.operators.OperatorBufferWithSize.BufferSkip.BufferSkipProducer
- BufferSubscriber(Subscriber<? super T>, Long, Action0, BackpressureOverflow.Strategy) - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- BufferUntilSubscriber<T> - Class in rx.internal.operators
-
A solution to the "time gap" problem that occurs with
groupBy
andpivot
. - BufferUntilSubscriber(BufferUntilSubscriber.State<T>) - Constructor for class rx.internal.operators.BufferUntilSubscriber
- BufferUntilSubscriber.OnSubscribeAction<T> - Class in rx.internal.operators
- BufferUntilSubscriber.State<T> - Class in rx.internal.operators
-
The common state.
- busy - Variable in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
C
- C_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.MpmcArrayQueueConsumerField
- C_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpmcArrayQueueConsumerField
- C_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpscArrayQueueConsumerField
- C_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- C_NODE_OFFSET - Static variable in class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- cache() - Method in class rx.Observable
-
Returns an Observable that subscribes to this Observable lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
- cache(int) - Method in class rx.Observable
-
Deprecated.Use
Observable.cacheWithInitialCapacity(int)
instead. - CachedObservable<T> - Class in rx.internal.operators
-
An observable which auto-connects to another observable, caches the elements from that observable but allows terminating the connection and completing the cache.
- CachedObservable(Observable.OnSubscribe<T>, CachedObservable.CacheState<T>) - Constructor for class rx.internal.operators.CachedObservable
-
Private constructor because state needs to be shared between the Observable body and the onSubscribe function.
- CachedObservable.CachedSubscribe<T> - Class in rx.internal.operators
-
Manages the subscription of child subscribers by setting up a replay producer and performs auto-connection of the very first subscription.
- CachedObservable.CacheState<T> - Class in rx.internal.operators
-
Contains the active child producers and the values to replay.
- CachedObservable.ReplayProducer<T> - Class in rx.internal.operators
-
Keeps track of the current request amount and the replay position for a child Subscriber.
- cachedSetRemoveOnCancelPolicyMethod - Static variable in class rx.internal.schedulers.NewThreadWorker
-
Improves performance of
NewThreadWorker.tryEnableCancelPolicy(ScheduledExecutorService)
. - CachedSubscribe(CachedObservable.CacheState<T>) - Constructor for class rx.internal.operators.CachedObservable.CachedSubscribe
- CachedThreadScheduler - Class in rx.internal.schedulers
- CachedThreadScheduler(ThreadFactory) - Constructor for class rx.internal.schedulers.CachedThreadScheduler
- CachedThreadScheduler.CachedWorkerPool - Class in rx.internal.schedulers
- CachedThreadScheduler.EventLoopWorker - Class in rx.internal.schedulers
- CachedThreadScheduler.ThreadWorker - Class in rx.internal.schedulers
- CachedWorkerPool(ThreadFactory, long, TimeUnit) - Constructor for class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- CacheState(Observable<? extends T>, int) - Constructor for class rx.internal.operators.CachedObservable.CacheState
- cacheWithInitialCapacity(int) - Method in class rx.Observable
-
Returns an Observable that subscribes to this Observable lazily, caches all of its events and replays them, in the same order as received, to all the downstream subscribers.
- calcDirectOffset(int) - Static method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- calcDirectOffset(int) - Static method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- calcDirectOffset(long) - Static method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- calcElementOffset(long) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- calcElementOffset(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- calcElementOffset(long, int) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- calcElementOffset(long, long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- calcSequenceOffset(long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- calcWrappedOffset(long, int) - Static method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- calcWrappedOffset(long, int) - Static method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- calcWrappedOffset(long, long) - Static method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- call() - Method in interface rx.functions.Action0
- call() - Method in class rx.functions.Actions.EmptyAction
- call() - Method in interface rx.functions.Func0
- call() - Method in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- call() - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- call() - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- call() - Method in class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- call() - Method in class rx.internal.operators.OperatorToMap.DefaultToMapFactory
- call() - Method in class rx.internal.operators.OperatorToMultimap.DefaultToMultimapFactory
- call() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- call() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- call() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- call() - Method in class rx.internal.schedulers.SleepingAction
- call() - Method in class rx.internal.util.InternalObservableUtils.ReplaySupplierBuffer
- call() - Method in class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- call() - Method in class rx.internal.util.InternalObservableUtils.ReplaySupplierNoParams
- call() - Method in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- call() - Method in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- call() - Method in class rx.internal.util.ScalarSynchronousSingle.ScalarSynchronousSingleAction
- call(Integer, Object) - Method in class rx.internal.util.InternalObservableUtils.PlusOneFunc2
- call(Long, Object) - Method in class rx.internal.util.InternalObservableUtils.PlusOneLongFunc2
- call(Object) - Method in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- call(Object) - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- call(Object) - Method in class rx.internal.util.InternalObservableUtils.EqualsWithFunc1
- call(Object) - Method in class rx.internal.util.InternalObservableUtils.IsInstanceOfFunc1
- call(Object) - Method in class rx.internal.util.InternalObservableUtils.ReturnsVoidFunc1
- call(Object) - Method in enum rx.internal.util.UtilityFunctions.AlwaysFalse
- call(Object) - Method in enum rx.internal.util.UtilityFunctions.AlwaysTrue
- call(Object...) - Method in interface rx.functions.ActionN
- call(Object...) - Method in class rx.functions.Actions.EmptyAction
- call(Object...) - Method in interface rx.functions.FuncN
- call(Object, Object) - Method in class rx.internal.util.InternalObservableUtils.ObjectEqualsFunc2
- call(Throwable) - Method in class rx.internal.util.InternalObservableUtils.ErrorNotImplementedAction
- call(List<? extends Observable<?>>) - Method in class rx.internal.util.InternalObservableUtils.ToArrayFunc1
- call(K) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber.EvictionAction
- call(K) - Method in class rx.internal.operators.OperatorToMultimap.DefaultMultimapCollectionFactory
- call(R, T) - Method in class rx.internal.util.InternalObservableUtils.CollectorCaller
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeConcat
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeConcatArray
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeConcatIterable
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeMerge
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeMergeArray
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorArray
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorIterable
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeMergeIterable
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.CompletableOnSubscribeTimeout
- call(Completable.CompletableSubscriber) - Method in class rx.internal.operators.OnSubscribeOnAssemblyCompletable
- call(Notification<?>) - Method in class rx.internal.util.InternalObservableUtils.NotificationErrorExtractor
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.operators.OnSubscribeRedo.RedoFinite
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.operators.OnSubscribeRedo.RetryWithPredicate
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.util.InternalObservableUtils.RepeatNotificationDematerializer
- call(Observable<? extends Notification<?>>) - Method in class rx.internal.util.InternalObservableUtils.RetryNotificationDematerializer
- call(Observable<T>) - Method in class rx.internal.util.InternalObservableUtils.SelectorAndObserveOn
- call(Scheduler.Worker) - Method in class rx.internal.schedulers.SchedulerWhen.ScheduledAction
- call(SingleSubscriber<? super R>) - Method in class rx.internal.operators.SingleOnSubscribeMap
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeOnAssemblySingle
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeSingle
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.SingleDoAfterTerminate
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.SingleOnSubscribeDelaySubscriptionOther
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.SingleOnSubscribeUsing
- call(SingleSubscriber<? super T>) - Method in class rx.internal.operators.SingleOperatorOnErrorResumeNext
- call(SingleSubscriber<? super T>) - Method in class rx.internal.util.ScalarSynchronousSingle.DirectScheduledEmission
- call(SingleSubscriber<? super T>) - Method in class rx.internal.util.ScalarSynchronousSingle.NormalScheduledEmission
- call(Subscriber<? super Boolean>) - Method in class rx.internal.operators.OperatorAll
- call(Subscriber<? super Boolean>) - Method in class rx.internal.operators.OperatorAny
- call(Subscriber<? super Integer>) - Method in class rx.internal.operators.OnSubscribeRange
- call(Subscriber<? super Long>) - Method in class rx.internal.operators.OnSubscribeTimerOnce
- call(Subscriber<? super Long>) - Method in class rx.internal.operators.OnSubscribeTimerPeriodically
- call(Subscriber<? super Object>) - Method in enum rx.internal.operators.EmptyObservableHolder
- call(Subscriber<? super Object>) - Method in enum rx.internal.operators.NeverObservableHolder
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithSingleObservable
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithSize
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorBufferWithTime
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorToObservableList
- call(Subscriber<? super List<T>>) - Method in class rx.internal.operators.OperatorToObservableSortedList
- call(Subscriber<? super Map<K, Collection<V>>>) - Method in class rx.internal.operators.OperatorToMultimap
- call(Subscriber<? super Map<K, V>>) - Method in class rx.internal.operators.OperatorToMap
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeCollect
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeCombineLatest
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeConcatMap
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeFlattenIterable
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeGroupJoin
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeJoin
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeLift
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeMap
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OnSubscribeReduceSeed
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorCast
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorEagerConcatMap
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorMapNotification
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorScan
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorWithLatestFrom
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorWithLatestFromMany
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorZip
- call(Subscriber<? super R>) - Method in class rx.internal.operators.OperatorZipIterable
- call(Subscriber<? super Notification<T>>) - Method in class rx.internal.operators.OperatorMaterialize
- call(Subscriber<? super Observable<? extends R>>) - Method in class rx.internal.operators.OperatorMapPair
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithObservable
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithSize
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable
- call(Subscriber<? super Observable<T>>) - Method in class rx.internal.operators.OperatorWindowWithTime
- call(Subscriber<? super GroupedObservable<K, V>>) - Method in class rx.internal.operators.OperatorGroupBy
- call(Subscriber<? super TimeInterval<T>>) - Method in class rx.internal.operators.OperatorTimeInterval
- call(Subscriber<? super Timestamped<T>>) - Method in class rx.internal.operators.OperatorTimestamp
- call(Subscriber<? super T>) - Method in class rx.internal.operators.BufferUntilSubscriber.OnSubscribeAction
- call(Subscriber<? super T>) - Method in class rx.internal.operators.CachedObservable.CachedSubscribe
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeAmb
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeAutoConnect
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDefer
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelaySubscription
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelaySubscriptionOther
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDelaySubscriptionWithSelector
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeDetach
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFilter
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFromArray
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFromAsync
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFromCallable
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeFromIterable
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeOnAssembly
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribePublishMulticast
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeRedo
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeReduce
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeRefCount
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeTakeLastOne
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeThrow
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OnSubscribeUsing
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorAsObservable
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDebounceWithSelector
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDebounceWithTime
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDelay
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDelayWithSelector
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDematerialize
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDistinct
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDistinctUntilChanged
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoAfterTerminate
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnEach
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnRequest
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnSubscribe
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorDoOnUnsubscribe
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorElementAt
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorGroupBy.State
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorIgnoreElements
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorMerge
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorObserveOn
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnBackpressureDrop
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnBackpressureLatest
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorRetryWithPredicate
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSampleWithObservable
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSampleWithTime
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSerialize
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSingle
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkip
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipLast
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipLastTimed
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipTimed
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipUntil
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSkipWhile
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSubscribeOn
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSwitch
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorSwitchIfEmpty
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTake
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeLast
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeLastTimed
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeTimed
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeUntil
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeUntilPredicate
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTakeWhile
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorThrottleFirst
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorTimeoutBase
- call(Subscriber<? super T>) - Method in class rx.internal.operators.OperatorUnsubscribeOn
- call(Subscriber<? super T>) - Method in class rx.internal.util.ScalarSynchronousObservable.JustOnSubscribe
- call(Subscriber<? super T>) - Method in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncOnSubscribe
- call(Subscriber<? super T>) - Method in class rx.Observable.OnSubscribeExtend
- call(Subscriber<? super T>) - Method in class rx.observables.AsyncOnSubscribe
- call(Subscriber<? super T>) - Method in class rx.observables.AsyncOnSubscribe.UnicastSubject.State
- call(Subscriber<? super T>) - Method in class rx.observables.SyncOnSubscribe
- call(Subscriber<? super T>) - Method in class rx.subjects.ReplaySubject.ReplayState
- call(Subscriber<? super T>) - Method in class rx.subjects.SubjectSubscriptionManager
- call(Subscriber<? super T>) - Method in class rx.subjects.UnicastSubject.State
-
Tries to set the given subscriber if not already set, sending an IllegalStateException to the subscriber otherwise.
- call(T) - Method in interface rx.functions.Action1
- call(T) - Method in class rx.functions.Actions.Action1CallsAction0
- call(T) - Method in interface rx.functions.Func1
- call(T0) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3, T4) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3, T4, T5) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3, T4, T5, T6) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3, T4, T5, T6, T7) - Method in class rx.functions.Actions.EmptyAction
- call(T0, T1, T2, T3, T4, T5, T6, T7, T8) - Method in class rx.functions.Actions.EmptyAction
- call(T1, T2) - Method in interface rx.functions.Action2
- call(T1, T2) - Method in interface rx.functions.Func2
- call(T1, T2, T3) - Method in interface rx.functions.Action3
- call(T1, T2, T3) - Method in interface rx.functions.Func3
- call(T1, T2, T3, T4) - Method in interface rx.functions.Action4
- call(T1, T2, T3, T4) - Method in interface rx.functions.Func4
- call(T1, T2, T3, T4, T5) - Method in interface rx.functions.Action5
- call(T1, T2, T3, T4, T5) - Method in interface rx.functions.Func5
- call(T1, T2, T3, T4, T5, T6) - Method in interface rx.functions.Action6
- call(T1, T2, T3, T4, T5, T6) - Method in interface rx.functions.Func6
- call(T1, T2, T3, T4, T5, T6, T7) - Method in interface rx.functions.Action7
- call(T1, T2, T3, T4, T5, T6, T7) - Method in interface rx.functions.Func7
- call(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface rx.functions.Action8
- call(T1, T2, T3, T4, T5, T6, T7, T8) - Method in interface rx.functions.Func8
- call(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface rx.functions.Action9
- call(T1, T2, T3, T4, T5, T6, T7, T8, T9) - Method in interface rx.functions.Func9
- call(U) - Method in class rx.internal.operators.OperatorMapPair.OuterInnerMapper
- call(U, U) - Method in class rx.internal.operators.OperatorDistinctUntilChanged
- callActual(Scheduler.Worker) - Method in class rx.internal.schedulers.SchedulerWhen.DelayedAction
- callActual(Scheduler.Worker) - Method in class rx.internal.schedulers.SchedulerWhen.ImmediateAction
- callActual(Scheduler.Worker) - Method in class rx.internal.schedulers.SchedulerWhen.ScheduledAction
- cancel - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- cancel - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- cancel - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- cancel - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- cancel - Variable in class rx.internal.schedulers.ScheduledAction
- cancel() - Method in interface rx.AsyncEmitter.Cancellable
-
Cancel the action or free a resource.
- cancel() - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- cancel(Queue<?>) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- cancel(K) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- CancellableSubscription(AsyncEmitter.Cancellable) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.CancellableSubscription
- cancelled - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- cancelled - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- cancelled - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- cancelled - Variable in class rx.internal.operators.OperatorGroupBy.State
- capacity - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- capacity - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer
- capacity - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- capacity() - Method in class rx.internal.util.RxRingBuffer
- capacityHint - Variable in class rx.internal.util.LinkedArrayList
-
The capacity of each array segment.
- capacityHint() - Method in class rx.internal.util.LinkedArrayList
-
Returns the capacity hint that indicates the capacity of each buffer segment.
- capacitySkip - Variable in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- casConsumerIndex(long, long) - Method in class rx.internal.util.unsafe.MpmcArrayQueueConsumerField
- casHead(long, long) - Method in class rx.internal.util.unsafe.SpmcArrayQueueConsumerField
- casObserverRef(Observer<? super T>, Observer<? super T>) - Method in class rx.internal.operators.BufferUntilSubscriber.State
- casProducerIndex(long, long) - Method in class rx.internal.util.unsafe.MpmcArrayQueueProducerField
- cast(Class<R>) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable, converted to the specified type.
- castClass - Variable in class rx.internal.operators.OperatorCast
- castClass - Variable in class rx.internal.operators.OperatorCast.CastSubscriber
- CastSubscriber(Subscriber<? super R>, Class<R>) - Constructor for class rx.internal.operators.OperatorCast.CastSubscriber
- caughtUp - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Indicate that the observer has caught up.
- caughtUp - Variable in class rx.subjects.UnicastSubject.State
-
Indicates the queue can be bypassed because the child has caught up with the replay.
- cause - Variable in exception rx.exceptions.CompositeException
- checkTerminate() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Check if the operator reached some terminal state: child unsubscribed, an error was reported and we don't delay errors.
- checkTerminated(boolean, boolean) - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Given the current source state, terminates all child subscribers.
- checkTerminated(boolean, boolean) - Method in class rx.internal.producers.QueuedProducer
- checkTerminated(boolean, boolean, Throwable, SpscLinkedArrayQueue<Object>, Subscriber<? super T>, boolean) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- checkTerminated(boolean, boolean, Subscriber<?>, Queue<?>) - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- checkTerminated(boolean, boolean, Subscriber<?>, Queue<?>, boolean) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- checkTerminated(boolean, boolean, Subscriber<? super R>) - Method in class rx.internal.operators.OperatorScan.InitialProducer
- checkTerminated(boolean, boolean, Subscriber<? super GroupedObservable<K, V>>, Queue<?>) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- checkTerminated(boolean, boolean, Subscriber<? super Subject<T, T>>, Queue<Subject<T, T>>) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- checkTerminated(boolean, boolean, Subscriber<? super T>) - Method in class rx.subjects.UnicastSubject.State
-
Checks if one of the terminal conditions have been met: child unsubscribed, an error happened or the source terminated and the queue is empty
- checkTerminated(boolean, boolean, Subscriber<? super T>, boolean) - Method in class rx.internal.operators.OperatorGroupBy.State
- checkTerminated(boolean, boolean, Subscriber<? super T>, Queue<Object>) - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- checkTerminated(Object, boolean) - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Perform termination actions in case the source has terminated in some way and the queue has also become empty.
- child - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
The actual child subscriber.
- child - Variable in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- child - Variable in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- child - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- child - Variable in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- child - Variable in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- child - Variable in class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- child - Variable in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- child - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- child - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- child - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- child - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- child - Variable in class rx.internal.operators.OperatorPublish.InnerProducer
-
The actual child subscriber.
- child - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
The actual child subscriber.
- child - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- child - Variable in class rx.internal.operators.OperatorScan.InitialProducer
- child - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- child - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- child - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- child - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- child - Variable in class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- child - Variable in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- child - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- child - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- child - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- child - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- child - Variable in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- child - Variable in class rx.internal.operators.OperatorZip.Zip
- child - Variable in class rx.internal.operators.OperatorZip.ZipSubscriber
- child - Variable in class rx.internal.producers.ProducerObserverArbiter
- child - Variable in class rx.internal.producers.QueuedProducer
- child - Variable in class rx.internal.producers.QueuedValueProducer
- child - Variable in class rx.internal.producers.SingleDelayedProducer
-
The child to emit the value and completion once possible.
- child - Variable in class rx.internal.producers.SingleProducer
-
The child subscriber.
- children - Variable in class rx.subscriptions.RefCountSubscription.State
- childRequested(long) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- childSubscriber - Variable in class rx.internal.operators.OnSubscribeRange.RangeProducer
- childSubscription - Variable in class rx.internal.operators.OperatorZip.Zip
- choice - Variable in class rx.internal.operators.OnSubscribeAmb.Selection
- chosen - Variable in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- chunk - Variable in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
-
Guarded by this.
- chunk - Variable in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
-
Guarded by this.
- chunks - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
-
Guarded by this.
- chunks - Variable in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
-
Guarded by this.
- chunks - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
-
Guarded by guard.
- chunks - Variable in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
-
Guarded by this.
- clazz - Variable in class rx.internal.util.InternalObservableUtils.IsInstanceOfFunc1
- cleanup() - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- cleanup() - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- clear() - Method in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
- clear() - Method in class rx.internal.operators.OperatorWindowWithTime.State
- clear() - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- clear() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- clear() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- clear() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- clear() - Method in class rx.internal.util.SubscriptionList
- clear() - Method in class rx.internal.util.SynchronizedQueue
- clear() - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- clear() - Method in class rx.observers.AsyncCompletableSubscriber
-
Call to clear the upstream's subscription without unsubscribing it.
- clear() - Static method in class rx.plugins.RxJavaHooks
-
Clears all hooks to be no-operations (and passthroughs) and onError hook to signal errors to the caller thread's UncaughtExceptionHandler.
- clear() - Method in class rx.subscriptions.CompositeSubscription
-
Unsubscribes any subscriptions that are currently part of this
CompositeSubscription
and remove them from theCompositeSubscription
so that theCompositeSubscription
is empty and able to manage new subscriptions. - clear(Action1<? super T>) - Method in class rx.internal.util.OpenHashSet
- clearAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
-
Clears the assembly tracking hooks to their default pass-through behavior.
- clearProducer() - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- clients - Variable in class rx.internal.operators.OnSubscribeAutoConnect
- CLOCK_DRIFT_TOLERANCE_NANOS - Static variable in class rx.Scheduler
-
The tolerance for a clock drift in nanoseconds where the periodic scheduler will rebase.
- clone() - Method in class rx.internal.util.SynchronizedQueue
- closingSubscriptions - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- collect(Collection<? super T>) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- collect(Func0<R>, Action2<R, ? super T>) - Method in class rx.Observable
-
Collects items emitted by the source Observable into a single mutable data structure and returns an Observable that emits this structure.
- collectErrors(Queue<Throwable>) - Static method in class rx.internal.operators.CompletableOnSubscribeMerge
-
Collects the Throwables from the queue, adding subsequent Throwables as suppressed to the first Throwable and returns it.
- collectionFactory - Variable in class rx.internal.operators.OnSubscribeCollect
- collectionFactory - Variable in class rx.internal.operators.OperatorToMultimap
- collectionSelector - Variable in class rx.internal.operators.OperatorMapPair
- collectionSelector - Variable in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- collector - Variable in class rx.internal.operators.OnSubscribeCollect
- collector - Variable in class rx.internal.operators.OnSubscribeCollect.CollectSubscriber
- collector - Variable in class rx.internal.util.InternalObservableUtils.CollectorCaller
- CollectorCaller(Action2<R, ? super T>) - Constructor for class rx.internal.util.InternalObservableUtils.CollectorCaller
- CollectSubscriber(Subscriber<? super R>, R, Action2<R, ? super T>) - Constructor for class rx.internal.operators.OnSubscribeCollect.CollectSubscriber
- combine(Object, int) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
-
Combine the given notification value from the indexth source with the existing known latest values.
- combineLatest(Iterable<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
-
Combines a collection of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(List<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
-
Combines a list of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
-
Combines two source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from either of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Observable
-
Combines three source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Observable
-
Combines four source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Observable
-
Combines five source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Observable
-
Combines six source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Observable
-
Combines seven source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Observable
-
Combines eight source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatest(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Observable<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Observable
-
Combines nine source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function.
- combineLatestDelayError(Iterable<? extends Observable<? extends T>>, FuncN<? extends R>) - Static method in class rx.Observable
-
Combines a collection of source Observables by emitting an item that aggregates the latest values of each of the source Observables each time an item is received from any of the source Observables, where this aggregation is defined by a specified function and delays any error from the sources until all source Observables terminate.
- combiner - Variable in class rx.internal.operators.OnSubscribeCombineLatest
- combiner - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- combiner - Variable in class rx.internal.operators.OperatorWithLatestFromMany
- combiner - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- CombinerSubscriber(OnSubscribeCombineLatest.LatestCoordinator<T, R>, int) - Constructor for class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- comparator - Variable in class rx.internal.operators.OperatorDistinctUntilChanged
- compare(int, int) - Static method in class rx.internal.schedulers.TrampolineScheduler
- compare(Object, Object) - Method in class rx.internal.operators.OperatorToObservableSortedList.DefaultComparableFunction
- compare(TestScheduler.TimedAction, TestScheduler.TimedAction) - Method in class rx.schedulers.TestScheduler.CompareActionsByTime
- CompareActionsByTime() - Constructor for class rx.schedulers.TestScheduler.CompareActionsByTime
- compareAndSwapInt(Object, long, int, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
- compareTo(TrampolineScheduler.TimedAction) - Method in class rx.internal.schedulers.TrampolineScheduler.TimedAction
- Completable - Class in rx
-
Represents a deferred computation without any value but only indication for completion or exception.
- Completable(Completable.CompletableOnSubscribe) - Constructor for class rx.Completable
-
Constructs a Completable instance with the given onSubscribe callback.
- Completable(Completable.CompletableOnSubscribe, boolean) - Constructor for class rx.Completable
-
Constructs a Completable instance with the given onSubscribe callback without calling the onCreate hook.
- Completable.CompletableOnSubscribe - Interface in rx
-
Callback used for building deferred computations that takes a CompletableSubscriber.
- Completable.CompletableOperator - Interface in rx
-
Convenience interface and callback used by the lift operator that given a child CompletableSubscriber, return a parent CompletableSubscriber that does any kind of lifecycle-related transformations.
- Completable.CompletableSubscriber - Interface in rx
-
Represents the subscription API callbacks when subscribing to a Completable instance.
- Completable.CompletableTransformer - Interface in rx
-
Convenience interface and callback used by the compose operator to turn a Completable into another Completable fluently.
- CompletableConcatSubscriber(Completable.CompletableSubscriber, int) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- completableExecutionHook - Variable in class rx.plugins.RxJavaPlugins
- CompletableMergeSubscriber(Completable.CompletableSubscriber, int, boolean) - Constructor for class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- CompletableOnSubscribeConcat - Class in rx.internal.operators
- CompletableOnSubscribeConcat(Observable<? extends Completable>, int) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcat
- CompletableOnSubscribeConcat.CompletableConcatSubscriber - Class in rx.internal.operators
- CompletableOnSubscribeConcat.CompletableConcatSubscriber.ConcatInnerSubscriber - Class in rx.internal.operators
- CompletableOnSubscribeConcatArray - Class in rx.internal.operators
- CompletableOnSubscribeConcatArray(Completable[]) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcatArray
- CompletableOnSubscribeConcatArray.ConcatInnerSubscriber - Class in rx.internal.operators
- CompletableOnSubscribeConcatIterable - Class in rx.internal.operators
- CompletableOnSubscribeConcatIterable(Iterable<? extends Completable>) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcatIterable
- CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber - Class in rx.internal.operators
- CompletableOnSubscribeMerge - Class in rx.internal.operators
- CompletableOnSubscribeMerge(Observable<? extends Completable>, int, boolean) - Constructor for class rx.internal.operators.CompletableOnSubscribeMerge
- CompletableOnSubscribeMerge.CompletableMergeSubscriber - Class in rx.internal.operators
- CompletableOnSubscribeMergeArray - Class in rx.internal.operators
- CompletableOnSubscribeMergeArray(Completable[]) - Constructor for class rx.internal.operators.CompletableOnSubscribeMergeArray
- CompletableOnSubscribeMergeDelayErrorArray - Class in rx.internal.operators
- CompletableOnSubscribeMergeDelayErrorArray(Completable[]) - Constructor for class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorArray
- CompletableOnSubscribeMergeDelayErrorIterable - Class in rx.internal.operators
- CompletableOnSubscribeMergeDelayErrorIterable(Iterable<? extends Completable>) - Constructor for class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorIterable
- CompletableOnSubscribeMergeIterable - Class in rx.internal.operators
- CompletableOnSubscribeMergeIterable(Iterable<? extends Completable>) - Constructor for class rx.internal.operators.CompletableOnSubscribeMergeIterable
- CompletableOnSubscribeTimeout - Class in rx.internal.operators
- CompletableOnSubscribeTimeout(Completable, long, TimeUnit, Scheduler, Completable) - Constructor for class rx.internal.operators.CompletableOnSubscribeTimeout
- complete - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- complete() - Static method in class rx.Completable
-
Returns a Completable instance that completes immediately when subscribed to.
- complete() - Method in class rx.internal.operators.DeferredScalarSubscriber
-
Signals onCompleted() to the downstream subscriber.
- complete() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- complete() - Method in interface rx.internal.operators.OperatorReplay.ReplayBuffer
-
Adds a completion event to the buffer
- complete() - Method in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- complete() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- complete() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- complete() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- complete() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- complete() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- complete() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- complete() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- complete(long) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- complete(Throwable) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- complete(Throwable) - Method in interface rx.internal.util.BackpressureDrainManager.BackpressureQueueCallback
-
Override this method to deliver a normal or exceptional terminal event.
- complete(List<Observer<T2>>) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- complete(R) - Method in class rx.internal.operators.DeferredScalarSubscriber
-
Atomically switches to the terminal state and emits the value if there is a request for it or stores it for retrieval by
downstreamRequest(long)
. - COMPLETE - Static variable in class rx.Completable
-
Single instance of a complete Completable.
- completed() - Method in class rx.internal.operators.NotificationLite
-
Creates a lite
onCompleted
notification without doing any allocation. - COMPLETED_FLAG - Static variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- COMPLETED_MASK - Static variable in class rx.internal.operators.BackpressureUtils
-
Masks the most significant bit, i.e., 0x8000_0000_0000_0000L.
- completions - Variable in class rx.observers.TestSubscriber
-
The number of onCompleted() calls.
- compose(Completable.CompletableTransformer) - Method in class rx.Completable
-
Calls the given transformer function with this instance and returns the function's resulting Completable.
- compose(Observable.Transformer<? super T, ? extends R>) - Method in class rx.Observable
-
Transform an Observable by applying a particular Transformer function to it.
- compose(Single.Transformer<? super T, ? extends R>) - Method in class rx.Single
-
Transform a Single by applying a particular Transformer function to it.
- CompositeException - Exception in rx.exceptions
-
Represents an exception that is a composite of one or more other exceptions.
- CompositeException(String, Collection<? extends Throwable>) - Constructor for exception rx.exceptions.CompositeException
-
Deprecated.please use
CompositeException(Collection)
- CompositeException(Throwable...) - Constructor for exception rx.exceptions.CompositeException
-
Constructs a CompositeException instance with the supplied initial Throwables.
- CompositeException(Collection<? extends Throwable>) - Constructor for exception rx.exceptions.CompositeException
- CompositeException.CompositeExceptionCausalChain - Exception in rx.exceptions
- CompositeException.PrintStreamOrWriter - Class in rx.exceptions
- CompositeException.WrappedPrintStream - Class in rx.exceptions
-
Same abstraction and implementation as in JDK to allow PrintStream and PrintWriter to share implementation
- CompositeException.WrappedPrintWriter - Class in rx.exceptions
- CompositeExceptionCausalChain() - Constructor for exception rx.exceptions.CompositeException.CompositeExceptionCausalChain
- CompositeSubscription - Class in rx.subscriptions
-
Subscription that represents a group of Subscriptions that are unsubscribed together.
- CompositeSubscription() - Constructor for class rx.subscriptions.CompositeSubscription
-
Constructs an empty Composite subscription.
- CompositeSubscription(Subscription...) - Constructor for class rx.subscriptions.CompositeSubscription
- computation() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
Scheduler
intended for computational work. - computationScheduler - Variable in class rx.schedulers.Schedulers
- concat(Iterable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Completable...) - Static method in class rx.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Observable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Observable<? extends Completable>, int) - Static method in class rx.Completable
-
Returns a Completable which completes only when all sources complete, one after another.
- concat(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by each of the Observables emitted by the source Observable, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by two Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by three Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by four Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by five Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by six Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by seven Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by eight Observables, one after the other, without interleaving them.
- concat(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits the items emitted by nine Observables, one after the other, without interleaving them.
- concat(Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by two Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by three Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by four Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by five Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by six Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by seven Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by eight Singles, one after the other.
- concat(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Returns an Observable that emits the items emitted by nine Singles, one after the other.
- concatDelayError(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Concatenates the Iterable sequence of Observables into a single sequence by subscribing to each Observable, one after the other, one at a time and delays any errors till the all inner Observables terminate.
- concatDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Concatenates the Observable sequence of Observables into a single sequence by subscribing to each inner Observable, one after the other, one at a time and delays any errors till the all inner and the outer Observables terminate.
- concatEager(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Concatenates a sequence of Observables eagerly into a single stream of values.
- concatEager(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Concatenates a sequence of Observables eagerly into a single stream of values.
- concatEager(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Concatenates an Observable sequence of Observables eagerly into a single stream of values.
- concatEager(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Concatenates an Observable sequence of Observables eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates two source Observables eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates three sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates four sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates five sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates six sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates seven sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates eight sources eagerly into a single stream of values.
- concatEager(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Concatenates nine sources eagerly into a single stream of values.
- ConcatInnerSubscriber() - Constructor for class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber.ConcatInnerSubscriber
- ConcatInnerSubscriber(Completable.CompletableSubscriber, Iterator<? extends Completable>) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- ConcatInnerSubscriber(Completable.CompletableSubscriber, Completable[]) - Constructor for class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- concatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Returns a new Observable that emits items resulting from applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then emitting the items that result from concatenating those resulting Observables.
- concatMapDelayError(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Maps each of the items into an Observable, subscribes to them one after the other, one at a time and emits their values in order while delaying any error from either this or any of the inner Observables till all of them terminate.
- concatMapEager(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
- concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int) - Method in class rx.Observable
-
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
- concatMapEager(Func1<? super T, ? extends Observable<? extends R>>, int, int) - Method in class rx.Observable
-
Maps a sequence of values into Observables and concatenates these Observables eagerly into a single Observable.
- ConcatMapInnerScalarProducer(R, OnSubscribeConcatMap.ConcatMapSubscriber<T, R>) - Constructor for class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerScalarProducer
- ConcatMapInnerSubscriber(OnSubscribeConcatMap.ConcatMapSubscriber<T, R>) - Constructor for class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- concatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>) - Method in class rx.Observable
-
Returns an Observable that concatenate each item emitted by the source Observable with the values in an Iterable corresponding to that item that is generated by a selector.
- ConcatMapSubscriber(Subscriber<? super R>, Func1<? super T, ? extends Observable<? extends R>>, int, int) - Constructor for class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- concatProducer - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- concatWith(Completable) - Method in class rx.Completable
-
Concatenates this Completable with another Completable.
- concatWith(Observable<? extends T>) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted from the current Observable, then the next, one after the other, without interleaving them.
- concatWith(Single<? extends T>) - Method in class rx.Single
-
Returns an Observable that emits the item emitted by the source Single, then the item emitted by the specified Single.
- ConcurrentCircularArrayQueue<E> - Class in rx.internal.util.unsafe
-
A concurrent access enabling class used by circular array based queues this class exposes an offset computation method along with differently memory fenced load/store methods into the underlying array.
- ConcurrentCircularArrayQueue(int) - Constructor for class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- ConcurrentCircularArrayQueueL0Pad<E> - Class in rx.internal.util.unsafe
- ConcurrentCircularArrayQueueL0Pad() - Constructor for class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- ConcurrentSequencedCircularArrayQueue<E> - Class in rx.internal.util.unsafe
- ConcurrentSequencedCircularArrayQueue(int) - Constructor for class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- connect() - Method in class rx.internal.operators.CachedObservable.CacheState
-
Connects the cache to the source.
- connect() - Method in class rx.observables.ConnectableObservable
-
Instructs the
ConnectableObservable
to begin emitting the items from its underlyingObservable
to itsSubscriber
s. - connect(Action1<? super Subscription>) - Method in class rx.internal.operators.OperatorMulticast
- connect(Action1<? super Subscription>) - Method in class rx.internal.operators.OperatorPublish
- connect(Action1<? super Subscription>) - Method in class rx.internal.operators.OperatorReplay
- connect(Action1<? super Subscription>) - Method in class rx.observables.ConnectableObservable
-
Instructs the
ConnectableObservable
to begin emitting the items from its underlyingObservable
to itsSubscriber
s. - ConnectableObservable<T> - Class in rx.observables
-
A
ConnectableObservable
resembles an ordinaryObservable
, except that it does not begin emitting items when it is subscribed to, but only when itsConnectableObservable.connect()
method is called. - ConnectableObservable(Observable.OnSubscribe<T>) - Constructor for class rx.observables.ConnectableObservable
- connectedSubject - Variable in class rx.internal.operators.OperatorMulticast
- connection - Variable in class rx.internal.operators.CachedObservable.CacheState
-
Holds onto the subscriber connected to source.
- connection - Variable in class rx.internal.operators.OnSubscribeAutoConnect
- consumer - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
-
Accessed from the serialized part.
- consumer - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
-
Accessed from the serialized part.
- consumer - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SerializedSubject
- consumer - Variable in class rx.internal.operators.OperatorWindowWithTime.CountedSerializedSubject
- consumer - Variable in class rx.internal.operators.OperatorWindowWithTime.State
- consumerBuffer - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- consumerBuffer - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- consumerBuffer - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueConsumerColdField
- consumerIndex - Variable in class rx.internal.util.atomic.SpscAtomicArrayQueue
- consumerIndex - Variable in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- consumerIndex - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- consumerIndex - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- consumerIndex - Variable in class rx.internal.util.unsafe.MpmcArrayQueueConsumerField
- consumerIndex - Variable in class rx.internal.util.unsafe.SpmcArrayQueueConsumerField
- consumerIndex - Variable in class rx.internal.util.unsafe.SpscArrayQueueConsumerField
- consumerIndex - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueConsumerField
- consumerMask - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- consumerMask - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- consumerMask - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueConsumerColdField
- consumerNode - Variable in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- consumerNode - Variable in class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- contains(Object) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- contains(Object) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- contains(Object) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- contains(Object) - Method in class rx.internal.util.SynchronizedQueue
- contains(Object) - Method in class rx.Observable
-
Returns an Observable that emits a Boolean that indicates whether the source Observable emitted a specified item.
- containsAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- containsAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- containsAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- containsAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
- controlHandlerFunction - Variable in class rx.internal.operators.OnSubscribeRedo
- convertSelector(Func1<? super T, ? extends Iterable<? extends U>>) - Static method in class rx.internal.operators.OperatorMapPair
-
Creates the function that generates a
Observable
based on an item emitted by anotherObservable
. - coordinateAll - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Indicate that all request amounts should be considered.
- coordinationQueue - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
The queue that holds producers with request changes that need to be coordinated.
- copyProducers() - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- cores - Variable in class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- count - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- count - Variable in class rx.internal.operators.OnSubscribeRedo.RedoFinite
- count - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- count - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- count - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- count - Variable in class rx.internal.operators.OperatorBufferWithSize
- count - Variable in class rx.internal.operators.OperatorBufferWithTime
- count - Variable in class rx.internal.operators.OperatorSkipLast
- count - Variable in class rx.internal.operators.OperatorTakeLast
- count - Variable in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- count - Variable in class rx.internal.operators.OperatorTakeLastTimed
- count - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- count - Variable in class rx.internal.operators.OperatorWindowWithTime.CountedSerializedSubject
- count - Variable in class rx.internal.operators.OperatorWindowWithTime.State
- count - Variable in class rx.internal.schedulers.TrampolineScheduler.TimedAction
- count - Variable in class rx.schedulers.TestScheduler.TimedAction
- count() - Method in class rx.internal.util.RxRingBuffer
- count() - Method in class rx.Observable
-
Returns an Observable that emits the count of the total number of items emitted by the source Observable.
- CountedSerializedSubject(Observer<T>, Observable<T>) - Constructor for class rx.internal.operators.OperatorWindowWithTime.CountedSerializedSubject
- counter - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- counter - Variable in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- counter - Static variable in class rx.schedulers.TestScheduler
- COUNTER - Static variable in enum rx.internal.util.InternalObservableUtils
-
A BiFunction that expects an integer as its first parameter and returns +1.
- countLong() - Method in class rx.Observable
-
Returns an Observable that counts the total number of items emitted by the source Observable and emits this count as a 64-bit Long.
- create() - Static method in class rx.exceptions.OnErrorThrowable.OnNextValue.Primitives
- create() - Static method in class rx.internal.operators.BufferUntilSubscriber
-
Creates a default, unbounded buffering Subject instance.
- create() - Static method in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
-
Creates a ScheduledExecutorService (either the default or given by a hook).
- create() - Static method in class rx.observables.AsyncOnSubscribe.UnicastSubject
- create() - Static method in class rx.observers.TestSubscriber
-
Factory method to construct a TestSubscriber with an initial request of Long.MAX_VALUE and no delegation.
- create() - Static method in class rx.subjects.AsyncSubject
-
Creates and returns a new
AsyncSubject
. - create() - Static method in class rx.subjects.BehaviorSubject
-
Creates a
BehaviorSubject
without a default item. - create() - Static method in class rx.subjects.PublishSubject
-
Creates and returns a new
PublishSubject
. - create() - Static method in class rx.subjects.ReplaySubject
-
Creates an unbounded replay subject.
- create() - Static method in class rx.subjects.UnicastSubject
-
Constructs an empty UnicastSubject instance with the default capacity hint of 16 elements.
- create() - Static method in class rx.subscriptions.BooleanSubscription
-
Creates a
BooleanSubscription
without unsubscribe behavior. - create(int) - Static method in class rx.subjects.ReplaySubject
-
Creates an unbounded replay subject with the specified initial buffer capacity.
- create(int) - Static method in class rx.subjects.UnicastSubject
-
Constructs an empty UnicastSubject instance with a capacity hint.
- create(int, Action0) - Static method in class rx.subjects.UnicastSubject
-
Constructs an empty UnicastSubject instance with a capacity hint and an Action0 instance to call if the subject reaches its terminal state or the single Subscriber unsubscribes mid-sequence.
- create(long) - Static method in class rx.observers.TestSubscriber
-
Factory method to construct a TestSubscriber with the given initial request amount and no delegation.
- create(K, Observable.OnSubscribe<T>) - Static method in class rx.observables.GroupedObservable
-
Returns an Observable that will execute the specified function when a
Subscriber
subscribes to it. - create(Completable.CompletableOnSubscribe) - Static method in class rx.Completable
-
Constructs a Completable instance by wrapping the given onSubscribe callback.
- create(Action0) - Static method in class rx.subscriptions.BooleanSubscription
-
Creates a
BooleanSubscription
with a specified function to invoke upon unsubscribe. - create(Action0) - Static method in class rx.subscriptions.Subscriptions
-
Creates and returns a
Subscription
that invokes the givenAction0
when unsubscribed. - create(Action1<? super T>) - Static method in class rx.observers.Observers
-
Creates an
Observer
that receives the emissions of anyObservable
it subscribes to viaonNext
but ignoresonCompleted
notifications; it will throw anOnErrorNotImplementedException
ifonError
is invoked. - create(Action1<? super T>) - Static method in class rx.observers.Subscribers
-
Creates a
Subscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
but ignoresonCompleted
notifications; it will throw anOnErrorNotImplementedException
ifonError
is invoked. - create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Observers
-
Creates an
Observer
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
notification but ignores anonCompleted
notification. - create(Action1<? super T>, Action1<Throwable>) - Static method in class rx.observers.Subscribers
-
Creates an
Subscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
notification but ignores anonCompleted
notification. - create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Observers
-
Creates an
Observer
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications. - create(Action1<? super T>, Action1<Throwable>, Action0) - Static method in class rx.observers.Subscribers
-
Creates an
Subscriber
that receives the emissions of anyObservable
it subscribes to viaonNext
and handles anyonError
oronCompleted
notifications. - create(Observable.OnSubscribe<T>) - Static method in class rx.Observable
-
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 a
Subscriber
subscribes to it. - create(Observable<? extends T>) - Static method in class rx.internal.operators.OperatorPublish
-
Creates a OperatorPublish instance to publish values of the given source observable.
- create(Observable<? extends T>) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a replaying ConnectableObservable with an unbounded buffer.
- create(Observable<? extends T>, int) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a replaying ConnectableObservable with a size bound buffer.
- create(Observable<? extends T>, long, TimeUnit, Scheduler) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a replaying ConnectableObservable with a time bound buffer.
- create(Observable<? extends T>, long, TimeUnit, Scheduler, int) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a replaying ConnectableObservable with a size and time bound buffer.
- create(Observable<? extends T>, Func0<? extends OperatorReplay.ReplayBuffer<T>>) - Static method in class rx.internal.operators.OperatorReplay
-
Creates a OperatorReplay instance to replay values of the given source observable.
- create(Observable<? extends T>, Func1<? super Observable<T>, ? extends Observable<R>>) - Static method in class rx.internal.operators.OperatorPublish
- create(Observable<? extends T>, Func1<? super Observable<T>, ? extends Observable<R>>, boolean) - Static method in class rx.internal.operators.OperatorPublish
- create(Observable<T>) - Static method in class rx.internal.operators.OnSubscribeSingle
- create(AsyncOnSubscribe<S, T>) - Static method in class rx.Observable
-
Returns an Observable that respects the back-pressure semantics.
- create(SyncOnSubscribe<S, T>) - Static method in class rx.Observable
-
Returns an Observable that respects the back-pressure semantics.
- create(Observer<T>) - Static method in class rx.observers.TestSubscriber
-
Factory method to construct a TestSubscriber which delegates events to the given Observer and an issues an initial request of Long.MAX_VALUE.
- create(Observer<T>, long) - Static method in class rx.observers.TestSubscriber
-
Factory method to construct a TestSubscriber which delegates events to the given Observer and issues the given initial request amount.
- create(Observer<T>, Observable<T>) - Method in class rx.internal.operators.OperatorWindowWithTime.State
- create(TestScheduler) - Static method in class rx.subjects.TestSubject
-
Creates and returns a new
TestSubject
. - create(Single.OnSubscribe<T>) - Static method in class rx.Single
-
Returns a Single that will execute the specified function when a
SingleSubscriber
executes it or aSubscriber
subscribes to it. - create(Subscriber<T>) - Static method in class rx.observers.TestSubscriber
-
Factory method to construct a TestSubscriber which delegates events to the given Subscriber and an issues an initial request of Long.MAX_VALUE.
- create(T) - Static method in class rx.internal.util.ScalarSynchronousObservable
-
Constructs a ScalarSynchronousObservable with the given constant value.
- create(T) - Static method in class rx.internal.util.ScalarSynchronousSingle
- create(T) - Static method in class rx.subjects.BehaviorSubject
-
Creates a
BehaviorSubject
that emits the last item it observed and all subsequent items to eachObserver
that subscribes to it. - create(T, boolean) - Static method in class rx.subjects.BehaviorSubject
- createCollectorCaller(Action2<R, ? super T>) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func2 which calls a collector with its parameters and returns the first (R) parameter.
- createComputationScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.computation()
. - createComputationScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.computation()
except usingthreadFactory
for thread creation. - createCountedSerializedSubject() - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- createDefault() - Static method in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
- createFrom(Observable<? extends T>, Func1<? super T, ? extends Iterable<? extends R>>, int) - Static method in class rx.internal.operators.OnSubscribeFlattenIterable
- createIoScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.io()
. - createIoScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.io()
except usingthreadFactory
for thread creation. - createMap(Func1<Action1<K>, Map<K, Object>>, Action1<K>) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- createNewThreadScheduler() - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.newThread()
. - createNewThreadScheduler(ThreadFactory) - Static method in class rx.plugins.RxJavaSchedulersHook
-
Create an instance of the default
Scheduler
used forSchedulers.newThread()
except usingthreadFactory
for thread creation. - createNewWindow() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- createNewWindow() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- createObject() - Method in class rx.internal.util.ObjectPool
-
Creates a new object.
- createOnCompleted() - Static method in class rx.Notification
-
Creates and returns a
Notification
of varietyKind.OnCompleted
. - createOnCompleted(Class<T>) - Static method in class rx.Notification
-
Creates and returns a
Notification
of varietyKind.OnCompleted
. - createOnError(Throwable) - Static method in class rx.Notification
-
Creates and returns a
Notification
of varietyKind.OnError
, and assigns it an exception. - createOnNext(T) - Static method in class rx.Notification
-
Creates and returns a
Notification
of varietyKind.OnNext
, and assigns it a value. - createProducer() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- createProducer() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- createProducer() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- createProducer() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- createProducer() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- createProducer() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- createProducer(Subscriber<? super T>, T) - Static method in class rx.internal.util.ScalarSynchronousObservable
-
Creates a scalar producer depending on the state of STRONG_MODE.
- createRepeatDematerializer(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a function that dematerializes the notification signal from an Observable and calls a notification handler with a null for non-terminal events.
- createReplaySelectorAndObserveOn(Func1<? super Observable<T>, ? extends Observable<R>>, Scheduler) - Static method in enum rx.internal.util.InternalObservableUtils
-
Creates a Func1 which calls the selector function with the received argument, applies an observeOn on the result and returns the resulting Observable.
- createReplaySupplier(Observable<T>) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func0 that supplies the ConnectableObservable returned by calling replay() on the source.
- createReplaySupplier(Observable<T>, int) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func0 that supplies the ConnectableObservable returned by calling a parameterized replay() on the source.
- createReplaySupplier(Observable<T>, int, long, TimeUnit, Scheduler) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func0 that supplies the ConnectableObservable returned by calling a parameterized replay() on the source.
- createReplaySupplier(Observable<T>, long, TimeUnit, Scheduler) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func0 that supplies the ConnectableObservable returned by calling a parameterized replay() on the source.
- createRetryDematerializer(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a function that dematerializes the notification signal from an Observable and calls a notification handler with the Throwable.
- createSerializedSubject() - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- createSingleState(Func0<? extends S>, Action2<? super S, ? super Observer<? super T>>) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createSingleState(Func0<? extends S>, Action2<? super S, ? super Observer<? super T>>, Action1<? super S>) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createSingleState(Func0<? extends S>, Action3<? super S, Long, ? super Observer<Observable<? extends T>>>) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createSingleState(Func0<? extends S>, Action3<? super S, Long, ? super Observer<Observable<? extends T>>>, Action1<? super S>) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStacktrace() - Static method in class rx.internal.operators.OnSubscribeOnAssembly
- createStateful(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateful(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>, Action1<? super S>) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateful(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateful(Func0<? extends S>, Func3<? super S, Long, ? super Observer<Observable<? extends T>>, ? extends S>, Action1<? super S>) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateless(Action1<? super Observer<? super T>>) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateless(Action1<? super Observer<? super T>>, Action0) - Static method in class rx.observables.SyncOnSubscribe
-
Generates a synchronous
SyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateless(Action2<Long, ? super Observer<Observable<? extends T>>>) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createStateless(Action2<Long, ? super Observer<Observable<? extends T>>>, Action0) - Static method in class rx.observables.AsyncOnSubscribe
-
Generates a synchronous
AsyncOnSubscribe
that calls the providednext
function to generate data to downstream subscribers. - createUnbounded() - Static method in class rx.subjects.ReplaySubject
-
Creates an unbounded replay subject with the bounded-implementation for testing purposes.
- createUnboundedTime() - Static method in class rx.subjects.ReplaySubject
-
Creates an unbounded replay subject with the time-bounded-implementation for testing purposes.
- createWith(K, int, OperatorGroupBy.GroupBySubscriber<?, K, T>, boolean) - Static method in class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- createWithSize(int) - Static method in class rx.subjects.ReplaySubject
-
Creates a size-bounded replay subject.
- createWithTime(long, TimeUnit, Scheduler) - Static method in class rx.subjects.ReplaySubject
-
Creates a time-bounded replay subject.
- createWithTimeAndSize(long, TimeUnit, int, Scheduler) - Static method in class rx.subjects.ReplaySubject
-
Creates a time- and size-bounded replay subject.
- createWorker() - Method in class rx.internal.schedulers.CachedThreadScheduler
- createWorker() - Method in class rx.internal.schedulers.EventLoopsScheduler
- createWorker() - Method in class rx.internal.schedulers.ExecutorScheduler
- createWorker() - Method in class rx.internal.schedulers.ImmediateScheduler
- createWorker() - Method in class rx.internal.schedulers.NewThreadScheduler
- createWorker() - Method in class rx.internal.schedulers.SchedulerWhen
- createWorker() - Method in class rx.internal.schedulers.TrampolineScheduler
- createWorker() - Method in class rx.Scheduler
-
Retrieves or creates a new
Scheduler.Worker
that represents serial execution of actions. - createWorker() - Method in class rx.schedulers.ImmediateScheduler
-
Deprecated.
- createWorker() - Method in class rx.schedulers.NewThreadScheduler
-
Deprecated.
- createWorker() - Method in class rx.schedulers.TestScheduler
- createWorker() - Method in class rx.schedulers.TrampolineScheduler
-
Deprecated.
- cs - Variable in class rx.SingleSubscriber
- csub - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- current - Variable in class rx.internal.operators.OperatorPublish
-
Holds the current subscriber that is, will be or just was subscribed to the source observable.
- current - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Holds onto the current connected PublishSubscriber.
- current - Variable in class rx.internal.operators.OperatorReplay
-
Holds the current subscriber that is, will be or just was subscribed to the source observable.
- current - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- currentBuffer - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
Contains the reference to the buffer segment in replay.
- currentConsumerIndex() - Method in interface rx.internal.util.unsafe.QueueProgressIndicators
-
This method has no concurrent visibility semantics.
- currentConsumerIndex() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- currentIndex - Variable in class rx.internal.operators.OnSubscribeRange.RangeProducer
- currentIndexInBuffer - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
Contains the index into the currentBuffer where the next value is expected.
- currentProducer - Variable in class rx.internal.producers.ProducerArbiter
- currentProducer - Variable in class rx.internal.producers.ProducerObserverArbiter
- currentProducerIndex() - Method in interface rx.internal.util.unsafe.QueueProgressIndicators
-
This method has no concurrent visibility semantics.
- currentProducerIndex() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
D
- debounce(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by newer items before a timeout value expires.
- debounce(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by newer items before a timeout value expires on a specified Scheduler.
- debounce(Func1<? super T, ? extends Observable<U>>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, except that it drops items emitted by the source Observable that are followed by another item within a computed debounce duration.
- DebounceState() - Constructor for class rx.internal.operators.OperatorDebounceWithTime.DebounceState
- decrementRequested() - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- DEFAULT_ERROR_HANDLER - Static variable in class rx.plugins.RxJavaPlugins
- DEFAULT_INSTANCE - Static variable in class rx.plugins.RxJavaSchedulersHook
- DEFAULT_SORT_FUNCTION - Static variable in class rx.internal.operators.OperatorToObservableSortedList
- DEFAULT_UNBOUNDED_FACTORY - Static variable in class rx.internal.operators.OperatorReplay
- DefaultComparableFunction() - Constructor for class rx.internal.operators.OperatorToObservableSortedList.DefaultComparableFunction
- defaultIfEmpty(T) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable or a specified default item if the source Observable is empty.
- DefaultMultimapCollectionFactory() - Constructor for class rx.internal.operators.OperatorToMultimap.DefaultMultimapCollectionFactory
- defaultSize - Static variable in class rx.internal.util.IndexedRingBuffer
- defaultSize - Static variable in class rx.internal.util.RxRingBuffer
-
128 was chosen as the default based on the numbers below.
- DefaultToMapFactory() - Constructor for class rx.internal.operators.OperatorToMap.DefaultToMapFactory
- DefaultToMultimapFactory() - Constructor for class rx.internal.operators.OperatorToMultimap.DefaultToMultimapFactory
- defaultValue - Variable in class rx.internal.operators.OperatorElementAt
- defaultValue - Variable in class rx.internal.operators.OperatorSingle
- defaultValue - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- defer(Callable<Single<T>>) - Static method in class rx.Single
- defer(Func0<? extends Completable>) - Static method in class rx.Completable
-
Defers the subscription to a Completable instance returned by a supplier.
- defer(Func0<Observable<T>>) - Static method in class rx.Observable
-
Returns an Observable that calls an Observable factory to create an Observable for each new Observer that subscribes.
- DeferredScalarSubscriber<T,R> - Class in rx.internal.operators
-
Base class for Subscribers that consume the entire upstream and signal zero or one element (or an error) in a backpressure honoring fashion.
- DeferredScalarSubscriber(Subscriber<? super R>) - Constructor for class rx.internal.operators.DeferredScalarSubscriber
- DeferredScalarSubscriber.InnerProducer - Class in rx.internal.operators
-
Redirects the downstream request amount bach to the DeferredScalarSubscriber.
- delay - Variable in class rx.internal.operators.OperatorDelay
- delay(long, TimeUnit) - Method in class rx.Completable
-
Returns a Completable which delays the emission of the completion event by the given time.
- delay(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable shifted forward in time by a specified delay.
- delay(long, TimeUnit) - Method in class rx.Single
-
Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
- delay(long, TimeUnit, Scheduler) - Method in class rx.Completable
-
Returns a Completable which delays the emission of the completion event by the given time while running on the specified scheduler.
- delay(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable shifted forward in time by a specified delay.
- delay(long, TimeUnit, Scheduler) - Method in class rx.Single
-
Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
- delay(long, TimeUnit, Scheduler, boolean) - Method in class rx.Completable
-
Returns a Completable which delays the emission of the completion event, and optionally the error as well, by the given time while running on the specified scheduler.
- delay(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
-
Returns an Observable that delays the subscription to and emissions from the source Observable via another Observable on a per-item basis.
- delay(Func1<? super T, ? extends Observable<U>>) - Method in class rx.Observable
-
Returns an Observable that delays the emissions of the source Observable via another Observable on a per-item basis.
- DelayedAction(Action0, long, TimeUnit) - Constructor for class rx.internal.schedulers.SchedulerWhen.DelayedAction
- delayError - Variable in class rx.internal.operators.OnSubscribeCombineLatest
- delayError - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- delayError - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Delays the error delivery to happen only after all values have been consumed.
- delayError - Variable in class rx.internal.operators.OperatorGroupBy
- delayError - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- delayError - Variable in class rx.internal.operators.OperatorGroupBy.State
- delayError - Variable in class rx.internal.operators.OperatorObserveOn
- delayError - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- delayError - Variable in class rx.internal.operators.OperatorSwitch
- delayError - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- delayErrorMode - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- delayErrorMode - Variable in class rx.internal.operators.OnSubscribeConcatMap
-
How to handle errors from the main and inner Observables.
- delayErrors - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- delayErrors - Variable in class rx.internal.operators.CompletableOnSubscribeMerge
- delayErrors - Variable in class rx.internal.operators.OperatorMerge
- delayErrors - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- delaySubscription(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that delays the subscription to the source Observable by a given amount of time.
- delaySubscription(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that delays the subscription to the source Observable by a given amount of time, both waiting and subscribing on a given Scheduler.
- delaySubscription(Func0<? extends Observable<U>>) - Method in class rx.Observable
-
Returns an Observable that delays the subscription to the source Observable until a second Observable emits an item.
- delaySubscription(Observable<?>) - Method in class rx.Single
-
Returns a Single that delays the subscription to this Single until the Observable completes.
- delaySubscription(Observable<U>) - Method in class rx.Observable
-
Returns an Observable that delays the subscription to this Observable until the other Observable emits an element or completes normally.
- delayTime - Variable in class rx.internal.schedulers.SchedulerWhen.DelayedAction
- delegate - Variable in class rx.observers.TestObserver
-
Deprecated.
- delegate - Variable in class rx.observers.TestSubscriber
- deliverUncaughtException(Throwable) - Static method in class rx.Completable
- dematerialize() - Method in class rx.Observable
-
Returns an Observable that reverses the effect of
materialize
by transforming theNotification
objects emitted by the source Observable into the items or notifications they represent. - deregisterExecutor(ScheduledExecutorService) - Static method in class rx.internal.schedulers.NewThreadWorker
-
Deregisters the executor service.
- DetachProducer(OnSubscribeDetach.DetachSubscriber<T>) - Constructor for class rx.internal.operators.OnSubscribeDetach.DetachProducer
- DetachSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- DirectScheduledEmission(EventLoopsScheduler, T) - Constructor for class rx.internal.util.ScalarSynchronousSingle.DirectScheduledEmission
- DISABLED_BY_USER - Static variable in class rx.internal.util.unsafe.UnsafeAccess
- disconnect(CompositeSubscription) - Method in class rx.internal.operators.OnSubscribeRefCount
- dispatch() - Method in class rx.internal.operators.CachedObservable.CacheState
-
Signals all known children there is work to do.
- dispatch() - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
The common serialization point of events arriving from upstream and child-subscribers requesting more.
- dispose - Variable in class rx.internal.operators.OnSubscribeUsing
- dispose - Variable in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- dispose(Action0) - Method in class rx.internal.operators.OnSubscribeUsing
- disposeAction - Variable in class rx.internal.operators.SingleOnSubscribeUsing
- DisposeAction(Action1<? super Resource>, Resource) - Constructor for class rx.internal.operators.OnSubscribeUsing.DisposeAction
- disposeEagerly - Variable in class rx.internal.operators.OnSubscribeUsing
- disposeEagerly - Variable in class rx.internal.operators.SingleOnSubscribeUsing
- distinct() - Method in class rx.Observable
-
Returns an Observable that emits all items emitted by the source Observable that are distinct.
- distinct(Func1<? super T, ? extends U>) - Method in class rx.Observable
-
Returns an Observable that emits all items emitted by the source Observable that are distinct according to a key selector function.
- distinctUntilChanged() - Method in class rx.Observable
-
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors.
- distinctUntilChanged(Func1<? super T, ? extends U>) - Method in class rx.Observable
-
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors, according to a key selector function.
- distinctUntilChanged(Func2<? super T, ? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits all items emitted by the source Observable that are distinct from their immediate predecessors when compared with each other via the provided comparator function.
- doAction() - Method in class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- doAfterTerminate(Action0) - Method in class rx.Completable
-
Returns a Completable instance that calls the given onAfterComplete callback after this Completable completes normally.
- doAfterTerminate(Action0) - Method in class rx.Observable
- doAfterTerminate(Action0) - Method in class rx.Single
-
Registers an
Action0
to be called when thisSingle
invokes eitherSingleSubscriber.onSuccess(Object)
onSuccess} oronError
. - done - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- done - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- done - Variable in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- done - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- done - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- done - Variable in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- done - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- done - Variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- done - Variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- done - Variable in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- done - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Indicates the upstream has completed.
- done - Variable in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
-
Guarded by this.
- done - Variable in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
-
Guarded by this.
- done - Variable in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
-
Guarded by this.
- done - Variable in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
-
Guarded by this.
- done - Variable in class rx.internal.operators.OperatorCast.CastSubscriber
- done - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- done - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- done - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- done - Variable in class rx.internal.operators.OperatorGroupBy.State
- done - Variable in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- done - Variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- done - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- done - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- done - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Contains either an onCompleted or an onError token from upstream.
- done - Variable in class rx.internal.operators.OperatorScan.InitialProducer
- done - Variable in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- done - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- done - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- done - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
-
Guarded by guard.
- done - Variable in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
-
Guarded by this.
- done - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- done - Variable in class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- done - Variable in class rx.internal.producers.QueuedProducer
- done - Variable in class rx.observers.SafeCompletableSubscriber
- done - Variable in class rx.observers.SafeSubscriber
- done - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- done - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- done - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- done - Variable in class rx.subjects.UnicastSubject.State
-
Indicates the source has terminated.
- doOnComplete(Action0) - Method in class rx.Completable
-
Deprecated.Use
Completable.doOnCompleted(Action0)
instead. - doOnCompleted(Action0) - Method in class rx.Completable
-
Returns a Completable which calls the given onCompleted callback if this Completable completes.
- doOnCompleted(Action0) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action when it calls
onCompleted
. - doOnEach(Action1<Notification<? super T>>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action for each item it emits.
- doOnEach(Observer<? super T>) - Method in class rx.Observable
-
Modifies the source Observable so that it notifies an Observer for each item and terminal event it emits.
- doOnEachObserver - Variable in class rx.internal.operators.OperatorDoOnEach
- doOnError(Action1<? super Throwable>) - Method in class rx.Completable
-
Returns a Completable which calls the given onError callback if this Completable emits an error.
- doOnError(Action1<Throwable>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action if it calls
onError
. - doOnError(Action1<Throwable>) - Method in class rx.Single
-
Modifies the source
Single
so that it invokes an action if it callsonError
. - doOnLifecycle(Action1<? super Subscription>, Action1<? super Throwable>, Action0, Action0, Action0) - Method in class rx.Completable
-
Returns a Completable instance that calls the various callbacks on the specific lifecycle events.
- doOnNext(Action1<? super T>) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action when it calls
onNext
. - doOnRequest(Action1<Long>) - Method in class rx.Observable
-
Modifies the source
Observable
so that it invokes the given action when it receives a request for more items. - doOnSubscribe(Action0) - Method in class rx.Observable
-
Modifies the source
Observable
so that it invokes the given action when it is subscribed from its subscribers. - doOnSubscribe(Action0) - Method in class rx.Single
-
Modifies the source
Single
so that it invokes the given action when it is subscribed from its subscribers. - doOnSubscribe(Action1<? super Subscription>) - Method in class rx.Completable
-
Returns a Completable instance that calls the given onSubscribe callback with the disposable that child subscribers receive on subscription.
- doOnSuccess(Action1<? super T>) - Method in class rx.Single
-
Modifies the source
Single
so that it invokes an action when it callsonSuccess
. - doOnTerminate(Action0) - Method in class rx.Completable
-
Returns a Completable instance that calls the given onTerminate callback just before this Completable completes normally or with an exception
- doOnTerminate(Action0) - Method in class rx.Observable
-
Modifies the source Observable so that it invokes an action when it calls
onCompleted
oronError
. - doOnUnsubscribe(Action0) - Method in class rx.Completable
-
Returns a Completable which calls the given onUnsubscribe callback if the child subscriber cancels the subscription.
- doOnUnsubscribe(Action0) - Method in class rx.Observable
-
Calls the unsubscribe
Action0
if the downstream unsubscribes the sequence. - doOnUnsubscribe(Action0) - Method in class rx.Single
-
Modifies the source
Single
so that it invokes the given action when it is unsubscribed from its subscribers. - doSubscribe(Subscriber<? super T>, CompositeSubscription) - Method in class rx.internal.operators.OnSubscribeRefCount
- doTerminate() - Method in class rx.subjects.UnicastSubject.State
-
Call the optional termination action at most once.
- doUnsubscribe() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- downstreamRequest(long) - Method in class rx.internal.operators.DeferredScalarSubscriber
- downstreamRequest(long) - Method in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- downstreamRequest(long) - Method in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- drain() - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- drain() - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- drain() - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- drain() - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- drain() - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- drain() - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
The serialization loop that determines the minimum request of all subscribers and tries to emit as many items from the queue if they are available.
- drain() - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- drain() - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- drain() - Method in class rx.internal.operators.OperatorGroupBy.State
- drain() - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- drain() - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- drain() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- drain() - Method in class rx.internal.producers.QueuedProducer
- drain() - Method in class rx.internal.producers.QueuedValueProducer
- drain() - Method in class rx.internal.util.BackpressureDrainManager
-
Try to drain the "queued" elements and terminal events by considering the available and requested event counts.
- drain(List<Object>) - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- drain(List<Object>) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- drain(List<Object>) - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- drain(ReplaySubject.ReplayProducer<T>) - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- drain(ReplaySubject.ReplayProducer<T>) - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- drain(ReplaySubject.ReplayProducer<T>) - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- drain(ReplaySubject.ReplayProducer<T>) - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- drainError(Throwable) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- drainWip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- DROP - rx.AsyncEmitter.BackpressureMode
- DropAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.DropAsyncEmitter
- DropLatest() - Constructor for class rx.BackpressureOverflow.DropLatest
- DropOldest() - Constructor for class rx.BackpressureOverflow.DropOldest
E
- e - Variable in class rx.internal.operators.NotificationLite.OnErrorSentinel
- EagerInnerSubscriber(OperatorEagerConcatMap.EagerOuterSubscriber<?, T>, int) - Constructor for class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- EagerOuterProducer(OperatorEagerConcatMap.EagerOuterSubscriber<?, ?>) - Constructor for class rx.internal.operators.OperatorEagerConcatMap.EagerOuterProducer
- EagerOuterSubscriber(Func1<? super T, ? extends Observable<? extends R>>, int, int, Subscriber<? super R>) - Constructor for class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- element() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- element() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- element() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- element() - Method in class rx.internal.util.SynchronizedQueue
- ELEMENT_SHIFT - Static variable in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- elementAt(int) - Method in class rx.Observable
-
Returns an Observable that emits the single item at a specified index in a sequence of emissions from a source Observable.
- elementAtOrDefault(int, T) - Method in class rx.Observable
-
Returns an Observable that emits the item found at a specified index in a sequence of emissions from a source Observable, or a default item if that index is out of range.
- elements - Variable in class rx.internal.util.IndexedRingBuffer
- ElementSection() - Constructor for class rx.internal.util.IndexedRingBuffer.ElementSection
- emit() - Method in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- emit() - Method in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- emit() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- emit() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- emit() - Method in class rx.internal.operators.OperatorScan.InitialProducer
- emit(int, Subscriber<T>, Subscriber<?>) - Method in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
- emit(Object) - Method in class rx.internal.operators.BufferUntilSubscriber
- emit(Subscriber<? super T>, T) - Static method in class rx.internal.producers.SingleDelayedProducer
-
Emits the given value to the child subscriber and completes it and checks for unsubscriptions eagerly.
- emit(T, OperatorSwitch.InnerSubscriber<T>) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- emitAndComplete(Subscriber<T>, Subscriber<?>) - Method in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
- emitChunk(List<T>) - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- emitEmpty() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- emitFirst(Object, NotificationLite<T>) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Tries to emit a NotificationLite value as the first value and drains the queue as long as possible.
- emitIfNonEmpty() - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- emitLoop() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
The standard emission loop serializing events and requests.
- emitLoop() - Method in class rx.internal.operators.OperatorScan.InitialProducer
- emitLoop() - Method in class rx.internal.producers.ProducerArbiter
- emitLoop() - Method in class rx.internal.producers.ProducerObserverArbiter
- emitLoop(List<Object>, Object, NotificationLite<T>) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Emits the contents of the queue as long as there are values.
- emitNext(Object, NotificationLite<T>) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Emits the given NotificationLite value and prevents the emitFirst to run if not already run.
- emitScalar(OperatorMerge.InnerSubscriber<T>, T, long) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- emitScalar(T, long) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- emitted - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
-
Remembers how many elements have been emitted before the requests run out.
- emitted - Variable in class rx.internal.operators.OperatorZip.Zip
- emitting - Variable in class rx.internal.operators.BufferUntilSubscriber.State
- emitting - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
Indicates there is a replay going on; guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
-
Guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
-
Guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
Indicates an emission state.
- emitting - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Guarded by this.
- emitting - Variable in class rx.internal.operators.OperatorScan.InitialProducer
- emitting - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- emitting - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
-
Guarded by guard.
- emitting - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
-
Guarded by guard.
- emitting - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
-
Guarded by guard.
- emitting - Variable in class rx.internal.producers.ProducerArbiter
- emitting - Variable in class rx.internal.producers.ProducerObserverArbiter
- emitting - Variable in class rx.internal.util.BackpressureDrainManager
-
Indicates if one is in emitting phase, guarded by this.
- emitting - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- emitting - Variable in class rx.observers.SerializedObserver
- emitting - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Guarded by this.
- emitting - Variable in class rx.subjects.UnicastSubject.State
-
Emitter loop: emitting indicator.
- emitValue(T) - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- emitValue(T) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- emitValue(T) - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- empty - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- empty() - Static method in class rx.functions.Actions
- empty() - Static method in class rx.internal.operators.OperatorWindowWithTime.State
- empty() - Static method in class rx.Observable
-
Returns an Observable that emits no items to the
Observer
and immediately invokes itsonCompleted
method. - empty() - Static method in class rx.observers.Observers
- empty() - Static method in class rx.observers.Subscribers
-
Returns an inert
Subscriber
that does nothing in response to the emissions or notifications from anyObservable
it subscribes to. - empty() - Static method in class rx.subscriptions.Subscriptions
- EMPTY - Static variable in class rx.internal.operators.CachedObservable.CacheState
-
The default empty array of producers.
- EMPTY - Static variable in enum rx.internal.operators.EmptyObservableHolder
-
The singleton instance.
- EMPTY - Static variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Represents an empty array of subscriber wrapper, helps avoid allocating an empty array all the time.
- EMPTY - Static variable in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- EMPTY - Static variable in class rx.internal.operators.OnSubscribeTakeLastOne.TakeLastOneSubscriber
- EMPTY - Static variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
An empty array to avoid creating new empty arrays in removeInner.
- EMPTY - Static variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- EMPTY - Static variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Indicates an empty array of inner producers.
- EMPTY - Static variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Indicates an empty array of inner producers.
- EMPTY - Static variable in class rx.internal.operators.OperatorWindowWithTime.State
- EMPTY - Static variable in class rx.internal.operators.OperatorWithLatestFrom
-
Indicates the other has not yet emitted a value.
- EMPTY - Static variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- EMPTY - Static variable in class rx.observers.Observers
- EMPTY - Static variable in class rx.subjects.ReplaySubject.ReplayState
- EMPTY - Static variable in class rx.subjects.SubjectSubscriptionManager.State
- EMPTY_ACTION - Static variable in class rx.functions.Actions
- EMPTY_ACTION - Static variable in class rx.subscriptions.BooleanSubscription
- EMPTY_ARRAY - Static variable in class rx.subjects.BehaviorSubject
-
An empty array to trigger getValues() to return a new array.
- EMPTY_ARRAY - Static variable in class rx.subjects.ReplaySubject
-
An empty array to trigger getValues() to return a new array.
- EMPTY_OBSERVER - Static variable in class rx.internal.operators.BufferUntilSubscriber
- EMPTY_STATE - Static variable in class rx.subscriptions.RefCountSubscription
- EMPTY_TOKEN - Static variable in class rx.internal.operators.OperatorSampleWithObservable
-
Indicates that no value is available.
- EMPTY_TOKEN - Static variable in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
-
Indicates that no value is available.
- EmptyAction() - Constructor for class rx.functions.Actions.EmptyAction
- EmptyObservableHolder - Enum in rx.internal.operators
-
Holds a singleton instance of an empty Observable which is stateless and completes the child subscriber immediately.
- EmptyObservableHolder() - Constructor for enum rx.internal.operators.EmptyObservableHolder
- enableAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
-
Sets up hooks that capture the current stacktrace when a source or an operator is instantiated, keeping it in a field for debugging purposes and alters exceptions passign along to hold onto this stacktrace.
- END - Static variable in class rx.internal.operators.OnSubscribeConcatMap
-
Delay all errors to the very end.
- endBuffer(List<T>) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- endIndex - Variable in class rx.internal.operators.OnSubscribeRange
- endOfRange - Variable in class rx.internal.operators.OnSubscribeRange.RangeProducer
- endWindow(OperatorWindowWithStartEndObservable.SerializedSubject<T>) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- endWith(Completable) - Method in class rx.Completable
-
Deprecated.Use
Completable.andThen(rx.Completable)
instead. - endWith(Observable<T>) - Method in class rx.Completable
-
Deprecated.Use
Completable.andThen(rx.Observable)
instead. - enqueue(Action0, long) - Method in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- enterTransform(Object) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Override this to wrap the NotificationLite object into a container to be used later by truncate.
- enterTransform(Object) - Method in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- equals(Object) - Method in class rx.internal.util.SynchronizedQueue
- equals(Object) - Method in class rx.Notification
- equals(Object) - Method in class rx.schedulers.TimeInterval
- equals(Object) - Method in class rx.schedulers.Timestamped
- equalsWith(Object) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func1 that checks if its argument is null-safe equals with the given constant reference.
- EqualsWithFunc1(Object) - Constructor for class rx.internal.util.InternalObservableUtils.EqualsWithFunc1
- error - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- error - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- error - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- error - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- error - Variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- error - Variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- error - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Holds onto the upstream's exception if done is true and this field is non-null.
- error - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- error - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- error - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- error - Variable in class rx.internal.operators.OperatorGroupBy.State
- error - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
-
The single exception if not null, should be written before setting finished (release) and read after reading finished (acquire).
- error - Variable in class rx.internal.operators.OperatorScan.InitialProducer
- error - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- error - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- error - Variable in class rx.internal.producers.QueuedProducer
- error - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- error - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- error - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- error - Variable in class rx.subjects.UnicastSubject.State
-
In case the source emitted an error.
- error() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- error() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- error() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- error() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- error(Throwable) - Static method in class rx.Completable
-
Creates a Completable instance that emits the given Throwable exception to subscribers.
- error(Throwable) - Method in class rx.internal.operators.NotificationLite
-
Create a lite
onError
notification. - error(Throwable) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- error(Throwable) - Method in interface rx.internal.operators.OperatorReplay.ReplayBuffer
-
Adds a terminal exception to the buffer
- error(Throwable) - Method in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- error(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- error(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- error(Throwable) - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- error(Throwable) - Static method in class rx.Observable
- error(Throwable) - Static method in class rx.Single
-
Returns a Single that invokes a subscriber's
onError
method when the subscriber subscribes to it. - error(Throwable) - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- error(Throwable) - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- error(Throwable) - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- error(Throwable) - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- error(Throwable, long) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- error(Func0<? extends Throwable>) - Static method in class rx.Completable
-
Creates a Completable which calls the given error supplier for each subscriber and emits its returned Throwable.
- Error() - Constructor for class rx.BackpressureOverflow.Error
- ERROR - rx.AsyncEmitter.BackpressureMode
- ERROR_EXTRACTOR - Static variable in enum rx.internal.util.InternalObservableUtils
- ERROR_IN_RENDERING_SUFFIX - Static variable in class rx.plugins.RxJavaErrorHandler
- ERROR_NOT_IMPLEMENTED - Static variable in enum rx.internal.util.InternalObservableUtils
-
Throws an OnErrorNotImplementedException when called.
- errorAll(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Notify everyone and cleanup.
- errorAll(Subscriber<? super GroupedObservable<K, V>>, Queue<?>, Throwable) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- ErrorAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.ErrorAsyncEmitter
- errorHandler - Variable in class rx.plugins.RxJavaPlugins
- errorMain(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Notify only the main subscriber and cleanup.
- ErrorNotImplementedAction() - Constructor for class rx.internal.util.InternalObservableUtils.ErrorNotImplementedAction
- errors - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- errors - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Due to the emission loop, we need to store errors somewhere if !delayErrors.
- errors - Variable in class rx.observers.TestSubscriber
- es - Variable in class rx.internal.util.ScalarSynchronousSingle.DirectScheduledEmission
- eventLoops - Variable in class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- EventLoopsScheduler - Class in rx.internal.schedulers
- EventLoopsScheduler(ThreadFactory) - Constructor for class rx.internal.schedulers.EventLoopsScheduler
-
Create a scheduler with pool size equal to the available processor count and using least-recent worker selection policy.
- EventLoopsScheduler.EventLoopWorker - Class in rx.internal.schedulers
- EventLoopsScheduler.FixedSchedulerPool - Class in rx.internal.schedulers
- EventLoopsScheduler.PoolWorker - Class in rx.internal.schedulers
- EventLoopWorker(CachedThreadScheduler.CachedWorkerPool) - Constructor for class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- EventLoopWorker(EventLoopsScheduler.PoolWorker) - Constructor for class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- evictedKeys - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- evictedKeys - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber.EvictionAction
- evictExpiredWorkers() - Method in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- evictFinal() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- EvictionAction(Queue<K>) - Constructor for class rx.internal.operators.OperatorGroupBy.GroupBySubscriber.EvictionAction
- evictOld(long) - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- evictorService - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- evictorTask - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- ExactSubscriber(Subscriber<? super List<T>>, Scheduler.Worker) - Constructor for class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- ExactSubscriber(Subscriber<? super Observable<T>>, Scheduler.Worker) - Constructor for class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- exception - Variable in class rx.internal.operators.OnSubscribeThrow
- exception - Variable in class rx.internal.util.BackpressureDrainManager
-
Indicates an error state, barrier is provided via terminated.
- exceptions - Variable in exception rx.exceptions.CompositeException
- Exceptions - Class in rx.exceptions
-
Utility class with methods to wrap checked exceptions and manage fatal and regular exception delivery.
- Exceptions() - Constructor for class rx.exceptions.Exceptions
-
Utility class, no instances.
- ExceptionsUtils - Enum in rx.internal.util
-
Utility methods for terminal atomics with Throwables.
- ExceptionsUtils() - Constructor for enum rx.internal.util.ExceptionsUtils
- execTime - Variable in class rx.internal.schedulers.SleepingAction
- execTime - Variable in class rx.internal.schedulers.TrampolineScheduler.TimedAction
- executor - Variable in class rx.internal.schedulers.ExecutorScheduler
- executor - Variable in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- executor - Variable in class rx.internal.schedulers.GenericScheduledExecutorService
- executor - Variable in class rx.internal.schedulers.NewThreadWorker
- EXECUTORS - Static variable in class rx.internal.schedulers.NewThreadWorker
- ExecutorScheduler - Class in rx.internal.schedulers
-
Scheduler that wraps an Executor instance and establishes the Scheduler contract upon it.
- ExecutorScheduler(Executor) - Constructor for class rx.internal.schedulers.ExecutorScheduler
- ExecutorScheduler.ExecutorSchedulerWorker - Class in rx.internal.schedulers
-
Worker that schedules tasks on the executor indirectly through a trampoline mechanism.
- ExecutorSchedulerWorker(Executor) - Constructor for class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- exists(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits
true
if any item emitted by the source Observable satisfies a specified condition, otherwisefalse
. - expectedDelivery - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- Experimental - Annotation Type in rx.annotations
-
Signifies that a public API (public class, method or field) is will almost certainly be changed or removed in a future release.
- expirationTime - Variable in class rx.internal.schedulers.CachedThreadScheduler.ThreadWorker
- expire(int, Subscription) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber
- expire(int, Subscription) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber
- expiringWorkerQueue - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- extend(Func1<? super Observable.OnSubscribe<T>, ? extends R>) - Method in class rx.Observable
-
Passes all emitted values from this Observable to the provided conversion function to be collected and returned as a single value.
F
- f - Variable in class rx.internal.schedulers.ScheduledAction.FutureCompleter
- f - Variable in class rx.subscriptions.Subscriptions.FutureSubscription
- FastList() - Constructor for class rx.observers.SerializedObserver.FastList
- fastpath() - Method in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- fastpath() - Method in class rx.internal.operators.OnSubscribeRange.RangeProducer
-
Emits all remaining values without decrementing the requested amount.
- fastpath() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- fastPath - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- fastPath() - Method in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- fillInStackTrace() - Method in exception rx.exceptions.AssemblyStackTraceException
- filter(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Filters items emitted by an Observable by only emitting those that satisfy a specified predicate.
- FilterSubscriber(Subscriber<? super T>, Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- finallyDo(Action0) - Method in class rx.Observable
-
Deprecated.use
Observable.doAfterTerminate(Action0)
instead. - find(Throwable) - Static method in exception rx.exceptions.AssemblyStackTraceException
-
Locate the first AssemblyStackTraceException in the causal chain of the given Throwable (or it if it's one).
- findSetRemoveOnCancelPolicyMethod(ScheduledExecutorService) - Static method in class rx.internal.schedulers.NewThreadWorker
-
Tries to find
"setRemoveOnCancelPolicy(boolean)"
method in the class of passed executor. - finished - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- first - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Was the emitFirst run? Guarded by this.
- first() - Method in class rx.Observable
-
Returns an Observable that emits only the very first item emitted by the source Observable, or notifies of an
NoSuchElementException
if the source Observable is empty. - first() - Method in class rx.observables.BlockingObservable
-
Returns the first item emitted by this
BlockingObservable
, or throwsNoSuchElementException
if it emits no items. - first(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition, or notifies of an
NoSuchElementException
if no such items are emitted. - first(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the first item emitted by this
BlockingObservable
that matches a predicate, or throwsNoSuchElementException
if it emits no such item. - firstOrDefault(T) - Method in class rx.Observable
-
Returns an Observable that emits only the very first item emitted by the source Observable, or a default item if the source Observable completes without emitting anything.
- firstOrDefault(T) - Method in class rx.observables.BlockingObservable
-
Returns the first item emitted by this
BlockingObservable
, or a default value if it emits no items. - firstOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition, or a default item if the source Observable emits no such items.
- firstOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the first item emitted by this
BlockingObservable
that matches a predicate, or a default value if it emits no such items. - firstTimeoutStub - Variable in class rx.internal.operators.OperatorTimeoutBase
- FixedSchedulerPool(ThreadFactory, int) - Constructor for class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- flatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then merging those resulting Observables and emitting the results of this merger.
- flatMap(Func1<? super T, ? extends Observable<? extends R>>, int) - Method in class rx.Observable
-
Returns an Observable that emits items based on applying a function that you supply to each item emitted by the source Observable, where that function returns an Observable, and then merging those resulting Observables and emitting the results of this merger, while limiting the maximum number of concurrent subscriptions to these Observables.
- flatMap(Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>) - Method in class rx.Observable
-
Returns an Observable that applies a function to each item emitted or notification raised by the source Observable and then flattens the Observables returned from these functions and emits the resulting items.
- flatMap(Func1<? super T, ? extends Observable<? extends R>>, Func1<? super Throwable, ? extends Observable<? extends R>>, Func0<? extends Observable<? extends R>>, int) - Method in class rx.Observable
-
Returns an Observable that applies a function to each item emitted or notification raised by the source Observable and then flattens the Observables returned from these functions and emits the resulting items, while limiting the maximum number of concurrent subscriptions to these Observables.
- flatMap(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source Observable and a specified collection Observable.
- flatMap(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int) - Method in class rx.Observable
-
Returns an Observable that emits the results of a specified function to the pair of values emitted by the source Observable and a specified collection Observable, while limiting the maximum number of concurrent subscriptions to these Observables.
- flatMap(Func1<? super T, ? extends Single<? extends R>>) - Method in class rx.Single
-
Returns a Single that is based on applying a specified function to the item emitted by the source Single, where that function returns a Single.
- flatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>) - Method in class rx.Observable
-
Returns an Observable that merges each item emitted by the source Observable with the values in an Iterable corresponding to that item that is generated by a selector.
- flatMapIterable(Func1<? super T, ? extends Iterable<? extends R>>, int) - Method in class rx.Observable
-
Returns an Observable that merges each item emitted by the source Observable with the values in an Iterable corresponding to that item that is generated by a selector, while limiting the number of concurrent subscriptions to these Observables.
- flatMapIterable(Func1<? super T, ? extends Iterable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that emits the results of applying a function to the pair of values from the source Observable and an Iterable corresponding to that item that is generated by a selector.
- flatMapIterable(Func1<? super T, ? extends Iterable<? extends U>>, Func2<? super T, ? super U, ? extends R>, int) - Method in class rx.Observable
-
Returns an Observable that emits the results of applying a function to the pair of values from the source Observable and an Iterable corresponding to that item that is generated by a selector, while limiting the number of concurrent subscriptions to these Observables.
- flatMapObservable(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Single
-
Returns an Observable that emits items based on applying a specified function to the item emitted by the source Observable, where that function returns an Observable.
- FlattenIterableSubscriber(Subscriber<? super R>, Func1<? super T, ? extends Iterable<? extends R>>, int) - Constructor for class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- forEach(Action1<? super T>) - Method in class rx.Observable
-
Subscribes to the
Observable
and receives notifications for each element. - forEach(Action1<? super T>) - Method in class rx.observables.BlockingObservable
-
Invokes a method on each item emitted by this
BlockingObservable
and blocks until the Observable completes. - forEach(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
-
Subscribes to the
Observable
and receives notifications for each element and error events. - forEach(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
-
Subscribes to the
Observable
and receives notifications for each element and the terminal events. - forEach(Func1<? super E, Boolean>) - Method in class rx.internal.util.IndexedRingBuffer
- forEach(Func1<? super E, Boolean>, int) - Method in class rx.internal.util.IndexedRingBuffer
-
Loop through each element in the buffer and call a specific function.
- forEach(Func1<? super E, Boolean>, int, int) - Method in class rx.internal.util.IndexedRingBuffer
- forward - Variable in class rx.internal.operators.BufferUntilSubscriber
- FREQUENCY_KEY - Static variable in class rx.internal.schedulers.NewThreadWorker
-
The purge frequency in milliseconds.
- from(Iterable<? extends T>) - Static method in class rx.Observable
-
Converts an
Iterable
sequence into an Observable that emits the items in the sequence. - from(Throwable) - Static method in exception rx.exceptions.OnErrorThrowable
-
Converts a
Throwable
into anOnErrorThrowable
. - from(Executor) - Static method in class rx.schedulers.Schedulers
-
Converts an
Executor
into a new Scheduler instance. - from(Future<?>) - Static method in class rx.subscriptions.Subscriptions
-
Converts a
Future
into aSubscription
and cancels it when unsubscribed. - from(Future<? extends T>) - Static method in class rx.Observable
-
Converts a
Future
into an Observable. - from(Future<? extends T>) - Static method in class rx.Single
-
Converts a
Future
into aSingle
. - from(Future<? extends T>, long, TimeUnit) - Static method in class rx.Observable
-
Converts a
Future
into an Observable, with a timeout on the Future. - from(Future<? extends T>, long, TimeUnit) - Static method in class rx.Single
-
Converts a
Future
into aSingle
, with a timeout on the Future. - from(Future<? extends T>, Scheduler) - Static method in class rx.Observable
-
Converts a
Future
, operating on a specifiedScheduler
, into an Observable. - from(Future<? extends T>, Scheduler) - Static method in class rx.Single
- from(K, Observable<T>) - Static method in class rx.observables.GroupedObservable
-
Converts an
Observable
into aGroupedObservable
with a particular key. - from(Observable<? extends T>) - Static method in class rx.internal.operators.CachedObservable
-
Creates a cached Observable with a default capacity hint of 16.
- from(Observable<? extends T>) - Static method in class rx.observables.BlockingObservable
-
Converts an
Observable
into aBlockingObservable
. - from(Observable<? extends T>, int) - Static method in class rx.internal.operators.CachedObservable
-
Creates a cached Observable with the given capacity hint.
- from(Observer<? super T>) - Static method in class rx.observers.Subscribers
-
Converts an
Observer
into aSubscriber
. - from(Single<? extends T>) - Static method in class rx.singles.BlockingSingle
-
Converts a
Single
into aBlockingSingle
. - from(Subscription...) - Static method in class rx.subscriptions.Subscriptions
-
Converts a set of
Subscription
s into aCompositeSubscription
that groups the multiple Subscriptions together and unsubscribes from all of them together. - from(T[]) - Static method in class rx.Observable
-
Converts an Array into an Observable that emits the items in the Array.
- fromAction(Action0) - Static method in class rx.Completable
-
Returns a Completable instance that runs the given Action0 for each subscriber and emits either an unchecked exception or simply completes.
- fromAction(Action0) - Static method in class rx.functions.Functions
- fromAction(Action1<? super T0>) - Static method in class rx.functions.Functions
- fromAction(Action2<? super T0, ? super T1>) - Static method in class rx.functions.Functions
- fromAction(Action3<? super T0, ? super T1, ? super T2>) - Static method in class rx.functions.Functions
- FromArrayProducer(Subscriber<? super T>, T[]) - Constructor for class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- fromAsync(Action1<AsyncEmitter<T>>, AsyncEmitter.BackpressureMode) - Static method in class rx.Observable
-
Provides an API (via a cold Observable) that bridges the reactive world with the callback-style, generally non-backpressured world.
- fromCallable(Callable<?>) - Static method in class rx.Completable
-
Returns a Completable which when subscribed, executes the callable function, ignores its normal result and emits onError or onCompleted only.
- fromCallable(Callable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that, when an observer subscribes to it, invokes a function you specify and then emits the value returned from that function.
- fromCallable(Callable<? extends T>) - Static method in class rx.Single
-
Returns a
Single
that invokes passed function and emits its result for each new Observer that subscribes. - fromFunc(Func0<? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func1<? super T0, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func2<? super T0, ? super T1, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func3<? super T0, ? super T1, ? super T2, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func4<? super T0, ? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func5<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func6<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func7<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func8<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.functions.Functions
- fromFunc(Func9<? super T0, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.functions.Functions
- fromFuture(Future<?>) - Static method in class rx.Completable
-
Returns a Completable instance that reacts to the termination of the given Future in a blocking fashion.
- fromObservable(Observable<?>) - Static method in class rx.Completable
-
Returns a Completable instance that subscribes to the given flowable, ignores all values and emits only the terminal event.
- fromSingle(Single<?>) - Static method in class rx.Completable
-
Returns a Completable instance that when subscribed to, subscribes to the Single instance and emits a completion event if the single emits onSuccess or forwards any onError events.
- fullStackTrace - Static variable in class rx.internal.operators.OnSubscribeOnAssembly
-
If set to true, the creation of PublisherOnAssembly will capture the raw stacktrace instead of the sanitized version.
- fullStackTrace - Static variable in class rx.internal.operators.OnSubscribeOnAssemblyCompletable
-
If set to true, the creation of PublisherOnAssembly will capture the raw stacktrace instead of the sanitized version.
- fullStackTrace - Static variable in class rx.internal.operators.OnSubscribeOnAssemblySingle
-
If set to true, the creation of PublisherOnAssembly will capture the raw stacktrace instead of the sanitized version.
- Func0<R> - Interface in rx.functions
-
Represents a function with zero arguments.
- Func1<T,R> - Interface in rx.functions
-
Represents a function with one argument.
- Func2<T1,T2,R> - Interface in rx.functions
-
Represents a function with two arguments.
- Func3<T1,T2,T3,R> - Interface in rx.functions
-
Represents a function with three arguments.
- Func4<T1,T2,T3,T4,R> - Interface in rx.functions
-
Represents a function with four arguments.
- Func5<T1,T2,T3,T4,T5,R> - Interface in rx.functions
-
Represents a function with five arguments.
- Func6<T1,T2,T3,T4,T5,T6,R> - Interface in rx.functions
-
Represents a function with six arguments.
- Func7<T1,T2,T3,T4,T5,T6,T7,R> - Interface in rx.functions
-
Represents a function with seven arguments.
- Func8<T1,T2,T3,T4,T5,T6,T7,T8,R> - Interface in rx.functions
-
Represents a function with eight arguments.
- Func9<T1,T2,T3,T4,T5,T6,T7,T8,T9,R> - Interface in rx.functions
-
Represents a function with nine arguments.
- FuncN<R> - Interface in rx.functions
-
Represents a vector-argument function.
- Function - Interface in rx.functions
-
All Func and Action interfaces extend from this.
- Functions - Class in rx.functions
- Functions() - Constructor for class rx.functions.Functions
- FutureCompleter(Future<?>) - Constructor for class rx.internal.schedulers.ScheduledAction.FutureCompleter
- FutureSubscription(Future<?>) - Constructor for class rx.subscriptions.Subscriptions.FutureSubscription
G
- generateState() - Method in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- generateState() - Method in class rx.observables.AsyncOnSubscribe
-
Executed once when subscribed to by a subscriber (via
AsyncOnSubscribe.call(Subscriber)
) to produce a state value. - generateState() - Method in class rx.observables.SyncOnSubscribe
-
Executed once when subscribed to by a subscriber (via
SyncOnSubscribe.call(Subscriber)
) to produce a state value. - generateState() - Method in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- generator - Variable in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- generator - Variable in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- GenericScheduledExecutorService - Class in rx.internal.schedulers
-
A default
ScheduledExecutorService
that can be used for scheduling actions when aScheduler
implementation doesn't have that ability. - GenericScheduledExecutorService() - Constructor for class rx.internal.schedulers.GenericScheduledExecutorService
- GenericScheduledExecutorServiceFactory - Enum in rx.internal.schedulers
-
Utility class to create the individual ScheduledExecutorService instances for the GenericScheduledExecutorService class.
- GenericScheduledExecutorServiceFactory() - Constructor for enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
- get() - Method in class rx.Completable
-
Subscribes to this Completable instance and blocks until it terminates, then returns null or the emitted exception if any.
- get() - Method in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- get() - Method in class rx.internal.util.ScalarSynchronousObservable
-
Returns the scalar constant value directly.
- get() - Method in class rx.internal.util.ScalarSynchronousSingle
- get() - Method in class rx.subscriptions.MultipleAssignmentSubscription
-
Gets the underlying subscription.
- get() - Method in class rx.subscriptions.RefCountSubscription
-
Returns a new sub-subscription
- get() - Method in class rx.subscriptions.SerialSubscription
-
Retrieves the current
Subscription
that is being represented by thisSerialSubscription
. - get(long, TimeUnit) - Method in class rx.Completable
-
Subscribes to this Completable instance and blocks until it terminates or the specified timeout elapses, then returns null for normal termination or the emitted exception if any.
- getActual() - Method in class rx.observers.SafeSubscriber
-
Returns the
Subscriber
underlying thisSafeSubscriber
. - getActual() - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- getAndAddInt(Object, long, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
- getAndAddRequest(AtomicLongFieldUpdater<T>, T, long) - Static method in class rx.internal.operators.BackpressureUtils
-
Deprecated.Android has issues with reflection-based atomics
- getAndAddRequest(AtomicLong, long) - Static method in class rx.internal.operators.BackpressureUtils
-
Adds
n
(not validated) torequested
and returns the value prior to addition once the addition is successful (uses CAS semantics). - getAndIncrementInt(Object, long) - Static method in class rx.internal.util.unsafe.UnsafeAccess
- getAndNullValue() - Method in class rx.internal.util.atomic.LinkedQueueNode
-
Gets the current value and nulls out the reference to it from this node.
- getAndroidApiVersion() - Static method in class rx.internal.util.PlatformDependent
-
Returns version of Android API.
- getAndSet(int, int) - Method in class rx.internal.util.IndexedRingBuffer.IndexSection
- getAndSetInt(Object, long, int) - Static method in class rx.internal.util.unsafe.UnsafeAccess
- getCause() - Method in exception rx.exceptions.CompositeException
- getCompletableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
-
Retrieves the instance of
RxJavaCompletableExecutionHook
to use based on order of precedence as defined inRxJavaPlugins
class header. - getCompletions() - Method in class rx.observers.TestSubscriber
-
Returns the number of times onCompleted was called on this TestSubscriber.
- getComputationScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
-
Scheduler to return from
Schedulers.computation()
or null if default should be used. - getDefaultInstance() - Static method in class rx.plugins.RxJavaSchedulersHook
- getElementSection(int) - Method in class rx.internal.util.IndexedRingBuffer
- getError(Object) - Method in class rx.internal.operators.NotificationLite
-
Returns the
Throwable
corresponding to thisOnError
lite notification. - getErrorHandler() - Method in class rx.plugins.RxJavaPlugins
-
Retrieves an instance of
RxJavaErrorHandler
to use based on order of precedence as defined inRxJavaPlugins
class header. - getEventLoop() - Method in class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- getEvents() - Method in class rx.observers.TestObserver
-
Deprecated.Get a list containing all of the items and notifications received by this observer, where the items will be given as-is, any error notifications will be represented by their
Throwable
s, and any sequence-complete notifications will be represented by theirNotification
objects. - getExceptions() - Method in exception rx.exceptions.CompositeException
-
Retrieves the list of exceptions that make up the
CompositeException
- getExpirationTime() - Method in class rx.internal.schedulers.CachedThreadScheduler.ThreadWorker
- getFinalCause(Throwable) - Static method in class rx.exceptions.Exceptions
-
Get the
Throwable
at the end of the causality-chain for a particularThrowable
- getIndexForAdd() - Method in class rx.internal.util.IndexedRingBuffer
- getIndexFromPreviouslyRemoved() - Method in class rx.internal.util.IndexedRingBuffer
-
Returns -1 if nothing, 0 or greater if the index should be used
- getIndexSection(int) - Method in class rx.internal.util.IndexedRingBuffer
- getInitialHead() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Returns the current head for initializing the replay location for a new subscriber.
- getInitialHead() - Method in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- getInstance() - Static method in class rx.internal.schedulers.GenericScheduledExecutorService
-
Returns one of the single-threaded ScheduledExecutorService helper executors.
- getInstance() - Static method in class rx.internal.util.IndexedRingBuffer
- getInstance() - Static method in class rx.plugins.RxJavaObservableExecutionHookDefault
- getInstance() - Static method in class rx.plugins.RxJavaPlugins
-
Deprecated.use the static methods of
RxJavaHooks
. - getInstance() - Static method in class rx.plugins.RxJavaSingleExecutionHookDefault
- getInstance() - Static method in class rx.schedulers.Schedulers
- getIntervalInMilliseconds() - Method in class rx.schedulers.TimeInterval
-
Returns the time interval, expressed in milliseconds.
- getIOScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
-
Scheduler to return from
Schedulers.io()
or null if default should be used. - getIterable() - Method in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
-
The
Iterator
return is not thread safe. - getIterator() - Method in class rx.observables.BlockingObservable
-
Returns an
Iterator
that iterates over all items emitted by thisBlockingObservable
. - getKey() - Method in class rx.observables.GroupedObservable
-
Returns the key that identifies the group of items emitted by this
GroupedObservable
- getKind() - Method in class rx.Notification
-
Retrieves the kind of this notification:
OnNext
,OnError
, orOnCompleted
- getLastSeenThread() - Method in class rx.observers.TestSubscriber
-
Returns the last thread that was in use when an item or notification was received by this
Subscriber
. - getLatest() - Method in class rx.subjects.SubjectSubscriptionManager
- getListOfCauses(Throwable) - Method in exception rx.exceptions.CompositeException
- getMessage() - Method in exception rx.exceptions.CompositeException.CompositeExceptionCausalChain
- getMessage() - Method in exception rx.exceptions.CompositeException
- getNewThreadScheduler() - Method in class rx.plugins.RxJavaSchedulersHook
-
Scheduler to return from
Schedulers.newThread()
or null if default should be used. - getNext() - Method in class rx.internal.util.IndexedRingBuffer.ElementSection
- getNext() - Method in class rx.internal.util.IndexedRingBuffer.IndexSection
- getObservableExecutionHook() - Method in class rx.plugins.RxJavaPlugins
-
Retrieves the instance of
RxJavaObservableExecutionHook
to use based on order of precedence as defined inRxJavaPlugins
class header. - getOnCompletableCreate() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Completable onCreate hook function or null if it is set to the default pass-through.
- getOnCompletableLift() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Completable onLift hook function or null if it is set to the default pass-through.
- getOnCompletableStart() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Completable onStart hook function or null if it is set to the default pass-through.
- getOnCompletableSubscribeError() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Completable onSubscribeError hook function or null if it is set to the default pass-through.
- getOnCompletedEvents() - Method in class rx.observers.TestObserver
-
Deprecated.Get the
Notification
s representing each time this observer was notified of sequence completion viaTestObserver.onCompleted()
, as aList
. - getOnCompletedEvents() - Method in class rx.observers.TestSubscriber
-
Deprecated.use
TestSubscriber.getCompletions()
instead. - getOnComputationScheduler() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current computation scheduler hook function or null if it is set to the default pass-through.
- getOnError() - Static method in class rx.plugins.RxJavaHooks
-
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.
- getOnErrorEvents() - Method in class rx.observers.TestObserver
-
Deprecated.Get the
Throwable
s this observer was notified of viaTestObserver.onError(java.lang.Throwable)
as aList
. - getOnErrorEvents() - Method in class rx.observers.TestSubscriber
-
Returns the
Throwable
s thisSubscriber
was notified of viaTestSubscriber.onError(java.lang.Throwable)
as aList
. - getOnGenericScheduledExecutorService() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current factory for creating ScheduledExecutorServices in GenericScheduledExecutorService utility.
- getOnIOScheduler() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current io scheduler hook function or null if it is set to the default pass-through.
- getOnNewThreadScheduler() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current new thread scheduler hook function or null if it is set to the default pass-through.
- getOnNextEvents() - Method in class rx.observers.TestObserver
-
Deprecated.Get the sequence of items observed by this observer, as an ordered
List
. - getOnNextEvents() - Method in class rx.observers.TestSubscriber
-
Returns the sequence of items observed by this
Subscriber
, as an orderedList
. - getOnObservableCreate() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Observable onCreate hook function or null if it is set to the default pass-through.
- getOnObservableLift() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Observable onLift hook function or null if it is set to the default pass-through.
- getOnObservableReturn() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Observable onReturn hook function or null if it is set to the default pass-through.
- getOnObservableStart() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Observable onStart hook function or null if it is set to the default pass-through.
- getOnObservableSubscribeError() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Observable onSubscribeError hook function or null if it is set to the default pass-through.
- getOnScheduleAction() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current schedule action hook function or null if it is set to the default pass-through.
- getOnSingleCreate() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Single onCreate hook function or null if it is set to the default pass-through.
- getOnSingleLift() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Single onLift hook function or null if it is set to the default pass-through.
- getOnSingleReturn() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Single onReturn hook function or null if it is set to the default pass-through.
- getOnSingleStart() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Single onStart hook function or null if it is set to the default pass-through.
- getOnSingleSubscribeError() - Static method in class rx.plugins.RxJavaHooks
-
Returns the current Single onSubscribeError hook function or null if it is set to the default pass-through.
- getOrCreateComposite() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- getOrCreateErrorQueue() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- getOrCreateErrors() - Method in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- getPluginImplementationViaProperty(Class<?>, Properties) - Static method in class rx.plugins.RxJavaPlugins
- getRootCause(Throwable) - Method in exception rx.exceptions.CompositeException
-
Returns the root cause of
e
. - getSchedulersHook() - Method in class rx.plugins.RxJavaPlugins
-
Retrieves the instance of
RxJavaSchedulersHook
to use based on order of precedence as defined in theRxJavaPlugins
class header. - getSingleExecutionHook() - Method in class rx.plugins.RxJavaPlugins
-
Retrieves the instance of
RxJavaSingleExecutionHook
to use based on order of precedence as defined inRxJavaPlugins
class header. - getSpmcInstance() - Static method in class rx.internal.util.RxRingBuffer
- getSpscInstance() - Static method in class rx.internal.util.RxRingBuffer
- getSystemClassLoader() - Static method in class rx.internal.util.PlatformDependent
-
Return the system
ClassLoader
. - getThrowable() - Method in class rx.Notification
-
Retrieves the exception associated with this (onError) notification.
- getThrowable() - Method in class rx.subjects.AsyncSubject
-
Returns the Throwable that terminated the Subject.
- getThrowable() - Method in class rx.subjects.BehaviorSubject
-
Returns the Throwable that terminated the Subject.
- getThrowable() - Method in class rx.subjects.PublishSubject
-
Returns the Throwable that terminated the Subject.
- getThrowable() - Method in class rx.subjects.ReplaySubject
-
Returns the Throwable that terminated the Subject.
- getTimestampMillis() - Method in class rx.schedulers.Timestamped
-
Returns the timestamp, expressed in milliseconds.
- getValue() - Method in exception rx.exceptions.OnErrorThrowable
-
Get the value associated with this
OnErrorThrowable
- getValue() - Method in exception rx.exceptions.OnErrorThrowable.OnNextValue
-
Retrieve the item that the Observable was trying to emit at the time this exception occurred.
- getValue() - Method in class rx.Notification
-
Retrieves the item associated with this (onNext) notification.
- getValue() - Method in class rx.schedulers.TimeInterval
-
Returns the item that was emitted by the Observable after this time interval.
- getValue() - Method in class rx.schedulers.Timestamped
-
Returns the value embedded in the
Timestamped
object. - getValue() - Method in class rx.subjects.AsyncSubject
-
Returns the current value of the Subject if there is such a value and the subject hasn't terminated with an exception.
- getValue() - Method in class rx.subjects.BehaviorSubject
-
Returns the current value of the Subject if there is such a value and the subject hasn't terminated yet.
- getValue() - Method in class rx.subjects.ReplaySubject
- getValue(Object) - Method in class rx.internal.operators.NotificationLite
-
Returns the item corresponding to this
OnNext
lite notification. - getValue(Object) - Method in class rx.internal.util.RxRingBuffer
- getValueCount() - Method in class rx.observers.TestSubscriber
-
Returns the committed number of onNext elements that are safe to be read from
TestSubscriber.getOnNextEvents()
other threads. - getValues() - Method in class rx.subjects.BehaviorSubject
-
Returns a snapshot of the currently buffered non-terminal events.
- getValues() - Method in class rx.subjects.ReplaySubject
-
Returns a snapshot of the currently buffered non-terminal events.
- getValues(T[]) - Method in class rx.subjects.BehaviorSubject
-
Returns a snapshot of the currently buffered non-terminal events into the provided
a
array or creates a new array if it has not enough capacity. - getValues(T[]) - Method in class rx.subjects.ReplaySubject
-
Returns a snapshot of the currently buffered non-terminal events into the provided
a
array or creates a new array if it has not enough capacity. - group - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- group - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
- groupBy(Func1<? super T, ? extends K>) - Method in class rx.Observable
-
Groups the items emitted by an
Observable
according to a specified criterion, and emits these grouped items asGroupedObservable
s. - groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>) - Method in class rx.Observable
-
Groups the items emitted by an
Observable
according to a specified criterion, and emits these grouped items asGroupedObservable
s. - groupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends R>, Func1<Action1<K>, Map<K, Object>>) - Method in class rx.Observable
-
Groups the items emitted by an
Observable
according to a specified criterion, and emits these grouped items asGroupedObservable
s. - GroupByProducer(OperatorGroupBy.GroupBySubscriber<?, ?, ?>) - Constructor for class rx.internal.operators.OperatorGroupBy.GroupByProducer
- GroupBySubscriber(Subscriber<? super GroupedObservable<K, V>>, Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, int, boolean, Func1<Action1<K>, Map<K, Object>>) - Constructor for class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- groupCount - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- GroupedObservable<K,T> - Class in rx.observables
-
An
Observable
that has been grouped by key, the value of which can be obtained withGroupedObservable.getKey()
. - GroupedObservable(K, Observable.OnSubscribe<T>) - Constructor for class rx.observables.GroupedObservable
- GroupedUnicast(K, OperatorGroupBy.State<T, K>) - Constructor for class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- groupJoin(Observable<T2>, Func1<? super T, ? extends Observable<D1>>, Func1<? super T2, ? extends Observable<D2>>, Func2<? super T, ? super Observable<T2>, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that correlates two Observables when they overlap in time and groups the results.
- groups - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- guard - Variable in class rx.internal.operators.BufferUntilSubscriber.State
- guard - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- guard - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
- guard - Variable in class rx.internal.operators.OperatorMulticast
- guard - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- guard - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- guard - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- guard - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- guard - Variable in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- guardedSubscription - Variable in class rx.internal.operators.OperatorMulticast
H
- handleError(Throwable) - Method in class rx.plugins.RxJavaErrorHandler
-
Deprecated.
- handleOnNextValueRendering(Object) - Method in class rx.plugins.RxJavaErrorHandler
-
Receives items causing
OnErrorThrowable.OnNextValue
and gives a chance to choose the String representation of the item in theOnNextValue
stacktrace rendering. - handleSubscriptionTimeError(SingleSubscriber<? super T>, Resource, Throwable) - Method in class rx.internal.operators.SingleOnSubscribeUsing
- handleThrownError(Throwable) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- handleThrownError(Subscriber<? super T>, Throwable) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- HAS_NEXT - Static variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- HAS_NEXT - Static variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- HAS_NEXT - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- HAS_REQUEST_HAS_VALUE - Static variable in class rx.internal.operators.DeferredScalarSubscriber
-
Value will be emitted.
- HAS_REQUEST_HAS_VALUE - Static variable in class rx.internal.producers.SingleDelayedProducer
- HAS_REQUEST_NO_VALUE - Static variable in class rx.internal.operators.DeferredScalarSubscriber
-
Request came first.
- HAS_REQUEST_NO_VALUE - Static variable in class rx.internal.producers.SingleDelayedProducer
- hasAnyValue() - Method in class rx.subjects.ReplaySubject
- hasCompleted() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- hasCompleted() - Method in class rx.subjects.AsyncSubject
-
Check if the Subject has terminated normally.
- hasCompleted() - Method in class rx.subjects.BehaviorSubject
-
Check if the Subject has terminated normally.
- hasCompleted() - Method in class rx.subjects.PublishSubject
-
Check if the Subject has terminated normally.
- hasCompleted() - Method in class rx.subjects.ReplaySubject
-
Check if the Subject has terminated normally.
- hasDefault - Variable in class rx.internal.operators.OperatorElementAt
- hasDefaultValue - Variable in class rx.internal.operators.OperatorSingle
- hasDefaultValue - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- hasError - Variable in class rx.internal.producers.ProducerObserverArbiter
- hasError() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- hashCode() - Method in class rx.internal.util.SynchronizedQueue
- hashCode() - Method in class rx.Notification
- hashCode() - Method in class rx.schedulers.TimeInterval
- hashCode() - Method in class rx.schedulers.Timestamped
- hasNext - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- hasNext() - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- hasNext() - Method in class rx.internal.operators.BlockingOperatorNext.NextIterator
- hasNext() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- hasObservers() - Method in class rx.internal.operators.BufferUntilSubscriber
- hasObservers() - Method in class rx.internal.operators.CachedObservable
-
Returns true if there are observers subscribed to this observable.
- hasObservers() - Method in class rx.subjects.AsyncSubject
- hasObservers() - Method in class rx.subjects.BehaviorSubject
- hasObservers() - Method in class rx.subjects.PublishSubject
- hasObservers() - Method in class rx.subjects.ReplaySubject
- hasObservers() - Method in class rx.subjects.SerializedSubject
- hasObservers() - Method in class rx.subjects.Subject
- hasObservers() - Method in class rx.subjects.TestSubject
- hasObservers() - Method in class rx.subjects.UnicastSubject
- hasSubscriptions() - Method in class rx.internal.util.SubscriptionList
-
Returns true if this composite is not unsubscribed and contains subscriptions.
- hasSubscriptions() - Method in class rx.subscriptions.CompositeSubscription
-
Returns true if this composite is not unsubscribed and contains subscriptions.
- hasTerminated - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- hasTerminated - Variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- hasThrowable() - Method in class rx.Notification
-
Indicates whether this notification has an exception associated with it.
- hasThrowable() - Method in class rx.subjects.AsyncSubject
-
Check if the Subject has terminated with an exception.
- hasThrowable() - Method in class rx.subjects.BehaviorSubject
-
Check if the Subject has terminated with an exception.
- hasThrowable() - Method in class rx.subjects.PublishSubject
-
Check if the Subject has terminated with an exception.
- hasThrowable() - Method in class rx.subjects.ReplaySubject
-
Check if the Subject has terminated with an exception.
- hasTooManyElements - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- hasValue - Variable in exception rx.exceptions.OnErrorThrowable
- hasValue - Variable in class rx.internal.operators.DeferredScalarSubscriber
-
Indicates there is a value available in value.
- hasValue - Variable in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
-
Guarded by this.
- hasValue() - Method in class rx.Notification
-
Indicates whether this notification has an item associated with it.
- hasValue() - Method in class rx.subjects.AsyncSubject
-
Check if the Subject has a value.
- hasValue() - Method in class rx.subjects.BehaviorSubject
-
Check if the Subject has a value.
- hasValue() - Method in class rx.subjects.ReplaySubject
- head - Variable in class rx.internal.util.LinkedArrayList
-
Contains the head of the linked array list if not null.
- head - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- head - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- head - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- head() - Method in class rx.internal.util.LinkedArrayList
-
Returns the head buffer segment or null if the list is empty.
- Holder() - Constructor for class rx.internal.operators.OperatorAsObservable.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorDematerialize.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorDistinct.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorDistinctUntilChanged.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorIgnoreElements.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorMaterialize.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorOnBackpressureDrop.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorOnBackpressureLatest.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorSerialize.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorSingle.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorSwitch.Holder
- Holder() - Constructor for class rx.internal.operators.OperatorToObservableList.Holder
- HolderDelayError() - Constructor for class rx.internal.operators.OperatorSwitch.HolderDelayError
- HolderDelayErrors() - Constructor for class rx.internal.operators.OperatorMerge.HolderDelayErrors
- HolderNoDelay() - Constructor for class rx.internal.operators.OperatorMerge.HolderNoDelay
I
- id - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- id - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- id - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- id - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- id - Variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- id - Variable in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- identity() - Static method in class rx.internal.util.UtilityFunctions
-
Returns a function that always returns the Object it is passed.
- ignoreElements() - Method in class rx.Observable
-
Ignores all items emitted by the source Observable and only calls
onCompleted
oronError
. - immediate() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
Scheduler
that executes work immediately on the current thread. - IMMEDIATE - Static variable in class rx.internal.operators.OnSubscribeConcatMap
-
Whenever any Observable fires an error, terminate with that error immediately.
- ImmediateAction(Action0) - Constructor for class rx.internal.schedulers.SchedulerWhen.ImmediateAction
- ImmediateScheduler - Class in rx.internal.schedulers
-
Executes work immediately on the current thread.
- ImmediateScheduler - Class in rx.schedulers
-
Deprecated.This type was never publicly instantiable. Use
Schedulers.immediate()
. - ImmediateScheduler() - Constructor for class rx.internal.schedulers.ImmediateScheduler
- ImmediateScheduler() - Constructor for class rx.schedulers.ImmediateScheduler
-
Deprecated.
- ImmediateScheduler.InnerImmediateScheduler - Class in rx.internal.schedulers
- index - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
Contains the absolute index up until the values have been replayed so far.
- index - Variable in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- index - Variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- index - Variable in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- index - Variable in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- index - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- index - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- index - Variable in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
-
Guarded by this.
- index - Variable in class rx.internal.operators.OperatorElementAt
- index - Variable in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
The total number of received values so far.
- index - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
Holds an object that represents the current location in the buffer.
- index - Variable in class rx.internal.operators.OperatorReplay.Node
-
The absolute index of the value.
- index - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- index - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- index - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- index - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- index - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- index - Variable in class rx.internal.util.IndexedRingBuffer
- index - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
Unbounded buffer.drain() uses this field to remember the absolute index of values replayed to this Subscriber.
- index - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Indicate where the observer is at replaying.
- index() - Method in class rx.internal.operators.OperatorReplay.InnerProducer
-
Convenience method to auto-cast the index object.
- index() - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Returns the stored index.
- index(Object) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Sets a new index value.
- IndexedRingBuffer<E> - Class in rx.internal.util
-
Add/Remove without object allocation (after initial construction).
- IndexedRingBuffer() - Constructor for class rx.internal.util.IndexedRingBuffer
- IndexedRingBuffer.ElementSection<E> - Class in rx.internal.util
- IndexedRingBuffer.IndexSection - Class in rx.internal.util
- indexInTail - Variable in class rx.internal.util.LinkedArrayList
-
The next available slot in the current tail.
- indexInTail() - Method in class rx.internal.util.LinkedArrayList
-
Returns the index of the next slot in the tail buffer segment.
- IndexSection() - Constructor for class rx.internal.util.IndexedRingBuffer.IndexSection
- INERT - Static variable in class rx.observers.TestObserver
-
Deprecated.
- INERT - Static variable in class rx.observers.TestSubscriber
-
The shared no-op observer.
- InexactSubscriber(Subscriber<? super List<T>>, Scheduler.Worker) - Constructor for class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- InexactSubscriber(Subscriber<? super Observable<T>>, Scheduler.Worker) - Constructor for class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- init() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- init() - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- init() - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- init() - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Should be called after the constructor finished to setup nulling-out the current reference.
- init() - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Should be called after the constructor finished to setup nulling-out the current reference.
- init() - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- init() - Static method in class rx.plugins.RxJavaHooks
-
Initialize the hooks via delegating to RxJavaPlugins.
- initCreate() - Static method in class rx.plugins.RxJavaHooks
- initialCapacity - Variable in class rx.internal.operators.OperatorBufferWithSingleObservable
- initialCapacity - Variable in class rx.internal.operators.OperatorToObservableSortedList
- initialDelay - Variable in class rx.internal.operators.OnSubscribeTimerPeriodically
- initialize(int) - Method in class rx.internal.util.ObjectPool
- InitialProducer(R, Subscriber<? super R>) - Constructor for class rx.internal.operators.OperatorScan.InitialProducer
- initialValue - Variable in class rx.internal.operators.OnSubscribeReduceSeed
- initialValueFactory - Variable in class rx.internal.operators.OperatorScan
- inner - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- inner - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- inner - Variable in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- inner - Variable in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- inner - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- inner - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- innerActive - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- innerComplete() - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- innerComplete(int) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- innerCompleted(long) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- InnerCurrentThreadScheduler() - Constructor for class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- innerError(int, Throwable) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- innerError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- innerError(Throwable, long) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- innerGuard - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- InnerImmediateScheduler() - Constructor for class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- innerNext(int, Object) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- innerNext(R) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- innerProducer(Producer, long) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- InnerProducer(DeferredScalarSubscriber<?, ?>) - Constructor for class rx.internal.operators.DeferredScalarSubscriber.InnerProducer
- InnerProducer(OperatorPublish.PublishSubscriber<T>, Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorPublish.InnerProducer
- InnerProducer(OperatorReplay.ReplaySubscriber<T>, Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorReplay.InnerProducer
- InnerProducer(Producer) - Constructor for class rx.internal.operators.OperatorElementAt.InnerProducer
- innerRequest(long) - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- innerScheduler - Variable in class rx.internal.schedulers.SleepingAction
- innerScheduler - Variable in class rx.subjects.TestSubject
- InnerSubscriber() - Constructor for class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- InnerSubscriber(long, OperatorSwitch.SwitchSubscriber<T>) - Constructor for class rx.internal.operators.OperatorSwitch.InnerSubscriber
- InnerSubscriber(OperatorMerge.MergeSubscriber<T>, long) - Constructor for class rx.internal.operators.OperatorMerge.InnerSubscriber
- innerSubscribers - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Copy-on-write array, guarded by innerGuard.
- innerSubscription - Variable in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- innerSubscription - Variable in class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- innerSubscription - Variable in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- InnerSubscription(RefCountSubscription) - Constructor for class rx.subscriptions.RefCountSubscription.InnerSubscription
- InnerTestScheduler() - Constructor for class rx.schedulers.TestScheduler.InnerTestScheduler
- innerUnsubscribe() - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- iNotif - Variable in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- instance() - Static method in enum rx.internal.operators.EmptyObservableHolder
-
Returns a type-corrected singleton instance of the empty Observable.
- instance() - Static method in enum rx.internal.operators.NeverObservableHolder
-
Returns a type-corrected singleton instance of the never Observable.
- instance() - Static method in class rx.internal.operators.NotificationLite
-
Gets the
NotificationLite
singleton. - instance() - Static method in class rx.internal.operators.OperatorAsObservable
- instance() - Static method in class rx.internal.operators.OperatorDematerialize
- instance() - Static method in class rx.internal.operators.OperatorDistinct
-
Returns a singleton instance of OperatorDistinct that was built using the identity function for comparison (
new OperatorDistinct(UtilityFunctions.identity())
). - instance() - Static method in class rx.internal.operators.OperatorDistinctUntilChanged
-
Returns a singleton instance of OperatorDistinctUntilChanged that was built using the identity function for comparison (
new OperatorDistinctUntilChanged(UtilityFunctions.identity())
). - instance() - Static method in class rx.internal.operators.OperatorIgnoreElements
- instance() - Static method in class rx.internal.operators.OperatorMaterialize
- instance() - Static method in class rx.internal.operators.OperatorOnBackpressureBuffer
- instance() - Static method in class rx.internal.operators.OperatorOnBackpressureDrop
- instance() - Static method in class rx.internal.operators.OperatorOnBackpressureLatest
-
Returns a singleton instance of the OnBackpressureLatest operator since it is stateless.
- instance() - Static method in class rx.internal.operators.OperatorSerialize
- instance() - Static method in class rx.internal.operators.OperatorSingle
-
Returns a singleton instance of OperatorSingle (if the stream is empty or has more than one element an error will be emitted) that is cast to the generic type.
- instance() - Static method in class rx.internal.operators.OperatorToObservableList
- instance(boolean) - Static method in class rx.internal.operators.OperatorMerge
- instance(boolean) - Static method in class rx.internal.operators.OperatorSwitch
-
Returns a singleton instance of the operator based on the delayError parameter.
- instance(boolean, int) - Static method in class rx.internal.operators.OperatorMerge
-
Creates a new instance of the operator with the given delayError and maxConcurrency settings.
- INSTANCE - rx.internal.operators.EmptyObservableHolder
- INSTANCE - rx.internal.operators.NeverObservableHolder
- INSTANCE - rx.internal.operators.OnSubscribeDetach.TerminatedProducer
- INSTANCE - rx.internal.util.UtilityFunctions.AlwaysFalse
- INSTANCE - rx.internal.util.UtilityFunctions.AlwaysTrue
- INSTANCE - Static variable in class rx.BackpressureOverflow.DropLatest
- INSTANCE - Static variable in class rx.BackpressureOverflow.DropOldest
- INSTANCE - Static variable in class rx.BackpressureOverflow.Error
- INSTANCE - Static variable in class rx.exceptions.OnErrorThrowable.OnNextValue.Primitives
- INSTANCE - Static variable in class rx.internal.operators.NotificationLite
- INSTANCE - Static variable in class rx.internal.operators.OperatorAsObservable.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorDematerialize.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorDistinct.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorDistinctUntilChanged.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorIgnoreElements.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorMaterialize.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorMerge.HolderDelayErrors
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorMerge.HolderNoDelay
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorOnBackpressureBuffer.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorOnBackpressureDrop.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorOnBackpressureLatest.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorSerialize.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorSingle.Holder
- INSTANCE - Static variable in class rx.internal.operators.OperatorSwitch.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorSwitch.HolderDelayError
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.operators.OperatorToObservableList.Holder
-
A singleton instance.
- INSTANCE - Static variable in class rx.internal.schedulers.GenericScheduledExecutorService
- INSTANCE - Static variable in class rx.internal.schedulers.ImmediateScheduler
- INSTANCE - Static variable in class rx.internal.schedulers.TrampolineScheduler
- INSTANCE - Static variable in class rx.plugins.RxJavaObservableExecutionHookDefault
- INSTANCE - Static variable in class rx.plugins.RxJavaPlugins
- INSTANCE - Static variable in class rx.plugins.RxJavaSingleExecutionHookDefault
- INSTANCE - Static variable in class rx.schedulers.Schedulers
- INT_PHI - Static variable in class rx.internal.util.OpenHashSet
- InternalObservableUtils - Enum in rx.internal.util
-
Holder of named utility classes factored out from Observable to save source space and help with debugging with properly named objects.
- InternalObservableUtils() - Constructor for enum rx.internal.util.InternalObservableUtils
- InternalObservableUtils.CollectorCaller<T,R> - Class in rx.internal.util
- InternalObservableUtils.EqualsWithFunc1 - Class in rx.internal.util
- InternalObservableUtils.ErrorNotImplementedAction - Class in rx.internal.util
- InternalObservableUtils.IsInstanceOfFunc1 - Class in rx.internal.util
- InternalObservableUtils.NotificationErrorExtractor - Class in rx.internal.util
- InternalObservableUtils.ObjectEqualsFunc2 - Class in rx.internal.util
- InternalObservableUtils.PlusOneFunc2 - Class in rx.internal.util
- InternalObservableUtils.PlusOneLongFunc2 - Class in rx.internal.util
- InternalObservableUtils.RepeatNotificationDematerializer - Class in rx.internal.util
- InternalObservableUtils.ReplaySupplierBuffer<T> - Class in rx.internal.util
- InternalObservableUtils.ReplaySupplierBufferTime<T> - Class in rx.internal.util
- InternalObservableUtils.ReplaySupplierNoParams<T> - Class in rx.internal.util
- InternalObservableUtils.ReplaySupplierTime<T> - Class in rx.internal.util
- InternalObservableUtils.RetryNotificationDematerializer - Class in rx.internal.util
- InternalObservableUtils.ReturnsVoidFunc1 - Class in rx.internal.util
- InternalObservableUtils.SelectorAndObserveOn<T,R> - Class in rx.internal.util
- InternalObservableUtils.ToArrayFunc1 - Class in rx.internal.util
- internalOnCompleted() - Method in class rx.subjects.TestSubject
- internalOnError(Throwable) - Method in class rx.subjects.TestSubject
- internalOnNext(T) - Method in class rx.subjects.TestSubject
- interval(long, long, TimeUnit) - Static method in class rx.Observable
-
Returns an Observable that emits a
0L
after theinitialDelay
and ever increasing numbers after eachperiod
of time thereafter. - interval(long, long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits a
0L
after theinitialDelay
and ever increasing numbers after eachperiod
of time thereafter, on a specifiedScheduler
. - interval(long, TimeUnit) - Static method in class rx.Observable
-
Returns an Observable that emits a sequential number every specified interval of time.
- interval(long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits a sequential number every specified interval of time, on a specified Scheduler.
- intervalInMilliseconds - Variable in class rx.schedulers.TimeInterval
- io() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
Scheduler
intended for IO-bound work. - ioScheduler - Variable in class rx.schedulers.Schedulers
- is - Variable in class rx.internal.operators.OnSubscribeFromIterable
- IS_ANDROID - Static variable in class rx.internal.util.PlatformDependent
- IS_EMPTY - Static variable in enum rx.internal.util.InternalObservableUtils
- isAndroid() - Static method in class rx.internal.util.PlatformDependent
-
Returns
true
if and only if the current platform is Android. - isComplete() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- isComplete() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- isComplete() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- isComplete() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- isCompleted(Object) - Method in class rx.internal.operators.NotificationLite
-
Indicates whether or not the lite notification represents an
onCompleted
event. - isCompleted(Object) - Method in class rx.internal.util.RxRingBuffer
- isConnected - Variable in class rx.internal.operators.CachedObservable.CacheState
-
Set to true after connection.
- isConnected() - Method in class rx.internal.operators.CachedObservable
-
Check if this cached observable is connected to its source.
- isEmpty() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
-
- isEmpty() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- isEmpty() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- isEmpty() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- isEmpty() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- isEmpty() - Method in class rx.internal.util.OpenHashSet
- isEmpty() - Method in class rx.internal.util.RxRingBuffer
- isEmpty() - Method in class rx.internal.util.SynchronizedQueue
- isEmpty() - Method in class rx.internal.util.unsafe.BaseLinkedQueue
-
- isEmpty() - Method in interface rx.internal.util.unsafe.MessagePassingQueue
-
This method's accuracy is subject to concurrent modifications happening as the observation is carried out.
- isEmpty() - Method in class rx.internal.util.unsafe.MpmcArrayQueue
- isEmpty() - Method in class rx.internal.util.unsafe.SpmcArrayQueue
- isEmpty() - Method in class rx.internal.util.unsafe.SpscArrayQueue
- isEmpty() - Method in class rx.Observable
-
Returns an Observable that emits
true
if the source Observable is empty, otherwisefalse
. - isEmpty() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- isEmpty() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- isEmpty() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- isEmpty() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- isError(Object) - Method in class rx.internal.operators.NotificationLite
-
Indicates whether or not the lite notification represents an
onError
event. - isError(Object) - Method in class rx.internal.util.RxRingBuffer
- isInstanceOf(Class<?>) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns a Func1 that checks if its argument is an instance of the supplied class.
- IsInstanceOfFunc1(Class<?>) - Constructor for class rx.internal.util.InternalObservableUtils.IsInstanceOfFunc1
- isLockdown() - Static method in class rx.plugins.RxJavaHooks
-
Returns true if the hooks can no longer be changed.
- isNext(Object) - Method in class rx.internal.operators.NotificationLite
-
Indicates whether or not the lite notification represents an
onNext
event. - isNextConsumed - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- isNonEmpty - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- isNull(Object) - Method in class rx.internal.operators.NotificationLite
-
Indicates whether or not the lite notification represents a wrapped
null
onNext
event. - isOnCompleted() - Method in class rx.Notification
-
Indicates whether this notification represents an
onCompleted
event. - isOnError() - Method in class rx.Notification
-
Indicates whether this notification represents an
onError
event. - isOnNext() - Method in class rx.Notification
-
Indicates whether this notification represents an
onNext
event. - isPowerOfTwo(int) - Static method in class rx.internal.util.unsafe.Pow2
-
Is this value a power of two.
- isSelected() - Method in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- isTerminated() - Method in class rx.internal.util.BackpressureDrainManager
-
Checks if a terminal state has been reached.
- isTerminated() - Method in class rx.subjects.ReplaySubject.ReplayState
- isTerminated(Throwable) - Static method in enum rx.internal.util.ExceptionsUtils
-
Returns true if the value is the terminated Throwable instance.
- isTerminated(AtomicReference<Throwable>) - Static method in enum rx.internal.util.ExceptionsUtils
-
Checks if the given field holds the terminated Throwable instance.
- isUnsafeAvailable() - Static method in class rx.internal.util.unsafe.UnsafeAccess
- isUnsubscribed - Variable in class rx.internal.schedulers.NewThreadWorker
- isUnsubscribed - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- isUnsubscribed - Variable in class rx.subscriptions.MultipleAssignmentSubscription.State
- isUnsubscribed - Variable in class rx.subscriptions.RefCountSubscription.State
- isUnsubscribed - Variable in class rx.subscriptions.SerialSubscription.State
- isUnsubscribed() - Method in class rx.internal.operators.CachedObservable.ReplayProducer
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeDetach.DetachProducer
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeFromAsync.CancellableSubscription
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribePublishMulticast
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
- isUnsubscribed() - Method in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- isUnsubscribed() - Method in class rx.internal.operators.OperatorGroupBy.State
- isUnsubscribed() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- isUnsubscribed() - Method in class rx.internal.operators.OperatorPublish.InnerProducer
- isUnsubscribed() - Method in class rx.internal.operators.OperatorReplay.InnerProducer
- isUnsubscribed() - Method in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- isUnsubscribed() - Method in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- isUnsubscribed() - Method in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- isUnsubscribed() - Method in class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- isUnsubscribed() - Method in class rx.internal.schedulers.NewThreadWorker
- isUnsubscribed() - Method in class rx.internal.schedulers.ScheduledAction.FutureCompleter
- isUnsubscribed() - Method in class rx.internal.schedulers.ScheduledAction
- isUnsubscribed() - Method in class rx.internal.schedulers.ScheduledAction.Remover
- isUnsubscribed() - Method in class rx.internal.schedulers.ScheduledAction.Remover2
- isUnsubscribed() - Method in class rx.internal.schedulers.SchedulerWhen
- isUnsubscribed() - Method in class rx.internal.schedulers.SchedulerWhen.ScheduledAction
- isUnsubscribed() - Method in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- isUnsubscribed() - Method in class rx.internal.util.IndexedRingBuffer
- isUnsubscribed() - Method in class rx.internal.util.RxRingBuffer
- isUnsubscribed() - Method in class rx.internal.util.SubscriptionList
- isUnsubscribed() - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- isUnsubscribed() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- isUnsubscribed() - Method in class rx.observers.AsyncCompletableSubscriber
- isUnsubscribed() - Method in class rx.observers.AsyncCompletableSubscriber.Unsubscribed
- isUnsubscribed() - Method in class rx.observers.SafeCompletableSubscriber
- isUnsubscribed() - Method in class rx.schedulers.TestScheduler.InnerTestScheduler
- isUnsubscribed() - Method in class rx.SingleSubscriber
-
Indicates whether this Subscriber has unsubscribed from its list of subscriptions.
- isUnsubscribed() - Method in class rx.subjects.ReplaySubject.ReplayProducer
- isUnsubscribed() - Method in class rx.subjects.UnicastSubject.State
- isUnsubscribed() - Method in class rx.Subscriber
-
Indicates whether this Subscriber has unsubscribed from its list of subscriptions.
- isUnsubscribed() - Method in interface rx.Subscription
-
Indicates whether this
Subscription
is currently unsubscribed. - isUnsubscribed() - Method in class rx.subscriptions.BooleanSubscription
- isUnsubscribed() - Method in class rx.subscriptions.CompositeSubscription
- isUnsubscribed() - Method in class rx.subscriptions.MultipleAssignmentSubscription
- isUnsubscribed() - Method in class rx.subscriptions.RefCountSubscription.InnerSubscription
- isUnsubscribed() - Method in class rx.subscriptions.RefCountSubscription
- isUnsubscribed() - Method in class rx.subscriptions.SerialSubscription
- isUnsubscribed() - Method in class rx.subscriptions.Subscriptions.FutureSubscription
- isUnsubscribed() - Method in class rx.subscriptions.Subscriptions.Unsubscribed
- isValueNull() - Method in exception rx.exceptions.OnErrorThrowable
-
Indicates whether or not there is a value associated with this
OnErrorThrowable
- it - Variable in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- itemDelay - Variable in class rx.internal.operators.OperatorDelayWithSelector
- items - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- items - Variable in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- iterable - Variable in class rx.internal.operators.OperatorZipIterable
- IterableProducer(Subscriber<? super T>, Iterator<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- iterableToArray(Iterable<? extends Single<? extends T>>) - Static method in class rx.Single
-
FOR INTERNAL USE ONLY.
- iterator() - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- iterator() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- iterator() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- iterator() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- iterator() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- iterator() - Method in class rx.internal.util.SynchronizedQueue
- iterator() - Method in class rx.internal.util.unsafe.BaseLinkedQueue
- iterator() - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- iterator() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
J
- join(Observable<TRight>, Func1<T, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<T, TRight, R>) - Method in class rx.Observable
-
Correlates the items emitted by two Observables based on overlapping durations.
- just(T) - Static method in class rx.Observable
-
Returns an Observable that emits a single item and then completes.
- just(T) - Static method in class rx.Single
-
Returns a
Single
that emits a specified item. - just(T, T) - Static method in class rx.Observable
-
Converts two items into an Observable that emits those items.
- just(T, T, T) - Static method in class rx.Observable
-
Converts three items into an Observable that emits those items.
- just(T, T, T, T) - Static method in class rx.Observable
-
Converts four items into an Observable that emits those items.
- just(T, T, T, T, T) - Static method in class rx.Observable
-
Converts five items into an Observable that emits those items.
- just(T, T, T, T, T, T) - Static method in class rx.Observable
-
Converts six items into an Observable that emits those items.
- just(T, T, T, T, T, T, T) - Static method in class rx.Observable
-
Converts seven items into an Observable that emits those items.
- just(T, T, T, T, T, T, T, T) - Static method in class rx.Observable
-
Converts eight items into an Observable that emits those items.
- just(T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
-
Converts nine items into an Observable that emits those items.
- just(T, T, T, T, T, T, T, T, T, T) - Static method in class rx.Observable
-
Converts ten items into an Observable that emits those items.
- JustOnSubscribe(T) - Constructor for class rx.internal.util.ScalarSynchronousObservable.JustOnSubscribe
K
- KEEP_ALIVE_TIME - Static variable in class rx.internal.schedulers.CachedThreadScheduler
- KEEP_ALIVE_UNIT - Static variable in class rx.internal.schedulers.CachedThreadScheduler
- keepAliveTime - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- key - Variable in class rx.internal.operators.OperatorGroupBy.State
- key - Variable in class rx.observables.GroupedObservable
- KEY_MAX_THREADS - Static variable in class rx.internal.schedulers.EventLoopsScheduler
-
Key to setting the maximum number of computation scheduler threads.
- keys - Variable in class rx.internal.util.OpenHashSet
- keySelector - Variable in class rx.internal.operators.OperatorDistinct
- keySelector - Variable in class rx.internal.operators.OperatorDistinctUntilChanged
- keySelector - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- keySelector - Variable in class rx.internal.operators.OperatorGroupBy
- keySelector - Variable in class rx.internal.operators.OperatorToMap
- keySelector - Variable in class rx.internal.operators.OperatorToMultimap
- kind - Variable in class rx.Notification
- kind(Object) - Method in class rx.internal.operators.NotificationLite
-
Indicates which variety a particular lite notification is.
- Kind() - Constructor for enum rx.Notification.Kind
L
- last() - Method in class rx.Observable
-
Returns an Observable that emits the last item emitted by the source Observable or notifies observers of a
NoSuchElementException
if the source Observable is empty. - last() - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this
BlockingObservable
, or throwsNoSuchElementException
if thisBlockingObservable
emits no items. - last() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- last() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- last() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- last() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- last(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a given condition, or notifies of a
NoSuchElementException
if no such items are emitted. - last(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this
BlockingObservable
that matches a predicate, or throwsNoSuchElementException
if it emits no such items. - lastId - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Which was the last InnerSubscriber that emitted? Accessed if emitting == true.
- lastIndex - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
What was its index in the innerSubscribers array? Accessed if emitting == true.
- lastOrDefault(T) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable, or a default item if the source Observable completes without emitting any items.
- lastOrDefault(T) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this
BlockingObservable
, or a default value if it emits no items. - lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable that satisfies a specified condition, or a default item if no such item is emitted by the source Observable.
- lastOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
Returns the last item emitted by this
BlockingObservable
that matches a predicate, or a default value if it emits no such items. - lastSeenThread - Variable in class rx.observers.TestSubscriber
- lastValue - Variable in class rx.subjects.AsyncSubject
- latch - Variable in class rx.observers.TestSubscriber
- latest - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- latest - Variable in class rx.subjects.SubjectSubscriptionManager
-
Stores the latest value or the terminal value for some Subjects.
- latest() - Method in class rx.observables.BlockingObservable
-
Returns an
Iterable
that returns the latest item emitted by thisBlockingObservable
, waiting if necessary for one to become available. - latest(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorLatest
-
Returns an
Iterable
that blocks until or unless theObservable
emits an item that has not been returned by theIterable
, then returns that item - LATEST - rx.AsyncEmitter.BackpressureMode
- LatestAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- LatestCoordinator(Subscriber<? super R>, FuncN<? extends R>, int, int, boolean) - Constructor for class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- LatestEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- latestHead() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- LatestObserverIterator() - Constructor for class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- LatestSubscriber(OperatorOnBackpressureLatest.LatestEmitter<T>) - Constructor for class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- leaveTransform(Object) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Override this to unwrap the transformed value into a NotificationLite object.
- leaveTransform(Object) - Method in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- left - Variable in class rx.internal.operators.OnSubscribeGroupJoin
- left - Variable in class rx.internal.operators.OnSubscribeJoin
- leftDone - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- leftDone - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- leftDuration - Variable in class rx.internal.operators.OnSubscribeGroupJoin
- LeftDurationObserver(int) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- leftDurationSelector - Variable in class rx.internal.operators.OnSubscribeJoin
- LeftDurationSubscriber(int) - Constructor for class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- leftId - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- leftIds - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- leftMap - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- leftMap - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- LeftObserver() - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftObserver
- LeftSubscriber() - Constructor for class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber
- lift(Completable.CompletableOperator) - Method in class rx.Completable
-
Lifts a CompletableSubscriber transformation into the chain of Completables.
- lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Observable
-
This method requires advanced knowledge about building operators; please consider other standard composition methods first; Lifts a function to the current Observable and returns a new Observable that when subscribed to will pass the values of the current Observable through the Operator function.
- lift(Observable.Operator<? extends R, ? super T>) - Method in class rx.Single
-
Lifts a function to the current Single and returns a new Single that when subscribed to will pass the values of the current Single through the Operator function.
- limit - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- limit - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
-
The emission threshold that should trigger a replenishing request.
- limit - Variable in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- limit - Variable in class rx.internal.operators.OperatorReplay.SizeBoundReplayBuffer
- limit - Variable in class rx.internal.operators.OperatorTake
- limit - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- limit - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- limit(int) - Method in class rx.Observable
-
Returns an Observable that emits only the first
count
items emitted by the source Observable. - LIMIT - Static variable in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- LIMIT - Static variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- LinkedArrayList - Class in rx.internal.util
-
A list implementation which combines an ArrayList with a LinkedList to avoid copying values when the capacity needs to be increased.
- LinkedArrayList(int) - Constructor for class rx.internal.util.LinkedArrayList
-
Constructor with the capacity hint of each array segment.
- LinkedQueueNode<E> - Class in rx.internal.util.atomic
- LinkedQueueNode() - Constructor for class rx.internal.util.atomic.LinkedQueueNode
- LinkedQueueNode(E) - Constructor for class rx.internal.util.atomic.LinkedQueueNode
- list - Variable in class rx.internal.util.SynchronizedQueue
- loadFactor - Variable in class rx.internal.util.OpenHashSet
- LOCAL_ONCOMPLETED - Static variable in class rx.internal.operators.OperatorSequenceEqual
-
NotificationLite doesn't work as zip uses it.
- lock - Variable in class rx.internal.operators.OnSubscribeRefCount
-
Use this lock for every subscription and disconnect action.
- lock() - Method in class rx.exceptions.CompositeException.PrintStreamOrWriter
-
Returns the object to be locked when using this StreamOrWriter
- lock() - Method in class rx.exceptions.CompositeException.WrappedPrintStream
- lock() - Method in class rx.exceptions.CompositeException.WrappedPrintWriter
- lockdown - Static variable in class rx.plugins.RxJavaHooks
-
Prevents changing the hook callbacks when set to true.
- lockdown() - Static method in class rx.plugins.RxJavaHooks
-
Prevents changing the hooks.
- LONG_COUNTER - Static variable in enum rx.internal.util.InternalObservableUtils
-
A BiFunction that expects a long as its first parameter and returns +1.
- lookAheadStep - Variable in class rx.internal.util.atomic.SpscAtomicArrayQueue
- lookAheadStep - Variable in class rx.internal.util.unsafe.SpscArrayQueueColdField
- lpConsumerIndex() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lpConsumerIndex() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lpConsumerNode() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- lpConsumerNode() - Method in class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- lpElement(int) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- lpElement(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain load (no ordering/fences) of an element from a given offset.
- lpElement(E[], long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain load (no ordering/fences) of an element from a given offset.
- lpElement(AtomicReferenceArray<E>, int) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- lpProducerIndex() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lpProducerIndex() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lpProducerNode() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- lpProducerNode() - Method in class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- lpValue() - Method in class rx.internal.util.atomic.LinkedQueueNode
- lvConsumerIndex() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- lvConsumerIndex() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lvConsumerIndex() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lvConsumerIndex() - Method in class rx.internal.util.unsafe.MpmcArrayQueueConsumerField
- lvConsumerIndex() - Method in class rx.internal.util.unsafe.SpmcArrayQueueConsumerField
- lvConsumerIndex() - Method in class rx.internal.util.unsafe.SpscArrayQueue
- lvConsumerIndex() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- lvConsumerNode() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- lvConsumerNode() - Method in class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- lvElement(int) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- lvElement(long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A volatile load (load + LoadLoad barrier) of an element from a given offset.
- lvElement(E[], long) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A volatile load (load + LoadLoad barrier) of an element from a given offset.
- lvElement(E[], long) - Static method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- lvElement(AtomicReferenceArray<E>, int) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- lvElement(AtomicReferenceArray<Object>, int) - Static method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lvElement(AtomicReferenceArray<Object>, int) - Static method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lvNext() - Method in class rx.internal.util.atomic.LinkedQueueNode
- lvNext(E[]) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- lvNext(AtomicReferenceArray<Object>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lvNext(AtomicReferenceArray<Object>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lvProducerIndex() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- lvProducerIndex() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- lvProducerIndex() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- lvProducerIndex() - Method in class rx.internal.util.unsafe.MpmcArrayQueueProducerField
- lvProducerIndex() - Method in class rx.internal.util.unsafe.SpmcArrayQueueProducerField
- lvProducerIndex() - Method in class rx.internal.util.unsafe.SpscArrayQueue
- lvProducerIndex() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- lvProducerIndexCache() - Method in class rx.internal.util.unsafe.SpmcArrayQueueProducerIndexCacheField
- lvProducerNode() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- lvProducerNode() - Method in class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- lvSequence(long[], long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
M
- main - Variable in class rx.internal.operators.OnSubscribeDelaySubscriptionOther
- main - Variable in class rx.internal.operators.OperatorWithLatestFromMany
- main - Variable in class rx.internal.operators.SingleOnSubscribeDelaySubscriptionOther
- mainDone - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- makeRequest(long, long) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- manager - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- manager() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- manageRequests(OperatorReplay.InnerProducer<T>) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Coordinates the request amounts of various child Subscribers.
- map(Func1<? super T, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that applies a specified function to each item emitted by the source Observable and emits the results of these function applications.
- map(Func1<? super T, ? extends R>) - Method in class rx.Single
-
Returns a Single that applies a specified function to the item emitted by the source Single and emits the result of this function application.
- mapFactory - Variable in class rx.internal.operators.OperatorGroupBy
- mapFactory - Variable in class rx.internal.operators.OperatorToMap
- mapFactory - Variable in class rx.internal.operators.OperatorToMultimap
- mapNotification(Func1<? super T, ? extends R>, Func1<? super Throwable, ? extends R>, Func0<? extends R>) - Method in class rx.Observable
- MapNotificationSubscriber(Subscriber<? super R>, Func1<? super T, ? extends R>, Func1<? super Throwable, ? extends R>, Func0<? extends R>) - Constructor for class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- MapPairSubscriber(Subscriber<? super Observable<? extends R>>, Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Constructor for class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- mapper - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- mapper - Variable in class rx.internal.operators.OnSubscribeConcatMap
- mapper - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- mapper - Variable in class rx.internal.operators.OnSubscribeFlattenIterable
- mapper - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable
- mapper - Variable in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- mapper - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- mapper - Variable in class rx.internal.operators.OperatorEagerConcatMap
- mapper - Variable in class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- MapSubscriber(SingleSubscriber<? super R>, Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- MapSubscriber(Subscriber<? super R>, Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.OnSubscribeMap.MapSubscriber
- mask - Variable in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- mask - Variable in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- mask - Variable in class rx.internal.util.OpenHashSet
- mask - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- materialize() - Method in class rx.Observable
-
Returns an Observable that represents all of the emissions and notifications from the source Observable into emissions marked with their original types within
Notification
objects. - materializeLite(Observable<T>) - Static method in class rx.internal.operators.OperatorSequenceEqual
- MAX_DEPTH - Static variable in class rx.exceptions.Exceptions
- MAX_LOOK_AHEAD_STEP - Static variable in class rx.internal.util.atomic.SpscAtomicArrayQueue
- MAX_LOOK_AHEAD_STEP - Static variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- MAX_LOOK_AHEAD_STEP - Static variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- MAX_LOOK_AHEAD_STEP - Static variable in class rx.internal.util.unsafe.SpscArrayQueueColdField
- MAX_LOOK_AHEAD_STEP - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- MAX_THREADS - Static variable in class rx.internal.schedulers.EventLoopsScheduler
-
The maximum number of computation scheduler threads.
- maxAgeInMillis - Variable in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- maxAgeMillis - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- maxChildRequested - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Contains the maximum element index the child Subscribers requested so far.
- maxConcurrency - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- maxConcurrency - Variable in class rx.internal.operators.CompletableOnSubscribeMerge
- maxConcurrent - Variable in class rx.internal.operators.OperatorEagerConcatMap
- maxConcurrent - Variable in class rx.internal.operators.OperatorMerge
- maxConcurrent - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- maxSize - Variable in class rx.internal.util.ObjectPool
- maxSize - Variable in class rx.internal.util.OpenHashSet
- maxUpstreamRequested - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Counts the outstanding upstream requests until the producer arrives.
- mayAttemptDrop() - Method in class rx.BackpressureOverflow.DropLatest
- mayAttemptDrop() - Method in class rx.BackpressureOverflow.DropOldest
- mayAttemptDrop() - Method in class rx.BackpressureOverflow.Error
- mayAttemptDrop() - Method in interface rx.BackpressureOverflow.Strategy
-
Whether the Backpressure manager should attempt to drop the oldest item, or simply drop the item currently causing backpressure.
- merge(Iterable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
- merge(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Flattens an Iterable of Observables into one Observable, without any transformation.
- merge(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Flattens an Iterable of Observables into one Observable, without any transformation, while limiting the number of concurrent subscriptions to these Observables.
- merge(Completable...) - Static method in class rx.Completable
-
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
- merge(Observable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable instance that subscribes to all sources at once and completes only when all source Completables complete or one of them emits an error.
- merge(Observable<? extends Completable>, int) - Static method in class rx.Completable
-
Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables complete or one of them emits an error.
- merge(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation.
- merge(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Flattens an Observable that emits Observables into a single Observable that emits the items emitted by those Observables, without any transformation, while limiting the maximum number of concurrent subscriptions to these Observables.
- merge(Observable<? extends T>[]) - Static method in class rx.Observable
-
Flattens an Array of Observables into one Observable, without any transformation.
- merge(Observable<? extends T>[], int) - Static method in class rx.Observable
-
Flattens an Array of Observables into one Observable, without any transformation, while limiting the number of concurrent subscriptions to these Observables.
- merge(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens two Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens three Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens four Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens five Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens six Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens seven Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens eight Observables into a single Observable, without any transformation.
- merge(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens nine Observables into a single Observable, without any transformation.
- merge(Single<? extends Single<? extends T>>) - Static method in class rx.Single
-
Flattens a
Single
that emits aSingle
into a singleSingle
that emits the item emitted by the nestedSingle
, without any transformation. - merge(Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens two Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens three Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens four Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens five Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens six Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens seven Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens eight Singles into a single Observable, without any transformation.
- merge(Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>, Single<? extends T>) - Static method in class rx.Single
-
Flattens nine Singles into a single Observable, without any transformation.
- merge0(Observable<? extends Completable>, int, boolean) - Static method in class rx.Completable
-
Returns a Completable instance that keeps subscriptions to a limited number of sources at once and completes only when all source Completables terminate in one way or another, combining any exceptions thrown by either the sources Observable or the inner Completable instances.
- mergeDelayError(Iterable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
- mergeDelayError(Iterable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Flattens an Iterable of Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Iterable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Flattens an Iterable of Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Observables.
- mergeDelayError(Completable...) - Static method in class rx.Completable
-
Returns a Completable that subscribes to all Completables in the source array and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
- mergeDelayError(Observable<? extends Completable>) - Static method in class rx.Completable
-
Returns a Completable that subscribes to all Completables in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
- mergeDelayError(Observable<? extends Completable>, int) - Static method in class rx.Completable
-
Returns a Completable that subscribes to a limited number of inner Completables at once in the source sequence and delays any error emitted by either the sources observable or any of the inner Completables until all of them terminate in a way or another.
- mergeDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends Observable<? extends T>>, int) - Static method in class rx.Observable
-
Flattens an Observable that emits Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them, while limiting the number of concurrent subscriptions to these Observables.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens two Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from each of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens three Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens four Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens five Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens six Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens seven Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens eight Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- mergeDelayError(Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Flattens nine Observables into one Observable, in a way that allows an Observer to receive all successfully emitted items from all of the source Observables without being interrupted by an error notification from one of them.
- MergeProducer(OperatorMerge.MergeSubscriber<T>) - Constructor for class rx.internal.operators.OperatorMerge.MergeProducer
- merger - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- MergeSubscriber(Subscriber<? super T>, boolean, int) - Constructor for class rx.internal.operators.OperatorMerge.MergeSubscriber
- mergeWith(Completable) - Method in class rx.Completable
-
Returns a Completable which subscribes to this and the other Completable and completes when both of them complete or one emits an error.
- mergeWith(Observable<? extends T>) - Method in class rx.Observable
-
Flattens this and another Observable into a single Observable, without any transformation.
- mergeWith(Single<? extends T>) - Method in class rx.Single
-
Flattens this and another Single into a single Observable, without any transformation.
- message - Variable in exception rx.exceptions.CompositeException
- MESSAGE - Static variable in exception rx.exceptions.CompositeException.CompositeExceptionCausalChain
- MessagePassingQueue<M> - Interface in rx.internal.util.unsafe
-
This is a tagging interface for the queues in this library which implement a subset of the
Queue
interface sufficient for concurrent message passing.
Message passing queues offer happens before semantics to messages passed through, namely that writes made by the producer before offering the message are visible to the consuming thread after the message has been polled out of the queue. - minSize - Variable in class rx.internal.util.ObjectPool
- missed - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
Indicates there were some state changes/replay attempts; guarded by this.
- missed - Variable in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- missed - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Guarded by this.
- missed - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
-
Guarded by this.
- missed - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Guarded by this.
- missed - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
Indicates a missed update.
- missed - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Guarded by this.
- missed - Variable in class rx.internal.operators.OperatorScan.InitialProducer
-
Missed a terminal event.
- missed - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- missed - Variable in class rx.subjects.UnicastSubject.State
-
Emitter loop: missed emission indicator.
- missedProduced - Variable in class rx.internal.producers.ProducerArbiter
- missedProducer - Variable in class rx.internal.producers.ProducerArbiter
- missedProducer - Variable in class rx.internal.producers.ProducerObserverArbiter
- missedRequested - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- missedRequested - Variable in class rx.internal.operators.OperatorScan.InitialProducer
-
Missed a request.
- missedRequested - Variable in class rx.internal.producers.ProducerArbiter
- missedRequested - Variable in class rx.internal.producers.ProducerObserverArbiter
- missedTerminal - Variable in class rx.internal.producers.ProducerObserverArbiter
- MISSING - Static variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
-
Indicates the particular source hasn't emitted any value yet.
- MissingBackpressureException - Exception in rx.exceptions
-
Represents an exception that indicates that a Subscriber or operator attempted to apply reactive pull backpressure to an Observable that does not implement it.
- MissingBackpressureException() - Constructor for exception rx.exceptions.MissingBackpressureException
-
Constructs the exception without any custom message.
- MissingBackpressureException(String) - Constructor for exception rx.exceptions.MissingBackpressureException
-
Constructs the exception with the given customized message.
- mix(int) - Static method in class rx.internal.util.OpenHashSet
- mostRecent(Observable<? extends T>, T) - Static method in class rx.internal.operators.BlockingOperatorMostRecent
-
Returns an
Iterable
that always returns the item most recently emitted by theObservable
. - mostRecent(T) - Method in class rx.observables.BlockingObservable
-
Returns an
Iterable
that always returns the item most recently emitted by thisBlockingObservable
. - MostRecentObserver(T) - Constructor for class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- moveToNext() - Method in class rx.internal.operators.BlockingOperatorNext.NextIterator
- MpmcArrayQueue<E> - Class in rx.internal.util.unsafe
-
A Multi-Producer-Multi-Consumer queue based on a
ConcurrentCircularArrayQueue
. - MpmcArrayQueue(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueue
- MpmcArrayQueueConsumerField<E> - Class in rx.internal.util.unsafe
- MpmcArrayQueueConsumerField(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueueConsumerField
- MpmcArrayQueueL1Pad<E> - Class in rx.internal.util.unsafe
- MpmcArrayQueueL1Pad(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- MpmcArrayQueueL2Pad<E> - Class in rx.internal.util.unsafe
- MpmcArrayQueueL2Pad(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- MpmcArrayQueueProducerField<E> - Class in rx.internal.util.unsafe
- MpmcArrayQueueProducerField(int) - Constructor for class rx.internal.util.unsafe.MpmcArrayQueueProducerField
- MpscLinkedAtomicQueue<E> - Class in rx.internal.util.atomic
-
This is a direct Java port of the MPSC algorithm as presented on 1024 Cores by D.
- MpscLinkedAtomicQueue() - Constructor for class rx.internal.util.atomic.MpscLinkedAtomicQueue
- MpscLinkedQueue<E> - Class in rx.internal.util.unsafe
-
This is a direct Java port of the MPSC algorithm as presented on 1024 Cores by D.
- MpscLinkedQueue() - Constructor for class rx.internal.util.unsafe.MpscLinkedQueue
- multicastSelector(Func0<? extends ConnectableObservable<U>>, Func1<? super Observable<U>, ? extends Observable<R>>) - Static method in class rx.internal.operators.OperatorReplay
-
Given a connectable observable factory, it multicasts over the generated ConnectableObservable via a selector function.
- MultipleAssignmentSubscription - Class in rx.subscriptions
-
Subscription that can be checked for status such as in a loop inside an
Observable
to exit the loop if unsubscribed. - MultipleAssignmentSubscription() - Constructor for class rx.subscriptions.MultipleAssignmentSubscription
- MultipleAssignmentSubscription.State - Class in rx.subscriptions
- multiplyCap(long, long) - Static method in class rx.internal.operators.BackpressureUtils
-
Multiplies two positive longs and caps the result at Long.MAX_VALUE.
N
- n - Variable in class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- nest() - Method in class rx.Observable
-
Converts the source
Observable<T>
into anObservable<Observable<T>>
that emits the source Observable as its single emission. - nest() - Method in class rx.Single
-
INTERNAL: Used with lift and operators.
- never() - Static method in class rx.Completable
-
Returns a Completable that never calls onError or onComplete.
- never() - Static method in class rx.Observable
-
Returns an Observable that never sends any items or notifications to an
Observer
. - NEVER - Static variable in class rx.Completable
-
Single instance of a never Completable.
- NEVER - Static variable in enum rx.internal.operators.NeverObservableHolder
-
The singleton instance.
- NeverObservableHolder - Enum in rx.internal.operators
-
Holds a singleton instance of a never Observable which is stateless doesn't call any of the Subscriber's methods.
- NeverObservableHolder() - Constructor for enum rx.internal.operators.NeverObservableHolder
- newBufferPeek(E[], long, long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- newBufferPeek(AtomicReferenceArray<Object>, long, int) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- newBufferPeek(AtomicReferenceArray<Object>, long, int) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- newBufferPoll(E[], long, long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- newBufferPoll(AtomicReferenceArray<Object>, long, int) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- newBufferPoll(AtomicReferenceArray<Object>, long, int) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- newThread() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
Scheduler
that creates a newThread
for each unit of work. - newThread(Runnable) - Method in class rx.internal.util.RxThreadFactory
- newThreadScheduler - Variable in class rx.schedulers.Schedulers
- NewThreadScheduler - Class in rx.internal.schedulers
-
Schedules work on a new thread.
- NewThreadScheduler - Class in rx.schedulers
-
Deprecated.This type was never publicly instantiable. Use
Schedulers.newThread()
. - NewThreadScheduler() - Constructor for class rx.schedulers.NewThreadScheduler
-
Deprecated.
- NewThreadScheduler(ThreadFactory) - Constructor for class rx.internal.schedulers.NewThreadScheduler
- NewThreadWorker - Class in rx.internal.schedulers
- NewThreadWorker(ThreadFactory) - Constructor for class rx.internal.schedulers.NewThreadWorker
- next - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- next - Variable in class rx.internal.util.IndexedRingBuffer.ElementSection
- next - Variable in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- next - Variable in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- next() - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- next() - Method in class rx.internal.operators.BlockingOperatorNext.NextIterator
- next() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- next() - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- next() - Method in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- next() - Method in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- next() - Method in class rx.internal.operators.OperatorWindowWithTime.State
- next() - Method in class rx.observables.BlockingObservable
-
Returns an
Iterable
that blocks until thisBlockingObservable
emits another item, then returns that item. - next(Object) - Method in class rx.subjects.SubjectSubscriptionManager
-
Set a new latest NotificationLite value and return the active observers.
- next(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorNext
-
Returns an
Iterable
that blocks until theObservable
emits another item, then returns that item. - next(S, long, Observer<Observable<? extends T>>) - Method in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- next(S, long, Observer<Observable<? extends T>>) - Method in class rx.observables.AsyncOnSubscribe
-
Called to produce data to the downstream subscribers.
- next(S, Observer<? super T>) - Method in class rx.observables.SyncOnSubscribe
-
Called to produce data to the downstream subscribers.
- next(S, Observer<? super T>) - Method in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- next(T) - Method in class rx.internal.operators.NotificationLite
-
Creates a lite
onNext
notification for the value passed in without doing any allocation. - next(T) - Method in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
- next(T) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- next(T) - Method in interface rx.internal.operators.OperatorReplay.ReplayBuffer
-
Adds a regular value to the buffer.
- next(T) - Method in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- next(T) - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- next(T) - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- next(T) - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- next(T) - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- NEXT_SUBJECT - Static variable in class rx.internal.operators.OperatorWindowWithObservable
-
Indicate the current subject should complete and a new subject be emitted.
- NEXT_SUBJECT - Static variable in class rx.internal.operators.OperatorWindowWithObservableFactory
-
Indicate the current subject should complete and a new subject be emitted.
- NEXT_SUBJECT - Static variable in class rx.internal.operators.OperatorWindowWithTime
-
Indicate the current subject should complete and a new subject be emitted.
- nextIteration(long) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- nextIteration(SyncOnSubscribe<S, T>) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- NextIterator(Observable<? extends T>, BlockingOperatorNext.NextObserver<T>) - Constructor for class rx.internal.operators.BlockingOperatorNext.NextIterator
- NextObserver() - Constructor for class rx.internal.operators.BlockingOperatorNext.NextObserver
- nextWindow() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- nl - Variable in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- nl - Variable in class rx.internal.operators.BufferUntilSubscriber.State
- nl - Variable in class rx.internal.operators.CachedObservable.CacheState
- nl - Variable in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- nl - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- nl - Variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- nl - Variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- nl - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- nl - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- nl - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
The notification-lite factory.
- nl - Variable in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- nl - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
The notification-lite factory.
- nl - Variable in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- nl - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- nl - Variable in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- nl - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- nl - Variable in class rx.observers.SerializedObserver
- nl - Variable in class rx.subjects.AsyncSubject
- nl - Variable in class rx.subjects.BehaviorSubject
- nl - Variable in class rx.subjects.PublishSubject
- nl - Variable in class rx.subjects.SubjectSubscriptionManager
-
The notification lite.
- nl - Variable in class rx.subjects.UnicastSubject.State
-
JCTools queues don't accept nulls.
- NL - Static variable in class rx.internal.operators.OperatorWindowWithObservable
-
For error and completion indication.
- NL - Static variable in class rx.internal.operators.OperatorWindowWithObservableFactory
-
For error and completion indication.
- NL - Static variable in class rx.internal.operators.OperatorWindowWithTime
-
For error and completion indication.
- NO_INITIAL_VALUE - Static variable in class rx.internal.operators.OperatorScan
- NO_OBSERVERS - Static variable in class rx.subjects.SubjectSubscriptionManager.State
- NO_REQUEST_HAS_VALUE - Static variable in class rx.internal.operators.DeferredScalarSubscriber
-
Value came first.
- NO_REQUEST_HAS_VALUE - Static variable in class rx.internal.producers.SingleDelayedProducer
- NO_REQUEST_NO_VALUE - Static variable in class rx.internal.operators.DeferredScalarSubscriber
-
Initial state.
- NO_REQUEST_NO_VALUE - Static variable in class rx.internal.producers.SingleDelayedProducer
- node - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
Stores the current replay node of the buffer to be used by buffer.drain().
- Node(Object, long) - Constructor for class rx.internal.operators.OperatorReplay.Node
- Node(T) - Constructor for class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer.Node
- NONE - rx.AsyncEmitter.BackpressureMode
- NONE - Static variable in class rx.internal.schedulers.CachedThreadScheduler
- NONE - Static variable in class rx.internal.schedulers.EventLoopsScheduler
-
This will indicate no pool is active.
- NONE - Static variable in class rx.internal.schedulers.GenericScheduledExecutorService
- NONE - Static variable in class rx.internal.util.RxThreadFactory
- NoneAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.NoneAsyncEmitter
- NoOverflowBaseAsyncEmitter(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter
- NormalScheduledEmission(Scheduler, T) - Constructor for class rx.internal.util.ScalarSynchronousSingle.NormalScheduledEmission
- NOT_REQUESTED - Static variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- NOT_REQUESTED - Static variable in class rx.internal.operators.OperatorPublish.InnerProducer
-
Indicates this child has not yet requested any value.
- NOT_SET - Static variable in class rx.Subscriber
- Notification<T> - Class in rx
-
An object representing a notification sent to an
Observable
. - Notification(Notification.Kind, T, Throwable) - Constructor for class rx.Notification
- Notification.Kind - Enum in rx
-
Specifies the kind of the notification: an element, an error or a completion notification.
- NotificationErrorExtractor() - Constructor for class rx.internal.util.InternalObservableUtils.NotificationErrorExtractor
- notificationHandler - Variable in class rx.internal.util.InternalObservableUtils.RepeatNotificationDematerializer
- notificationHandler - Variable in class rx.internal.util.InternalObservableUtils.RetryNotificationDematerializer
- NotificationLite<T> - Class in rx.internal.operators
-
For use in internal operators that need something like materialize and dematerialize wholly within the implementation of the operator but don't want to incur the allocation cost of actually creating
Notification
objects for everyonNext
andonCompleted
. - NotificationLite() - Constructor for class rx.internal.operators.NotificationLite
- NotificationLite.OnErrorSentinel - Class in rx.internal.operators
- notifications - Variable in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- notify - Variable in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- now() - Method in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- now() - Method in class rx.Scheduler
-
Gets the current time, in milliseconds, according to this Scheduler.
- now() - Method in class rx.Scheduler.Worker
-
Gets the current time, in milliseconds, according to this Scheduler.
- now() - Method in class rx.schedulers.TestScheduler.InnerTestScheduler
- now() - Method in class rx.schedulers.TestScheduler
- NULL_KEY - Static variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- NULL_PRODUCER - Static variable in class rx.internal.producers.ProducerArbiter
- NULL_PRODUCER - Static variable in class rx.internal.producers.ProducerObserverArbiter
- NULL_SENTINEL - Static variable in class rx.internal.producers.QueuedProducer
- NULL_SENTINEL - Static variable in class rx.internal.producers.QueuedValueProducer
- numberOfSubscribers - Variable in class rx.internal.operators.OnSubscribeAutoConnect
O
- o - Variable in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- o - Variable in class rx.observables.BlockingObservable
- OBJECT_EQUALS - Static variable in enum rx.internal.util.InternalObservableUtils
-
A bifunction comparing two objects via null-safe equals.
- ObjectEqualsFunc2() - Constructor for class rx.internal.util.InternalObservableUtils.ObjectEqualsFunc2
- ObjectPool<T> - Class in rx.internal.util
- ObjectPool() - Constructor for class rx.internal.util.ObjectPool
- ObjectPool(int, int, long) - Constructor for class rx.internal.util.ObjectPool
-
Creates the pool.
- observable - Variable in class rx.internal.operators.OnSubscribeSingle
- Observable<T> - Class in rx
-
The Observable class that implements the Reactive Pattern.
- Observable(Observable.OnSubscribe<T>) - Constructor for class rx.Observable
-
Creates an Observable with a Function to execute when it is subscribed to.
- Observable.OnSubscribe<T> - Interface in rx
-
Invoked when Observable.subscribe is called.
- Observable.OnSubscribeExtend<T> - Class in rx
-
Transforms a OnSubscribe.call() into an Observable.subscribe() call.
- Observable.Operator<R,T> - Interface in rx
-
Operator function for lifting into an Observable.
- Observable.Transformer<T,R> - Interface in rx
-
Function that receives the current Observable and should return another Observable, possibly with given element type, in exchange that will be subscribed to by the downstream operators and subscribers.
- observableExecutionHook - Variable in class rx.plugins.RxJavaPlugins
- observableFactory - Variable in class rx.internal.operators.OnSubscribeDefer
- observableFactory - Variable in class rx.internal.operators.OnSubscribeUsing
- observeOn(ConnectableObservable<T>, Scheduler) - Static method in class rx.internal.operators.OperatorReplay
-
Child Subscribers will observe the events of the ConnectableObservable on the specified scheduler.
- observeOn(Scheduler) - Method in class rx.Completable
-
Returns a Completable which emits the terminal events from the thread of the specified scheduler.
- observeOn(Scheduler) - Method in class rx.Observable
-
Modifies an Observable to perform its emissions and notifications on a specified
Scheduler
, asynchronously with a bounded buffer ofRxRingBuffer.SIZE
slots. - observeOn(Scheduler) - Method in class rx.Single
-
Modifies a Single to emit its item (or notify of its error) on a specified
Scheduler
, asynchronously. - observeOn(Scheduler, boolean) - Method in class rx.Observable
-
Modifies an Observable to perform its emissions and notifications on a specified
Scheduler
, asynchronously with a bounded buffer and optionally delays onError notifications. - observeOn(Scheduler, boolean, int) - Method in class rx.Observable
-
Modifies an Observable to perform its emissions and notifications on a specified
Scheduler
, asynchronously with a bounded buffer of configurable size and optionally delays onError notifications. - observeOn(Scheduler, int) - Method in class rx.Observable
-
Modifies an Observable to perform its emissions and notifications on a specified
Scheduler
, asynchronously with a bounded buffer of configurable size. - ObserveOnSubscriber(Scheduler, Subscriber<? super T>, boolean, int) - Constructor for class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- observer - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- observer - Variable in class rx.internal.util.ObserverSubscriber
- observer - Variable in class rx.subjects.SerializedSubject
- Observer<T> - Interface in rx
-
Provides a mechanism for receiving push-based notifications.
- observers - Variable in class rx.subjects.SubjectSubscriptionManager.State
- observers() - Method in class rx.subjects.SubjectSubscriptionManager
- Observers - Class in rx.observers
-
Helper methods and utilities for creating and working with
Observer
objects. - Observers() - Constructor for class rx.observers.Observers
- ObserverSubscriber<T> - Class in rx.internal.util
-
Wraps an Observer and forwards the onXXX method calls to it.
- ObserverSubscriber(Observer<? super T>) - Constructor for class rx.internal.util.ObserverSubscriber
- offer(E) - Method in class rx.internal.util.atomic.MpscLinkedAtomicQueue
-
- offer(E) - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- offer(E) - Method in class rx.internal.util.atomic.SpscLinkedAtomicQueue
-
IMPLEMENTATION NOTES:
Offer is allowed from a SINGLE thread.
Offer allocates a new node (holding the offered value) and: Sets that node as the producerNode.next Sets the new node as the producerNode From this follows that producerNode.next is always null and for all other nodes node.next is not null. - offer(E) - Method in class rx.internal.util.unsafe.MpmcArrayQueue
- offer(E) - Method in class rx.internal.util.unsafe.MpscLinkedQueue
-
- offer(E) - Method in class rx.internal.util.unsafe.SpmcArrayQueue
- offer(E) - Method in class rx.internal.util.unsafe.SpscArrayQueue
-
Called from a producer thread subject to the restrictions appropriate to the implementation and according to the
Queue.offer(Object)
interface. - offer(E) - Method in class rx.internal.util.unsafe.SpscLinkedQueue
-
IMPLEMENTATION NOTES:
Offer is allowed from a SINGLE thread.
Offer allocates a new node (holding the offered value) and: Sets that node as the producerNode.next Sets the new node as the producerNode From this follows that producerNode.next is always null and for all other nodes node.next is not null. - offer(E) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- offer(M) - Method in interface rx.internal.util.unsafe.MessagePassingQueue
-
Called from a producer thread subject to the restrictions appropriate to the implementation and according to the
Queue.offer(Object)
interface. - offer(T) - Method in class rx.internal.producers.QueuedProducer
-
Offers a value to this producer and tries to emit any queued values if the child requests allow it.
- offer(T) - Method in class rx.internal.producers.QueuedValueProducer
-
Offers a value to this producer and tries to emit any queued values if the child requests allow it.
- offer(T) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- offer(T) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- offer(T) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- offer(T) - Method in class rx.internal.util.SynchronizedQueue
- offer(T, T) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
-
Offer two elements at the same time.
- ofType(Class<R>) - Method in class rx.Observable
-
Filters the items emitted by an Observable, only emitting those of the specified type.
- on - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- on - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- ON - Static variable in class rx.internal.util.RxRingBuffer
-
Queue implementation testing that led to current choices of data structures: With synchronized LinkedList
- ON_COMPLETED - Static variable in class rx.Notification
- ON_COMPLETED_SENTINEL - Static variable in class rx.internal.operators.NotificationLite
- ON_NEXT_NULL_SENTINEL - Static variable in class rx.internal.operators.NotificationLite
- ON_OVERFLOW_DEFAULT - Static variable in class rx.BackpressureOverflow
-
By default, signal a MissingBackressureException due to lack of requests.
- ON_OVERFLOW_DROP_LATEST - Static variable in class rx.BackpressureOverflow
-
Drop the latest value.
- ON_OVERFLOW_DROP_OLDEST - Static variable in class rx.BackpressureOverflow
-
Drop the oldest value in the buffer.
- ON_OVERFLOW_ERROR - Static variable in class rx.BackpressureOverflow
-
Signal a MissingBackressureException due to lack of requests.
- ON_START - Static variable in class rx.observables.BlockingObservable
-
Constant to indicate the onStart method should be called.
- onAdded - Variable in class rx.subjects.SubjectSubscriptionManager
-
Action called after the subscriber has been added to the state.
- OnAssemblyCompletableSubscriber(Completable.CompletableSubscriber, String) - Constructor for class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- OnAssemblySingleSubscriber(SingleSubscriber<? super T>, String) - Constructor for class rx.internal.operators.OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber
- OnAssemblySubscriber(Subscriber<? super T>, String) - Constructor for class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- onBackpressureBuffer() - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to buffer these items indefinitely until they can be emitted.
- onBackpressureBuffer(long) - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
- onBackpressureBuffer(long, Action0) - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
- onBackpressureBuffer(long, Action0, BackpressureOverflow.Strategy) - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to buffer up to a given amount of items until they can be emitted.
- onBackpressureDrop() - Method in class rx.Observable
-
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.
- onBackpressureDrop(Action1<? super T>) - Method in class rx.Observable
-
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.
- onBackpressureLatest() - Method in class rx.Observable
-
Instructs an Observable that is emitting items faster than its observer can consume them to hold onto the latest value and emit that on request.
- once - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- once - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- once - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerScalarProducer
- once - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- once - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- once - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- once - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- once - Variable in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
-
Makes sure unsubscription happens only once.
- once - Variable in class rx.internal.operators.OperatorGroupBy.State
- once - Variable in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- once - Variable in class rx.internal.util.ScalarSynchronousObservable.WeakSingleProducer
- onCompletableCreate - Static variable in class rx.plugins.RxJavaHooks
- onCompletableError(Throwable) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call if the Completable.subscribe() crashes for some reason.
- onCompletableLift - Static variable in class rx.plugins.RxJavaHooks
- onCompletableLift(Completable.CompletableOperator) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber would subscribe to an Operator.
- onCompletableStart - Static variable in class rx.plugins.RxJavaHooks
- onCompletableStart(Completable, Completable.CompletableOnSubscribe) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
- onCompletableSubscribeError - Static variable in class rx.plugins.RxJavaHooks
- onComplete() - Method in class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- onComplete() - Method in class rx.internal.operators.OperatorGroupBy.State
- onCompleted - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onCompleted - Variable in class rx.internal.operators.OperatorMapNotification
- onCompleted - Variable in class rx.internal.util.ActionSubscriber
- onCompleted() - Method in interface rx.Completable.CompletableSubscriber
-
Called once the deferred computation completes normally.
- onCompleted() - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- onCompleted() - Method in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- onCompleted() - Method in class rx.internal.operators.BlockingOperatorNext.NextObserver
- onCompleted() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- onCompleted() - Method in class rx.internal.operators.BufferUntilSubscriber
- onCompleted() - Method in class rx.internal.operators.CachedObservable.CacheState
- onCompleted() - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber.ConcatInnerSubscriber
- onCompleted() - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- onCompleted() - Method in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- onCompleted() - Method in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- onCompleted() - Method in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- onCompleted() - Method in class rx.internal.operators.DeferredScalarSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- onCompleted() - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- onCompleted() - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- onCompleted() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- onCompleted() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftObserver
- onCompleted() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- onCompleted() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightObserver
- onCompleted() - Method in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribePublishMulticast
- onCompleted() - Method in class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- onCompleted() - Method in class rx.internal.operators.OnSubscribeTakeLastOne.TakeLastOneSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorCast.CastSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorMerge.InnerSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- onCompleted() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorScan.InitialProducer
- onCompleted() - Method in class rx.internal.operators.OperatorSingle.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- onCompleted() - Method in class rx.internal.operators.OperatorZip.ZipSubscriber
- onCompleted() - Method in class rx.internal.producers.ProducerObserverArbiter
- onCompleted() - Method in class rx.internal.producers.QueuedProducer
- onCompleted() - Method in class rx.internal.util.ActionNotificationObserver
- onCompleted() - Method in class rx.internal.util.ActionSubscriber
- onCompleted() - Method in class rx.internal.util.ObserverSubscriber
- onCompleted() - Method in class rx.internal.util.RxRingBuffer
- onCompleted() - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- onCompleted() - Method in class rx.observables.AsyncOnSubscribe.UnicastSubject
- onCompleted() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- onCompleted() - Method in interface rx.Observer
-
Notifies the Observer that the
Observable
has finished sending push-based notifications. - onCompleted() - Method in class rx.observers.SafeCompletableSubscriber
- onCompleted() - Method in class rx.observers.SafeSubscriber
-
Notifies the Subscriber that the
Observable
has finished sending push-based notifications. - onCompleted() - Method in class rx.observers.SerializedObserver
- onCompleted() - Method in class rx.observers.SerializedSubscriber
-
Notifies the Subscriber that the
Observable
has finished sending push-based notifications. - onCompleted() - Method in class rx.observers.TestObserver
-
Deprecated.
- onCompleted() - Method in class rx.observers.TestSubscriber
-
Notifies the Subscriber that the
Observable
has finished sending push-based notifications. - onCompleted() - Method in class rx.subjects.AsyncSubject
- onCompleted() - Method in class rx.subjects.BehaviorSubject
- onCompleted() - Method in class rx.subjects.PublishSubject
- onCompleted() - Method in class rx.subjects.ReplaySubject
- onCompleted() - Method in class rx.subjects.ReplaySubject.ReplayState
- onCompleted() - Method in class rx.subjects.SerializedSubject
- onCompleted() - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- onCompleted() - Method in class rx.subjects.TestSubject
-
Schedule a call to
onCompleted
on TestScheduler. - onCompleted() - Method in class rx.subjects.UnicastSubject
- onCompleted() - Method in class rx.subjects.UnicastSubject.State
- onCompleted(long) - Method in class rx.subjects.TestSubject
-
Schedule a call to
onCompleted
relative to "now()" +n milliseconds in the future. - OnCompleted - rx.Notification.Kind
- onCompletedEvents - Variable in class rx.observers.TestObserver
-
Deprecated.
- OnCompletedFailedException - Exception in rx.exceptions
-
Represents an exception used to re-throw errors thrown from
onCompleted()
. - OnCompletedFailedException(String, Throwable) - Constructor for exception rx.exceptions.OnCompletedFailedException
-
Customizes the
Throwable
with a custom message and wraps it before it is to be re-thrown as anOnCompletedFailedException
. - OnCompletedFailedException(Throwable) - Constructor for exception rx.exceptions.OnCompletedFailedException
-
Wraps the
Throwable
before it is to be re-thrown as anOnCompletedFailedException
. - onComputationScheduler - Static variable in class rx.plugins.RxJavaHooks
- onComputationScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when the Schedulers.computation() is called.
- onCreate(Completable.CompletableOnSubscribe) - Method in class rx.plugins.RxJavaCompletableExecutionHook
-
Deprecated.
- onCreate(Completable.CompletableOnSubscribe) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when a Completable is created.
- onCreate(Observable.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when an Observable is created.
- onCreate(Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Deprecated.
- onCreate(Single.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when a Single is created.
- onCreate(Single.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Deprecated.
- onDrop - Variable in class rx.internal.operators.OperatorOnBackpressureDrop
- onError - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onError - Variable in class rx.internal.operators.OperatorMapNotification
- onError - Variable in class rx.internal.util.ActionSubscriber
- onError - Static variable in class rx.plugins.RxJavaHooks
- onError(Throwable) - Method in interface rx.Completable.CompletableSubscriber
-
Called once if the deferred computation 'throws' an exception.
- onError(Throwable) - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- onError(Throwable) - Method in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- onError(Throwable) - Method in class rx.internal.operators.BlockingOperatorNext.NextObserver
- onError(Throwable) - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- onError(Throwable) - Method in class rx.internal.operators.BufferUntilSubscriber
- onError(Throwable) - Method in class rx.internal.operators.CachedObservable.CacheState
- onError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber.ConcatInnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- onError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- onError(Throwable) - Method in class rx.internal.operators.DeferredScalarSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftObserver
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightObserver
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribePublishMulticast
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorCast.CastSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- onError(Throwable) - Method in class rx.internal.operators.OperatorGroupBy.State
- onError(Throwable) - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorMerge.InnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- onError(Throwable) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorScan.InitialProducer
- onError(Throwable) - Method in class rx.internal.operators.OperatorSingle.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- onError(Throwable) - Method in class rx.internal.operators.OperatorZip.ZipSubscriber
- onError(Throwable) - Method in class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- onError(Throwable) - Method in class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- onError(Throwable) - Method in class rx.internal.producers.ProducerObserverArbiter
- onError(Throwable) - Method in class rx.internal.producers.QueuedProducer
- onError(Throwable) - Method in class rx.internal.util.ActionNotificationObserver
- onError(Throwable) - Method in class rx.internal.util.ActionSubscriber
- onError(Throwable) - Method in class rx.internal.util.ObserverSubscriber
- onError(Throwable) - Method in class rx.internal.util.RxRingBuffer
- onError(Throwable) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- onError(Throwable) - Method in class rx.observables.AsyncOnSubscribe.UnicastSubject
- onError(Throwable) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- onError(Throwable) - Method in interface rx.Observer
-
Notifies the Observer that the
Observable
has experienced an error condition. - onError(Throwable) - Method in class rx.observers.SafeCompletableSubscriber
- onError(Throwable) - Method in class rx.observers.SafeSubscriber
-
Notifies the Subscriber that the
Observable
has experienced an error condition. - onError(Throwable) - Method in class rx.observers.SerializedObserver
- onError(Throwable) - Method in class rx.observers.SerializedSubscriber
-
Notifies the Subscriber that the
Observable
has experienced an error condition. - onError(Throwable) - Method in class rx.observers.TestObserver
-
Deprecated.
- onError(Throwable) - Method in class rx.observers.TestSubscriber
-
Notifies the Subscriber that the
Observable
has experienced an error condition. - onError(Throwable) - Static method in class rx.plugins.RxJavaHooks
-
Consume undeliverable Throwables (acts as a global catch).
- onError(Throwable) - Method in class rx.SingleSubscriber
-
Notifies the SingleSubscriber that the
Single
has experienced an error condition. - onError(Throwable) - Method in class rx.subjects.AsyncSubject
- onError(Throwable) - Method in class rx.subjects.BehaviorSubject
- onError(Throwable) - Method in class rx.subjects.PublishSubject
- onError(Throwable) - Method in class rx.subjects.ReplaySubject
- onError(Throwable) - Method in class rx.subjects.ReplaySubject.ReplayState
- onError(Throwable) - Method in class rx.subjects.SerializedSubject
- onError(Throwable) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- onError(Throwable) - Method in class rx.subjects.TestSubject
-
Schedule a call to
onError
on TestScheduler. - onError(Throwable) - Method in class rx.subjects.UnicastSubject
- onError(Throwable) - Method in class rx.subjects.UnicastSubject.State
- onError(Throwable, long) - Method in class rx.subjects.TestSubject
-
Schedule a call to
onError
relative to "now()" +n milliseconds in the future. - OnError - rx.Notification.Kind
- onErrorComplete() - Method in class rx.Completable
-
Returns a Completable instance that if this Completable emits an error, it will emit an onComplete and swallow the throwable.
- onErrorComplete(Func1<? super Throwable, Boolean>) - Method in class rx.Completable
-
Returns a Completable instance that if this Completable emits an error and the predicate returns true, it will emit an onComplete and swallow the throwable.
- onErrorEvents - Variable in class rx.observers.TestObserver
-
Deprecated.
- OnErrorFailedException - Exception in rx.exceptions
-
Represents an exception used to re-throw errors thrown from
onError(Throwable)
. - OnErrorFailedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
-
Customizes the
Throwable
with a custom message and wraps it before it is to be re-thrown as anOnErrorFailedException
. - OnErrorFailedException(Throwable) - Constructor for exception rx.exceptions.OnErrorFailedException
-
Wraps the
Throwable
before it is to be re-thrown as anOnErrorFailedException
. - OnErrorNotImplementedException - Exception in rx.exceptions
-
Represents an exception used to re-throw
onError(Throwable)
when an implementation doesn't exist. - OnErrorNotImplementedException(String, Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
-
Customizes the
Throwable
with a custom message and wraps it before it is to be re-thrown as anOnErrorNotImplementedException
. - OnErrorNotImplementedException(Throwable) - Constructor for exception rx.exceptions.OnErrorNotImplementedException
-
Wraps the
Throwable
before it is to be re-thrown as anOnErrorNotImplementedException
. - onErrorResumeNext(Func1<? super Throwable, ? extends Completable>) - Method in class rx.Completable
-
Returns a Completable instance that when encounters an error from this Completable, calls the specified mapper function that returns another Completable instance for it and resumes the execution with it.
- onErrorResumeNext(Func1<Throwable, ? extends Observable<? extends T>>) - Method in class rx.Observable
-
Instructs an Observable to pass control to another Observable rather than invoking
onError
if it encounters an error. - onErrorResumeNext(Func1<Throwable, ? extends Single<? extends T>>) - Method in class rx.Single
-
Instructs a Single to pass control to another Single rather than invoking
onError(Throwable)
if it encounters an error. - onErrorResumeNext(Observable<? extends T>) - Method in class rx.Observable
-
Instructs an Observable to pass control to another Observable rather than invoking
onError
if it encounters an error. - onErrorResumeNext(Single<? extends T>) - Method in class rx.Single
-
Instructs a Single to pass control to another Single rather than invoking
onError(Throwable)
if it encounters an error. - onErrorReturn(Func1<Throwable, ? extends T>) - Method in class rx.Observable
-
Instructs an Observable to emit an item (returned by a specified function) rather than invoking
onError
if it encounters an error. - onErrorReturn(Func1<Throwable, ? extends T>) - Method in class rx.Single
-
Instructs a Single to emit an item (returned by a specified function) rather than invoking
onError
if it encounters an error. - OnErrorSentinel(Throwable) - Constructor for class rx.internal.operators.NotificationLite.OnErrorSentinel
- OnErrorThrowable - Exception in rx.exceptions
-
Represents a
Throwable
that anObservable
might notify its subscribers of, but that then can be handled by an operator that is designed to recover from or react appropriately to such an error. - OnErrorThrowable(Throwable) - Constructor for exception rx.exceptions.OnErrorThrowable
- OnErrorThrowable(Throwable, Object) - Constructor for exception rx.exceptions.OnErrorThrowable
- OnErrorThrowable.OnNextValue - Exception in rx.exceptions
-
Represents an exception that was encountered while trying to emit an item from an Observable, and tries to preserve that item for future use and/or reporting.
- OnErrorThrowable.OnNextValue.Primitives - Class in rx.exceptions
- onExceptionResumeNext(Observable<? extends T>) - Method in class rx.Observable
-
Instructs an Observable to pass control to another Observable rather than invoking
onError
if it encounters anException
. - onGenericScheduledExecutorService - Static variable in class rx.plugins.RxJavaHooks
- onIOScheduler - Static variable in class rx.plugins.RxJavaHooks
- onIOScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when the Schedulers.io() is called.
- onLift(Completable.CompletableOperator) - Method in class rx.plugins.RxJavaCompletableExecutionHook
-
Deprecated.
- onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Deprecated.
- onLift(Observable.Operator<? extends R, ? super T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Deprecated.
- onNewThreadScheduler - Static variable in class rx.plugins.RxJavaHooks
- onNewThreadScheduler(Scheduler) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call when the Schedulers.newThread() is called.
- onNext - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onNext - Variable in class rx.internal.operators.OperatorMapNotification
- onNext - Variable in class rx.internal.util.ActionSubscriber
- onNext(D1) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftDurationObserver
- onNext(D2) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- onNext(Object) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- onNext(Object) - Method in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- onNext(Object) - Method in class rx.internal.util.RxRingBuffer
- onNext(R) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- onNext(R) - Method in class rx.internal.operators.OperatorScan.InitialProducer
- onNext(Completable) - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- onNext(Completable) - Method in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- onNext(Notification<? extends T>) - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- onNext(Notification<? extends T>) - Method in class rx.internal.operators.BlockingOperatorNext.NextObserver
- onNext(Notification<? extends T>) - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- onNext(Observable[]) - Method in class rx.internal.operators.OperatorZip.ZipSubscriber
- onNext(Observable<? extends T>) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- onNext(Observable<? extends T>) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- onNext(Observable<? extends T>) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- onNext(Observable<T>) - Method in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- onNext(T) - Method in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- onNext(T) - Method in class rx.internal.operators.BufferUntilSubscriber
- onNext(T) - Method in class rx.internal.operators.CachedObservable.CacheState
- onNext(T) - Method in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeCollect.CollectSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFromAsync.NoneAsyncEmitter
- onNext(T) - Method in class rx.internal.operators.OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter
- onNext(T) - Method in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribePublishMulticast
- onNext(T) - Method in class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeReduceSeed.ReduceSeedSubscriber
- onNext(T) - Method in class rx.internal.operators.OnSubscribeTakeLastOne.TakeLastOneSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithSingleObservable.BufferingSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferExact
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorCast.CastSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- onNext(T) - Method in class rx.internal.operators.OperatorGroupBy.State
- onNext(T) - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorMerge.InnerSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- onNext(T) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorSingle.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- onNext(T) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- onNext(T) - Method in class rx.internal.producers.ProducerObserverArbiter
- onNext(T) - Method in class rx.internal.producers.QueuedProducer
- onNext(T) - Method in class rx.internal.util.ActionNotificationObserver
- onNext(T) - Method in class rx.internal.util.ActionSubscriber
- onNext(T) - Method in class rx.internal.util.ObserverSubscriber
- onNext(T) - Method in class rx.observables.AsyncOnSubscribe.UnicastSubject
- onNext(T) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- onNext(T) - Method in interface rx.Observer
-
Provides the Observer with a new item to observe.
- onNext(T) - Method in class rx.observers.SafeSubscriber
-
Provides the Subscriber with a new item to observe.
- onNext(T) - Method in class rx.observers.SerializedObserver
- onNext(T) - Method in class rx.observers.SerializedSubscriber
-
Provides the Subscriber with a new item to observe.
- onNext(T) - Method in class rx.observers.TestObserver
-
Deprecated.
- onNext(T) - Method in class rx.observers.TestSubscriber
-
Provides the Subscriber with a new item to observe.
- onNext(T) - Method in class rx.subjects.AsyncSubject
- onNext(T) - Method in class rx.subjects.BehaviorSubject
- onNext(T) - Method in class rx.subjects.PublishSubject
- onNext(T) - Method in class rx.subjects.ReplaySubject
- onNext(T) - Method in class rx.subjects.ReplaySubject.ReplayState
- onNext(T) - Method in class rx.subjects.SerializedSubject
- onNext(T) - Method in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- onNext(T) - Method in class rx.subjects.TestSubject
-
Schedule a call to
onNext
on TestScheduler. - onNext(T) - Method in class rx.subjects.UnicastSubject
- onNext(T) - Method in class rx.subjects.UnicastSubject.State
- onNext(T1) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.LeftObserver
- onNext(T2) - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightObserver
- onNext(TLeft) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber
- onNext(TLeftDuration) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber
- onNext(T, long) - Method in class rx.subjects.TestSubject
-
Schedule a call to
onNext
relative to "now()" +n milliseconds in the future. - onNext(TRight) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber
- onNext(TRightDuration) - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- onNext(U) - Method in class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- onNext(U) - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- OnNext - rx.Notification.Kind
- onNextCalled - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- onNextCalled - Variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- onNextEvents - Variable in class rx.observers.TestObserver
-
Deprecated.
- OnNextValue(Object) - Constructor for exception rx.exceptions.OnErrorThrowable.OnNextValue
-
Create an
OnNextValue
exception and include in its error message a string representation of the item that was intended to be emitted at the time the exception was handled. - onNotification - Variable in class rx.internal.util.ActionNotificationObserver
- onObservableCreate - Static variable in class rx.plugins.RxJavaHooks
- onObservableError(Throwable) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call if the Observable.subscribe() crashes for some reason.
- onObservableLift - Static variable in class rx.plugins.RxJavaHooks
- onObservableLift(Observable.Operator<R, T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber would subscribe to an Operator.
- onObservableReturn - Static variable in class rx.plugins.RxJavaHooks
- onObservableReturn(Subscription) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the Observable.subscribe() method is about to return a Subscription.
- onObservableStart - Static variable in class rx.plugins.RxJavaHooks
- onObservableStart(Observable<T>, Observable.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
- onObservableSubscribeError - Static variable in class rx.plugins.RxJavaHooks
- onOverflow - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- onOverflow - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer
- onOverflow() - Method in class rx.internal.operators.OnSubscribeFromAsync.DropAsyncEmitter
- onOverflow() - Method in class rx.internal.operators.OnSubscribeFromAsync.ErrorAsyncEmitter
- onOverflow() - Method in class rx.internal.operators.OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter
- onRequested() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- onRequested() - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- onRequested() - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- onSchedule - Variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncOnSubscribe
- onSchedule - Variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- onSchedule(Action0) - Method in class rx.plugins.RxJavaSchedulersHook
-
Deprecated.
- onScheduleAction - Static variable in class rx.plugins.RxJavaHooks
- onScheduledAction(Action0) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the action is scheduled, allows decorating the original action.
- onSingleCreate - Static variable in class rx.plugins.RxJavaHooks
- onSingleError(Throwable) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call if the Single.subscribe() crashes for some reason.
- onSingleLift - Static variable in class rx.plugins.RxJavaHooks
- onSingleLift(Observable.Operator<R, T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber would subscribe to an Operator.
- onSingleReturn - Static variable in class rx.plugins.RxJavaHooks
- onSingleReturn(Subscription) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the Single.subscribe() method is about to return a Subscription.
- onSingleStart - Static variable in class rx.plugins.RxJavaHooks
- onSingleStart(Single<T>, Observable.OnSubscribe<T>) - Static method in class rx.plugins.RxJavaHooks
-
Hook to call before the child subscriber is subscribed to the OnSubscribe action.
- onSingleSubscribeError - Static variable in class rx.plugins.RxJavaHooks
- onStart - Variable in class rx.subjects.SubjectSubscriptionManager
-
Action called when a new subscriber subscribes but before it is added to the state.
- onStart() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- onStart() - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- onStart() - Method in class rx.internal.operators.OperatorMerge.InnerSubscriber
- onStart() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- onStart() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- onStart() - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
- onStart() - Method in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- onStart() - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- onStart() - Method in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- onStart() - Method in class rx.observers.AsyncCompletableSubscriber
-
Called before the first onSubscribe() call succeeds.
- onStart() - Method in class rx.Subscriber
-
This method is invoked when the Subscriber and Observable have been connected but the Observable has not yet begun to emit items or send notifications to the Subscriber.
- onSubscribe - Variable in class rx.Completable
-
The actual subscription action.
- onSubscribe - Variable in class rx.Observable
- onSubscribe - Variable in class rx.Single
- onSubscribe(Subscriber<? super T>, AtomicBoolean) - Method in class rx.internal.operators.OnSubscribeRefCount
- onSubscribe(Subscription) - Method in interface rx.Completable.CompletableSubscriber
-
Called once by the Completable to set a Subscription on this instance which then can be used to cancel the subscription at any time.
- onSubscribe(Subscription) - Method in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber.ConcatInnerSubscriber
- onSubscribe(Subscription) - Method in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- onSubscribe(Subscription) - Method in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- onSubscribe(Subscription) - Method in class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- onSubscribe(Subscription) - Method in class rx.observers.AsyncCompletableSubscriber
- onSubscribe(Subscription) - Method in class rx.observers.SafeCompletableSubscriber
- OnSubscribeAction(BufferUntilSubscriber.State<T>) - Constructor for class rx.internal.operators.BufferUntilSubscriber.OnSubscribeAction
- OnSubscribeAmb<T> - Class in rx.internal.operators
-
Given multiple
Observable
s, propagates the one that first emits an item. - OnSubscribeAmb(Iterable<? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OnSubscribeAmb
- OnSubscribeAmb.AmbSubscriber<T> - Class in rx.internal.operators
- OnSubscribeAmb.Selection<T> - Class in rx.internal.operators
- OnSubscribeAutoConnect<T> - Class in rx.internal.operators
-
Wraps a ConnectableObservable and calls its connect() method once the specified number of Subscribers have subscribed.
- OnSubscribeAutoConnect(ConnectableObservable<? extends T>, int, Action1<? super Subscription>) - Constructor for class rx.internal.operators.OnSubscribeAutoConnect
- OnSubscribeCollect<T,R> - Class in rx.internal.operators
- OnSubscribeCollect(Observable<T>, Func0<R>, Action2<R, ? super T>) - Constructor for class rx.internal.operators.OnSubscribeCollect
- OnSubscribeCollect.CollectSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeCombineLatest<T,R> - Class in rx.internal.operators
- OnSubscribeCombineLatest(Iterable<? extends Observable<? extends T>>, FuncN<? extends R>) - Constructor for class rx.internal.operators.OnSubscribeCombineLatest
- OnSubscribeCombineLatest(Observable<? extends T>[], Iterable<? extends Observable<? extends T>>, FuncN<? extends R>, int, boolean) - Constructor for class rx.internal.operators.OnSubscribeCombineLatest
- OnSubscribeCombineLatest.CombinerSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeCombineLatest.LatestCoordinator<T,R> - Class in rx.internal.operators
- OnSubscribeConcatMap<T,R> - Class in rx.internal.operators
-
Maps a source sequence into Observables and concatenates them in order, subscribing to one at a time.
- OnSubscribeConcatMap(Observable<? extends T>, Func1<? super T, ? extends Observable<? extends R>>, int, int) - Constructor for class rx.internal.operators.OnSubscribeConcatMap
- OnSubscribeConcatMap.ConcatMapInnerScalarProducer<T,R> - Class in rx.internal.operators
- OnSubscribeConcatMap.ConcatMapInnerSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeConcatMap.ConcatMapSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeDefer<T> - Class in rx.internal.operators
-
Do not create the Observable until an Observer subscribes; create a fresh Observable on each subscription.
- OnSubscribeDefer(Func0<? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OnSubscribeDefer
- OnSubscribeDelaySubscription<T> - Class in rx.internal.operators
-
Delays the subscription to the source by the given amount, running on the given scheduler.
- OnSubscribeDelaySubscription(Observable<? extends T>, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeDelaySubscription
- OnSubscribeDelaySubscriptionOther<T,U> - Class in rx.internal.operators
-
Delays the subscription to the main source until the other observable fires an event or completes.
- OnSubscribeDelaySubscriptionOther(Observable<? extends T>, Observable<U>) - Constructor for class rx.internal.operators.OnSubscribeDelaySubscriptionOther
- OnSubscribeDelaySubscriptionWithSelector<T,U> - Class in rx.internal.operators
-
Delays the subscription until the Observable emits an event.
- OnSubscribeDelaySubscriptionWithSelector(Observable<? extends T>, Func0<? extends Observable<U>>) - Constructor for class rx.internal.operators.OnSubscribeDelaySubscriptionWithSelector
- OnSubscribeDetach<T> - Class in rx.internal.operators
-
Nulls out references to upstream data structures when the source terminates or the child unsubscribes.
- OnSubscribeDetach(Observable<T>) - Constructor for class rx.internal.operators.OnSubscribeDetach
- OnSubscribeDetach.DetachProducer<T> - Class in rx.internal.operators
-
Callbacks from the child Subscriber.
- OnSubscribeDetach.DetachSubscriber<T> - Class in rx.internal.operators
-
The parent subscriber that forwards events and cleans up on a terminal state.
- OnSubscribeDetach.TerminatedProducer - Enum in rx.internal.operators
-
Singleton instance via enum.
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaCompletableExecutionHook
-
Deprecated.
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Deprecated.
- onSubscribeError(Throwable) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Deprecated.
- OnSubscribeExtend(Observable<T>) - Constructor for class rx.Observable.OnSubscribeExtend
- OnSubscribeFilter<T> - Class in rx.internal.operators
-
Filters an Observable by discarding any items it emits that do not meet some test.
- OnSubscribeFilter(Observable<T>, Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OnSubscribeFilter
- OnSubscribeFilter.FilterSubscriber<T> - Class in rx.internal.operators
- OnSubscribeFlattenIterable<T,R> - Class in rx.internal.operators
-
Flattens a sequence if Iterable sources, generated via a function, into a single sequence.
- OnSubscribeFlattenIterable(Observable<? extends T>, Func1<? super T, ? extends Iterable<? extends R>>, int) - Constructor for class rx.internal.operators.OnSubscribeFlattenIterable
-
Protected: use createFrom to handle source-dependent optimizations.
- OnSubscribeFlattenIterable.FlattenIterableSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable<T,R> - Class in rx.internal.operators
-
A custom flattener that works from a scalar value and computes the iterable during subscription time.
- OnSubscribeFromArray<T> - Class in rx.internal.operators
- OnSubscribeFromArray(T[]) - Constructor for class rx.internal.operators.OnSubscribeFromArray
- OnSubscribeFromArray.FromArrayProducer<T> - Class in rx.internal.operators
- OnSubscribeFromAsync<T> - Class in rx.internal.operators
- OnSubscribeFromAsync(Action1<AsyncEmitter<T>>, AsyncEmitter.BackpressureMode) - Constructor for class rx.internal.operators.OnSubscribeFromAsync
- OnSubscribeFromAsync.BaseAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.BufferAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.CancellableSubscription - Class in rx.internal.operators
- OnSubscribeFromAsync.DropAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.ErrorAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.LatestAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.NoneAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter<T> - Class in rx.internal.operators
- OnSubscribeFromCallable<T> - Class in rx.internal.operators
-
Do not invoke the function until an Observer subscribes; Invokes function on each subscription.
- OnSubscribeFromCallable(Callable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeFromCallable
- OnSubscribeFromIterable<T> - Class in rx.internal.operators
-
Converts an
Iterable
sequence into anObservable
. - OnSubscribeFromIterable(Iterable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeFromIterable
- OnSubscribeFromIterable.IterableProducer<T> - Class in rx.internal.operators
- OnSubscribeGroupJoin<T1,T2,D1,D2,R> - Class in rx.internal.operators
-
Correlates two sequences when they overlap and groups the results.
- OnSubscribeGroupJoin(Observable<T1>, Observable<T2>, Func1<? super T1, ? extends Observable<D1>>, Func1<? super T2, ? extends Observable<D2>>, Func2<? super T1, ? super Observable<T2>, ? extends R>) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin
- OnSubscribeGroupJoin.ResultManager - Class in rx.internal.operators
-
Manages sub-observers and subscriptions.
- OnSubscribeGroupJoin.ResultManager.LeftDurationObserver - Class in rx.internal.operators
-
Observe left duration and apply termination.
- OnSubscribeGroupJoin.ResultManager.LeftObserver - Class in rx.internal.operators
-
Observe the left source.
- OnSubscribeGroupJoin.ResultManager.RightDurationObserver - Class in rx.internal.operators
-
Observe right duration and apply termination.
- OnSubscribeGroupJoin.ResultManager.RightObserver - Class in rx.internal.operators
-
Observe the right source.
- OnSubscribeGroupJoin.WindowObservableFunc<T> - Class in rx.internal.operators
-
The reference-counted window observable.
- OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber - Class in rx.internal.operators
-
Observe activities on the window.
- OnSubscribeJoin<TLeft,TRight,TLeftDuration,TRightDuration,R> - Class in rx.internal.operators
-
Correlates the elements of two sequences based on overlapping durations.
- OnSubscribeJoin(Observable<TLeft>, Observable<TRight>, Func1<TLeft, Observable<TLeftDuration>>, Func1<TRight, Observable<TRightDuration>>, Func2<TLeft, TRight, R>) - Constructor for class rx.internal.operators.OnSubscribeJoin
- OnSubscribeJoin.ResultSink - Class in rx.internal.operators
-
Manage the left and right sources.
- OnSubscribeJoin.ResultSink.LeftSubscriber - Class in rx.internal.operators
-
Observes the left values.
- OnSubscribeJoin.ResultSink.LeftSubscriber.LeftDurationSubscriber - Class in rx.internal.operators
-
Observes the left duration.
- OnSubscribeJoin.ResultSink.RightSubscriber - Class in rx.internal.operators
-
Observes the right values.
- OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber - Class in rx.internal.operators
-
Observe the right duration.
- OnSubscribeLift<T,R> - Class in rx.internal.operators
-
Transforms the downstream Subscriber into a Subscriber via an operator callback and calls the parent OnSubscribe.call() method with it.
- OnSubscribeLift(Observable.OnSubscribe<T>, Observable.Operator<? extends R, ? super T>) - Constructor for class rx.internal.operators.OnSubscribeLift
- OnSubscribeMap<T,R> - Class in rx.internal.operators
-
Applies a function of your choosing to every item emitted by an
Observable
, and emits the results of this transformation as a newObservable
. - OnSubscribeMap(Observable<T>, Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.OnSubscribeMap
- OnSubscribeMap.MapSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeOnAssembly<T> - Class in rx.internal.operators
-
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.
- OnSubscribeOnAssembly(Observable.OnSubscribe<T>) - Constructor for class rx.internal.operators.OnSubscribeOnAssembly
- OnSubscribeOnAssembly.OnAssemblySubscriber<T> - Class in rx.internal.operators
- OnSubscribeOnAssemblyCompletable<T> - Class in rx.internal.operators
-
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.
- OnSubscribeOnAssemblyCompletable(Completable.CompletableOnSubscribe) - Constructor for class rx.internal.operators.OnSubscribeOnAssemblyCompletable
- OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber - Class in rx.internal.operators
- OnSubscribeOnAssemblySingle<T> - Class in rx.internal.operators
-
Captures the current stack when it is instantiated, makes it available through a field and attaches it to all passing exception.
- OnSubscribeOnAssemblySingle(Single.OnSubscribe<T>) - Constructor for class rx.internal.operators.OnSubscribeOnAssemblySingle
- OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber<T> - Class in rx.internal.operators
- OnSubscribePublishMulticast<T> - Class in rx.internal.operators
-
Multicasts notifications coming through its input Subscriber view to its client Subscribers via lockstep backpressure mode.
- OnSubscribePublishMulticast(int, boolean) - Constructor for class rx.internal.operators.OnSubscribePublishMulticast
-
Constructor, initializes the fields
- OnSubscribePublishMulticast.ParentSubscriber<T> - Class in rx.internal.operators
-
The subscriber that must be used for subscribing to the upstream source.
- OnSubscribePublishMulticast.PublishProducer<T> - Class in rx.internal.operators
-
A Producer and Subscription that wraps a child Subscriber and manages its backpressure requests along with its unsubscription from the parent class.
- OnSubscribeRange - Class in rx.internal.operators
-
Emit ints from start to end inclusive.
- OnSubscribeRange(int, int) - Constructor for class rx.internal.operators.OnSubscribeRange
- OnSubscribeRange.RangeProducer - Class in rx.internal.operators
- OnSubscribeRedo<T> - Class in rx.internal.operators
- OnSubscribeRedo(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, boolean, boolean, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeRedo
- OnSubscribeRedo.RedoFinite - Class in rx.internal.operators
- OnSubscribeRedo.RetryWithPredicate - Class in rx.internal.operators
- OnSubscribeReduce<T> - Class in rx.internal.operators
- OnSubscribeReduce(Observable<T>, Func2<T, T, T>) - Constructor for class rx.internal.operators.OnSubscribeReduce
- OnSubscribeReduce.ReduceSubscriber<T> - Class in rx.internal.operators
- OnSubscribeReduceSeed<T,R> - Class in rx.internal.operators
- OnSubscribeReduceSeed(Observable<T>, R, Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OnSubscribeReduceSeed
- OnSubscribeReduceSeed.ReduceSeedSubscriber<T,R> - Class in rx.internal.operators
- OnSubscribeRefCount<T> - Class in rx.internal.operators
-
Returns an observable sequence that stays connected to the source as long as there is at least one subscription to the observable sequence.
- OnSubscribeRefCount(ConnectableObservable<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeRefCount
-
Constructor.
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Deprecated.
- onSubscribeReturn(Subscription) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Deprecated.
- OnSubscribeScalarFlattenIterable(T, Func1<? super T, ? extends Iterable<? extends R>>) - Constructor for class rx.internal.operators.OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable
- OnSubscribeSingle<T> - Class in rx.internal.operators
-
Allows conversion of an Observable to a Single ensuring that exactly one item is emitted - no more and no less.
- OnSubscribeSingle(Observable<T>) - Constructor for class rx.internal.operators.OnSubscribeSingle
- onSubscribeStart(Completable, Completable.CompletableOnSubscribe) - Method in class rx.plugins.RxJavaCompletableExecutionHook
-
Deprecated.
- onSubscribeStart(Observable<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaObservableExecutionHook
-
Deprecated.
- onSubscribeStart(Single<? extends T>, Observable.OnSubscribe<T>) - Method in class rx.plugins.RxJavaSingleExecutionHook
-
Deprecated.
- OnSubscribeTakeLastOne<T> - Class in rx.internal.operators
- OnSubscribeTakeLastOne(Observable<T>) - Constructor for class rx.internal.operators.OnSubscribeTakeLastOne
- OnSubscribeTakeLastOne.TakeLastOneSubscriber<T> - Class in rx.internal.operators
- OnSubscribeThrow<T> - Class in rx.internal.operators
- OnSubscribeThrow(Throwable) - Constructor for class rx.internal.operators.OnSubscribeThrow
- OnSubscribeTimerOnce - Class in rx.internal.operators
-
Timer that emits a single 0L and completes after the specified time.
- OnSubscribeTimerOnce(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeTimerOnce
- OnSubscribeTimerPeriodically - Class in rx.internal.operators
-
Emit 0L after the initial period and ever increasing number after each period.
- OnSubscribeTimerPeriodically(long, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OnSubscribeTimerPeriodically
- OnSubscribeToObservableFuture - Class in rx.internal.operators
-
Converts a
Future
into anObservable
. - OnSubscribeToObservableFuture() - Constructor for class rx.internal.operators.OnSubscribeToObservableFuture
- OnSubscribeToObservableFuture.ToObservableFuture<T> - Class in rx.internal.operators
- OnSubscribeUsing<T,Resource> - Class in rx.internal.operators
-
Constructs an observable sequence that depends on a resource object.
- OnSubscribeUsing(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>, boolean) - Constructor for class rx.internal.operators.OnSubscribeUsing
- OnSubscribeUsing.DisposeAction<Resource> - Class in rx.internal.operators
- onSuccess(T) - Method in class rx.internal.operators.OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber
- onSuccess(T) - Method in class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- onSuccess(T) - Method in class rx.internal.operators.SingleOnSubscribeMap.MapSubscriber
- onSuccess(T) - Method in class rx.SingleSubscriber
-
Notifies the SingleSubscriber with a single item and that the
Single
has finished sending push-based notifications. - onTerminated - Variable in class rx.subjects.SubjectSubscriptionManager
-
Action called when the subscriber wants to subscribe to a terminal state.
- onTerminateDetach() - Method in class rx.Observable
-
Nulls out references to the upstream producer and downstream Subscriber if the sequence is terminated or downstream unsubscribes.
- onTimeout(long) - Method in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- onUnsubscribe - Variable in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- onUnsubscribe - Variable in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- onUnsubscribe(S) - Method in class rx.observables.AsyncOnSubscribe.AsyncOnSubscribeImpl
- onUnsubscribe(S) - Method in class rx.observables.AsyncOnSubscribe
-
Clean up behavior that is executed after the downstream subscriber's subscription is unsubscribed.
- onUnsubscribe(S) - Method in class rx.observables.SyncOnSubscribe
-
Clean up behavior that is executed after the downstream subscriber's subscription is unsubscribed.
- onUnsubscribe(S) - Method in class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- onUnsubscribed() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- onUnsubscribed() - Method in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- onUnsubscribed() - Method in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- OpenHashSet<T> - Class in rx.internal.util
-
A simple open hash set with add, remove and clear capabilities only.
- OpenHashSet() - Constructor for class rx.internal.util.OpenHashSet
- OpenHashSet(int) - Constructor for class rx.internal.util.OpenHashSet
-
Creates an OpenHashSet with the initial capacity and load factor of 0.75f.
- OpenHashSet(int, float) - Constructor for class rx.internal.util.OpenHashSet
- operator - Variable in class rx.internal.operators.OnSubscribeLift
- OperatorAll<T> - Class in rx.internal.operators
-
Returns an Observable that emits a Boolean that indicates whether all items emitted by an Observable satisfy a condition.
- OperatorAll(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorAll
- OperatorAny<T> - Class in rx.internal.operators
-
Returns an
Observable
that emitstrue
if any element of an observable sequence satisfies a condition, otherwisefalse
. - OperatorAny(Func1<? super T, Boolean>, boolean) - Constructor for class rx.internal.operators.OperatorAny
- OperatorAsObservable<T> - Class in rx.internal.operators
-
Hides the identity of another observable.
- OperatorAsObservable() - Constructor for class rx.internal.operators.OperatorAsObservable
- OperatorAsObservable.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorBufferWithSingleObservable<T,TClosing> - Class in rx.internal.operators
-
This operation takes values from the specified
Observable
source and stores them in a buffer until theObservable
constructed using theFunc0
argument, produces a value. - OperatorBufferWithSingleObservable(Func0<? extends Observable<? extends TClosing>>, int) - Constructor for class rx.internal.operators.OperatorBufferWithSingleObservable
- OperatorBufferWithSingleObservable(Observable<? extends TClosing>, int) - Constructor for class rx.internal.operators.OperatorBufferWithSingleObservable
- OperatorBufferWithSingleObservable.BufferingSubscriber - Class in rx.internal.operators
- OperatorBufferWithSize<T> - Class in rx.internal.operators
-
This operation takes values from the specified
Observable
source and stores them in all active chunks until the buffer contains a specified number of elements. - OperatorBufferWithSize(int, int) - Constructor for class rx.internal.operators.OperatorBufferWithSize
- OperatorBufferWithSize.BufferExact<T> - Class in rx.internal.operators
- OperatorBufferWithSize.BufferOverlap<T> - Class in rx.internal.operators
- OperatorBufferWithSize.BufferOverlap.BufferOverlapProducer - Class in rx.internal.operators
- OperatorBufferWithSize.BufferSkip<T> - Class in rx.internal.operators
- OperatorBufferWithSize.BufferSkip.BufferSkipProducer - Class in rx.internal.operators
- OperatorBufferWithStartEndObservable<T,TOpening,TClosing> - Class in rx.internal.operators
-
This operation takes values from the specified
Observable
source and stores them in the currently active chunks. - OperatorBufferWithStartEndObservable(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Constructor for class rx.internal.operators.OperatorBufferWithStartEndObservable
- OperatorBufferWithStartEndObservable.BufferingSubscriber - Class in rx.internal.operators
- OperatorBufferWithTime<T> - Class in rx.internal.operators
-
This operation takes values from the specified
Observable
source and stores them in a buffer. - OperatorBufferWithTime(long, long, TimeUnit, int, Scheduler) - Constructor for class rx.internal.operators.OperatorBufferWithTime
- OperatorBufferWithTime.ExactSubscriber - Class in rx.internal.operators
-
Subscriber when exact timed chunking is required.
- OperatorBufferWithTime.InexactSubscriber - Class in rx.internal.operators
-
Subscriber when the buffer chunking time and length differ.
- OperatorCast<T,R> - Class in rx.internal.operators
-
Converts the elements of an observable sequence to the specified type.
- OperatorCast(Class<R>) - Constructor for class rx.internal.operators.OperatorCast
- OperatorCast.CastSubscriber<T,R> - Class in rx.internal.operators
- OperatorDebounceWithSelector<T,U> - Class in rx.internal.operators
-
Delay the emission via another observable if no new source appears in the meantime.
- OperatorDebounceWithSelector(Func1<? super T, ? extends Observable<U>>) - Constructor for class rx.internal.operators.OperatorDebounceWithSelector
- OperatorDebounceWithTime<T> - Class in rx.internal.operators
-
This operation filters out events which are published too quickly in succession.
- OperatorDebounceWithTime(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorDebounceWithTime
- OperatorDebounceWithTime.DebounceState<T> - Class in rx.internal.operators
-
Tracks the last value to be emitted and manages completion.
- OperatorDelay<T> - Class in rx.internal.operators
-
Delays the emission of onNext events by a given amount of time.
- OperatorDelay(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorDelay
- OperatorDelayWithSelector<T,V> - Class in rx.internal.operators
-
Delay the subscription and emission of the source items by a per-item observable that fires its first element.
- OperatorDelayWithSelector(Observable<? extends T>, Func1<? super T, ? extends Observable<V>>) - Constructor for class rx.internal.operators.OperatorDelayWithSelector
- OperatorDematerialize<T> - Class in rx.internal.operators
-
Reverses the effect of
OperatorMaterialize
by transforming the Notification objects emitted by a source Observable into the items or notifications they represent. - OperatorDematerialize() - Constructor for class rx.internal.operators.OperatorDematerialize
- OperatorDematerialize.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorDistinct<T,U> - Class in rx.internal.operators
-
Returns an Observable that emits all distinct items emitted by the source.
- OperatorDistinct(Func1<? super T, ? extends U>) - Constructor for class rx.internal.operators.OperatorDistinct
- OperatorDistinct.Holder - Class in rx.internal.operators
- OperatorDistinctUntilChanged<T,U> - Class in rx.internal.operators
-
Returns an Observable that emits all sequentially distinct items emitted by the source.
- OperatorDistinctUntilChanged(Func1<? super T, ? extends U>) - Constructor for class rx.internal.operators.OperatorDistinctUntilChanged
- OperatorDistinctUntilChanged(Func2<? super U, ? super U, Boolean>) - Constructor for class rx.internal.operators.OperatorDistinctUntilChanged
- OperatorDistinctUntilChanged.Holder - Class in rx.internal.operators
- OperatorDoAfterTerminate<T> - Class in rx.internal.operators
-
Registers an action to be called after an Observable invokes
onComplete
oronError
. - OperatorDoAfterTerminate(Action0) - Constructor for class rx.internal.operators.OperatorDoAfterTerminate
- OperatorDoOnEach<T> - Class in rx.internal.operators
-
Converts the elements of an observable sequence to the specified type.
- OperatorDoOnEach(Observer<? super T>) - Constructor for class rx.internal.operators.OperatorDoOnEach
- OperatorDoOnRequest<T> - Class in rx.internal.operators
-
This operator modifies an
Observable
so a given action is invoked when theProducer
receives a request. - OperatorDoOnRequest(Action1<Long>) - Constructor for class rx.internal.operators.OperatorDoOnRequest
- OperatorDoOnRequest.ParentSubscriber<T> - Class in rx.internal.operators
- OperatorDoOnSubscribe<T> - Class in rx.internal.operators
-
This operator modifies an
Observable
so a given action is invoked when theObservable
is subscribed. - OperatorDoOnSubscribe(Action0) - Constructor for class rx.internal.operators.OperatorDoOnSubscribe
-
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is subscribed
- OperatorDoOnUnsubscribe<T> - Class in rx.internal.operators
-
This operator modifies an
Observable
so a given action is invoked when theObservable
is unsubscribed. - OperatorDoOnUnsubscribe(Action0) - Constructor for class rx.internal.operators.OperatorDoOnUnsubscribe
-
Constructs an instance of the operator with the callback that gets invoked when the modified Observable is unsubscribed
- OperatorEagerConcatMap<T,R> - Class in rx.internal.operators
- OperatorEagerConcatMap(Func1<? super T, ? extends Observable<? extends R>>, int, int) - Constructor for class rx.internal.operators.OperatorEagerConcatMap
- OperatorEagerConcatMap.EagerInnerSubscriber<T> - Class in rx.internal.operators
- OperatorEagerConcatMap.EagerOuterProducer - Class in rx.internal.operators
- OperatorEagerConcatMap.EagerOuterSubscriber<T,R> - Class in rx.internal.operators
- OperatorElementAt<T> - Class in rx.internal.operators
-
Returns the element at a specified index in a sequence.
- OperatorElementAt(int) - Constructor for class rx.internal.operators.OperatorElementAt
- OperatorElementAt(int, T) - Constructor for class rx.internal.operators.OperatorElementAt
- OperatorElementAt(int, T, boolean) - Constructor for class rx.internal.operators.OperatorElementAt
- OperatorElementAt.InnerProducer - Class in rx.internal.operators
-
A producer that wraps another Producer and requests Long.MAX_VALUE when the first positive request() call comes in.
- OperatorGroupBy<T,K,V> - Class in rx.internal.operators
-
Groups the items emitted by an Observable according to a specified criterion, and emits these grouped items as Observables, one Observable per group.
- OperatorGroupBy(Func1<? super T, ? extends K>) - Constructor for class rx.internal.operators.OperatorGroupBy
- OperatorGroupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Constructor for class rx.internal.operators.OperatorGroupBy
- OperatorGroupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, int, boolean, Func1<Action1<K>, Map<K, Object>>) - Constructor for class rx.internal.operators.OperatorGroupBy
- OperatorGroupBy(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func1<Action1<K>, Map<K, Object>>) - Constructor for class rx.internal.operators.OperatorGroupBy
- OperatorGroupBy.GroupByProducer - Class in rx.internal.operators
- OperatorGroupBy.GroupBySubscriber<T,K,V> - Class in rx.internal.operators
- OperatorGroupBy.GroupBySubscriber.EvictionAction<K> - Class in rx.internal.operators
- OperatorGroupBy.GroupedUnicast<K,T> - Class in rx.internal.operators
- OperatorGroupBy.State<T,K> - Class in rx.internal.operators
- OperatorIgnoreElements<T> - Class in rx.internal.operators
- OperatorIgnoreElements() - Constructor for class rx.internal.operators.OperatorIgnoreElements
- OperatorIgnoreElements.Holder - Class in rx.internal.operators
- OperatorMapNotification<T,R> - Class in rx.internal.operators
-
Applies a function of your choosing to every item emitted by an
Observable
, and emits the results of this transformation as a newObservable
. - OperatorMapNotification(Func1<? super T, ? extends R>, Func1<? super Throwable, ? extends R>, Func0<? extends R>) - Constructor for class rx.internal.operators.OperatorMapNotification
- OperatorMapNotification.MapNotificationSubscriber<T,R> - Class in rx.internal.operators
- OperatorMapPair<T,U,R> - Class in rx.internal.operators
-
An
Observable.Operator
that pairs up items emitted by a sourceObservable
with the sequence of items emitted by theObservable
that is derived from each item by means of a selector, and emits the results of this pairing. - OperatorMapPair(Func1<? super T, ? extends Observable<? extends U>>, Func2<? super T, ? super U, ? extends R>) - Constructor for class rx.internal.operators.OperatorMapPair
- OperatorMapPair.MapPairSubscriber<T,U,R> - Class in rx.internal.operators
- OperatorMapPair.OuterInnerMapper<T,U,R> - Class in rx.internal.operators
- OperatorMaterialize<T> - Class in rx.internal.operators
-
Turns all of the notifications from an Observable into
onNext
emissions, and marks them with their original notification types withinNotification
objects. - OperatorMaterialize() - Constructor for class rx.internal.operators.OperatorMaterialize
- OperatorMaterialize.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorMaterialize.ParentSubscriber<T> - Class in rx.internal.operators
- OperatorMerge<T> - Class in rx.internal.operators
-
Flattens a list of
Observable
s into oneObservable
, without any transformation. - OperatorMerge(boolean, int) - Constructor for class rx.internal.operators.OperatorMerge
- OperatorMerge.HolderDelayErrors - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorMerge.HolderNoDelay - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorMerge.InnerSubscriber<T> - Class in rx.internal.operators
- OperatorMerge.MergeProducer<T> - Class in rx.internal.operators
- OperatorMerge.MergeSubscriber<T> - Class in rx.internal.operators
-
The subscriber that observes Observables.
- OperatorMulticast<T,R> - Class in rx.internal.operators
-
Shares a single subscription to a source through a Subject.
- OperatorMulticast(Object, AtomicReference<Subject<? super T, ? extends R>>, List<Subscriber<? super R>>, Observable<? extends T>, Func0<? extends Subject<? super T, ? extends R>>) - Constructor for class rx.internal.operators.OperatorMulticast
- OperatorMulticast(Observable<? extends T>, Func0<? extends Subject<? super T, ? extends R>>) - Constructor for class rx.internal.operators.OperatorMulticast
- OperatorObserveOn<T> - Class in rx.internal.operators
-
Delivers events on the specified
Scheduler
asynchronously via an unbounded buffer. - OperatorObserveOn(Scheduler, boolean) - Constructor for class rx.internal.operators.OperatorObserveOn
- OperatorObserveOn(Scheduler, boolean, int) - Constructor for class rx.internal.operators.OperatorObserveOn
- OperatorObserveOn.ObserveOnSubscriber<T> - Class in rx.internal.operators
-
Observe through individual queue per observer.
- OperatorOnBackpressureBuffer<T> - Class in rx.internal.operators
- OperatorOnBackpressureBuffer() - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer
- OperatorOnBackpressureBuffer(long) - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer
-
Construct a new instance that will handle overflows with
ON_OVERFLOW_DEFAULT
, providing the following behavior config: - OperatorOnBackpressureBuffer(long, Action0) - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer
-
Construct a new instance that will handle overflows with
ON_OVERFLOW_DEFAULT
, providing the following behavior config: - OperatorOnBackpressureBuffer(long, Action0, BackpressureOverflow.Strategy) - Constructor for class rx.internal.operators.OperatorOnBackpressureBuffer
-
Construct a new instance feeding the following behavior config:
- OperatorOnBackpressureBuffer.BufferSubscriber<T> - Class in rx.internal.operators
- OperatorOnBackpressureBuffer.Holder - Class in rx.internal.operators
- OperatorOnBackpressureDrop<T> - Class in rx.internal.operators
- OperatorOnBackpressureDrop() - Constructor for class rx.internal.operators.OperatorOnBackpressureDrop
- OperatorOnBackpressureDrop(Action1<? super T>) - Constructor for class rx.internal.operators.OperatorOnBackpressureDrop
- OperatorOnBackpressureDrop.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorOnBackpressureLatest<T> - Class in rx.internal.operators
-
An operator which drops all but the last received value in case the downstream doesn't request more.
- OperatorOnBackpressureLatest() - Constructor for class rx.internal.operators.OperatorOnBackpressureLatest
- OperatorOnBackpressureLatest.Holder - Class in rx.internal.operators
-
Holds a singleton instance initialized on class-loading.
- OperatorOnBackpressureLatest.LatestEmitter<T> - Class in rx.internal.operators
-
A terminable producer which emits the latest items on request.
- OperatorOnBackpressureLatest.LatestSubscriber<T> - Class in rx.internal.operators
- OperatorOnErrorResumeNextViaFunction<T> - Class in rx.internal.operators
-
Instruct an Observable to pass control to another Observable (the return value of a function) rather than invoking
onError
if it encounters an error. - OperatorOnErrorResumeNextViaFunction(Func1<Throwable, ? extends Observable<? extends T>>) - Constructor for class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- OperatorPublish<T> - Class in rx.internal.operators
-
A connectable observable which shares an underlying source and dispatches source values to subscribers in a backpressure-aware manner.
- OperatorPublish(Observable.OnSubscribe<T>, Observable<? extends T>, AtomicReference<OperatorPublish.PublishSubscriber<T>>) - Constructor for class rx.internal.operators.OperatorPublish
- OperatorPublish.InnerProducer<T> - Class in rx.internal.operators
-
A Producer and Subscription that manages the request and unsubscription state of a child subscriber in thread-safe manner.
- OperatorPublish.PublishSubscriber<T> - Class in rx.internal.operators
- OperatorReplay<T> - Class in rx.internal.operators
- OperatorReplay(Observable.OnSubscribe<T>, Observable<? extends T>, AtomicReference<OperatorReplay.ReplaySubscriber<T>>, Func0<? extends OperatorReplay.ReplayBuffer<T>>) - Constructor for class rx.internal.operators.OperatorReplay
- OperatorReplay.BoundedReplayBuffer<T> - Class in rx.internal.operators
-
Base class for bounded buffering with options to specify an enter and leave transforms and custom truncation behavior.
- OperatorReplay.InnerProducer<T> - Class in rx.internal.operators
-
A Producer and Subscription that manages the request and unsubscription state of a child subscriber in thread-safe manner.
- OperatorReplay.Node - Class in rx.internal.operators
-
Represents a node in a bounded replay buffer's linked list.
- OperatorReplay.ReplayBuffer<T> - Interface in rx.internal.operators
-
The interface for interacting with various buffering logic.
- OperatorReplay.ReplaySubscriber<T> - Class in rx.internal.operators
- OperatorReplay.SizeAndTimeBoundReplayBuffer<T> - Class in rx.internal.operators
-
Size and time bound replay buffer.
- OperatorReplay.SizeBoundReplayBuffer<T> - Class in rx.internal.operators
-
A bounded replay buffer implementation with size limit only.
- OperatorReplay.UnboundedReplayBuffer<T> - Class in rx.internal.operators
-
Holds an unbounded list of events.
- OperatorRetryWithPredicate<T> - Class in rx.internal.operators
- OperatorRetryWithPredicate(Func2<Integer, Throwable, Boolean>) - Constructor for class rx.internal.operators.OperatorRetryWithPredicate
- OperatorRetryWithPredicate.SourceSubscriber<T> - Class in rx.internal.operators
- OperatorSampleWithObservable<T,U> - Class in rx.internal.operators
-
Sample with the help of another observable.
- OperatorSampleWithObservable(Observable<U>) - Constructor for class rx.internal.operators.OperatorSampleWithObservable
- OperatorSampleWithTime<T> - Class in rx.internal.operators
-
Returns an Observable that emits the results of sampling the items emitted by the source Observable at a specified time interval.
- OperatorSampleWithTime(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSampleWithTime
- OperatorSampleWithTime.SamplerSubscriber<T> - Class in rx.internal.operators
-
The source subscriber and sampler.
- OperatorScan<R,T> - Class in rx.internal.operators
-
Returns an Observable that applies a function to the first item emitted by a source Observable, then feeds the result of that function along with the second item emitted by an Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the result of each of these iterations.
- OperatorScan(R, Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OperatorScan
-
Applies an accumulator function over an observable sequence and returns each intermediate result with the specified source and accumulator.
- OperatorScan(Func0<R>, Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OperatorScan
- OperatorScan(Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OperatorScan
-
Applies an accumulator function over an observable sequence and returns each intermediate result with the specified source and accumulator.
- OperatorScan.InitialProducer<R> - Class in rx.internal.operators
- OperatorSequenceEqual - Class in rx.internal.operators
-
Returns an
Observable
that emits a singleBoolean
value that indicates whether two sourceObservable
s emit sequences of items that are equivalent to each other. - OperatorSequenceEqual() - Constructor for class rx.internal.operators.OperatorSequenceEqual
- OperatorSerialize<T> - Class in rx.internal.operators
- OperatorSerialize() - Constructor for class rx.internal.operators.OperatorSerialize
- OperatorSerialize.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorSingle<T> - Class in rx.internal.operators
-
If the Observable completes after emitting a single item that matches a predicate, return an Observable containing that item.
- OperatorSingle() - Constructor for class rx.internal.operators.OperatorSingle
- OperatorSingle(boolean, T) - Constructor for class rx.internal.operators.OperatorSingle
- OperatorSingle(T) - Constructor for class rx.internal.operators.OperatorSingle
- OperatorSingle.Holder - Class in rx.internal.operators
- OperatorSingle.ParentSubscriber<T> - Class in rx.internal.operators
- OperatorSkip<T> - Class in rx.internal.operators
-
Returns an Observable that skips the first
num
items emitted by the source Observable. - OperatorSkip(int) - Constructor for class rx.internal.operators.OperatorSkip
- OperatorSkipLast<T> - Class in rx.internal.operators
-
Bypasses a specified number of elements at the end of an observable sequence.
- OperatorSkipLast(int) - Constructor for class rx.internal.operators.OperatorSkipLast
- OperatorSkipLastTimed<T> - Class in rx.internal.operators
-
Skip delivering values in the time window before the values.
- OperatorSkipLastTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSkipLastTimed
- OperatorSkipTimed<T> - Class in rx.internal.operators
-
Skips elements until a specified time elapses.
- OperatorSkipTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorSkipTimed
- OperatorSkipUntil<T,U> - Class in rx.internal.operators
-
Skip elements from the source Observable until the secondary observable fires an element.
- OperatorSkipUntil(Observable<U>) - Constructor for class rx.internal.operators.OperatorSkipUntil
- OperatorSkipWhile<T> - Class in rx.internal.operators
-
Skips any emitted source items as long as the specified condition holds true.
- OperatorSkipWhile(Func2<? super T, Integer, Boolean>) - Constructor for class rx.internal.operators.OperatorSkipWhile
- OperatorSubscribeOn<T> - Class in rx.internal.operators
-
Subscribes Observers on the specified
Scheduler
. - OperatorSubscribeOn(Observable<T>, Scheduler) - Constructor for class rx.internal.operators.OperatorSubscribeOn
- OperatorSwitch<T> - Class in rx.internal.operators
-
Transforms an Observable that emits Observables into a single Observable that emits the items emitted by the most recently published of those Observables.
- OperatorSwitch(boolean) - Constructor for class rx.internal.operators.OperatorSwitch
- OperatorSwitch.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorSwitch.HolderDelayError - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorSwitch.InnerSubscriber<T> - Class in rx.internal.operators
- OperatorSwitch.SwitchSubscriber<T> - Class in rx.internal.operators
- OperatorSwitchIfEmpty<T> - Class in rx.internal.operators
-
If the Observable completes without emitting any items, subscribe to an alternate Observable.
- OperatorSwitchIfEmpty(Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorSwitchIfEmpty
- OperatorSwitchIfEmpty.AlternateSubscriber<T> - Class in rx.internal.operators
- OperatorSwitchIfEmpty.ParentSubscriber<T> - Class in rx.internal.operators
- OperatorTake<T> - Class in rx.internal.operators
-
An
Observable
that emits the firstnum
items emitted by the sourceObservable
. - OperatorTake(int) - Constructor for class rx.internal.operators.OperatorTake
- OperatorTakeLast<T> - Class in rx.internal.operators
-
Returns an Observable that emits the at most the last
count
items emitted by the source Observable. - OperatorTakeLast(int) - Constructor for class rx.internal.operators.OperatorTakeLast
- OperatorTakeLast.TakeLastSubscriber<T> - Class in rx.internal.operators
- OperatorTakeLastTimed<T> - Class in rx.internal.operators
-
Returns an Observable that emits the last
count
items emitted by the source Observable. - OperatorTakeLastTimed(int, long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeLastTimed
- OperatorTakeLastTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeLastTimed
- OperatorTakeLastTimed.TakeLastTimedSubscriber<T> - Class in rx.internal.operators
- OperatorTakeTimed<T> - Class in rx.internal.operators
-
Takes values from the source until the specific time elapses.
- OperatorTakeTimed(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeTimed
- OperatorTakeTimed.TakeSubscriber<T> - Class in rx.internal.operators
-
Subscribed to source and scheduled on a worker.
- OperatorTakeUntil<T,E> - Class in rx.internal.operators
-
Returns an Observable that emits the items from the source Observable until another Observable emits an item.
- OperatorTakeUntil(Observable<? extends E>) - Constructor for class rx.internal.operators.OperatorTakeUntil
- OperatorTakeUntilPredicate<T> - Class in rx.internal.operators
-
Returns an Observable that emits items emitted by the source Observable until the provided predicate returns false
- OperatorTakeUntilPredicate(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorTakeUntilPredicate
- OperatorTakeUntilPredicate.ParentSubscriber - Class in rx.internal.operators
-
Subscriber returned to the upstream.
- OperatorTakeWhile<T> - Class in rx.internal.operators
-
O Returns an Observable that emits items emitted by the source Observable as long as a specified condition is true.
- OperatorTakeWhile(Func1<? super T, Boolean>) - Constructor for class rx.internal.operators.OperatorTakeWhile
- OperatorTakeWhile(Func2<? super T, ? super Integer, Boolean>) - Constructor for class rx.internal.operators.OperatorTakeWhile
- OperatorThrottleFirst<T> - Class in rx.internal.operators
-
Throttle by windowing a stream and returning the first value in each window.
- OperatorThrottleFirst(long, TimeUnit, Scheduler) - Constructor for class rx.internal.operators.OperatorThrottleFirst
- OperatorTimeInterval<T> - Class in rx.internal.operators
-
Records the time interval between consecutive elements in an observable sequence.
- OperatorTimeInterval(Scheduler) - Constructor for class rx.internal.operators.OperatorTimeInterval
- OperatorTimeout<T> - Class in rx.internal.operators
-
Applies a timeout policy for each element in the observable sequence, using the specified scheduler to run timeout timers.
- OperatorTimeout(long, TimeUnit, Observable<? extends T>, Scheduler) - Constructor for class rx.internal.operators.OperatorTimeout
- OperatorTimeoutBase<T> - Class in rx.internal.operators
- OperatorTimeoutBase(OperatorTimeoutBase.FirstTimeoutStub<T>, OperatorTimeoutBase.TimeoutStub<T>, Observable<? extends T>, Scheduler) - Constructor for class rx.internal.operators.OperatorTimeoutBase
- OperatorTimeoutBase.FirstTimeoutStub<T> - Interface in rx.internal.operators
-
Set up the timeout action on the first value.
- OperatorTimeoutBase.TimeoutStub<T> - Interface in rx.internal.operators
-
Set up the timeout action based on every value
- OperatorTimeoutBase.TimeoutSubscriber<T> - Class in rx.internal.operators
- OperatorTimeoutWithSelector<T,U,V> - Class in rx.internal.operators
-
Returns an Observable that mirrors the source Observable.
- OperatorTimeoutWithSelector(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorTimeoutWithSelector
- OperatorTimestamp<T> - Class in rx.internal.operators
-
Wraps each item emitted by a source
Observable
in aTimestamped
object. - OperatorTimestamp(Scheduler) - Constructor for class rx.internal.operators.OperatorTimestamp
- OperatorToMap<T,K,V> - Class in rx.internal.operators
-
Maps the elements of the source observable into a java.util.Map instance and emits that once the source observable completes.
- OperatorToMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Constructor for class rx.internal.operators.OperatorToMap
-
ToMap with key selector, value selector and default HashMap factory.
- OperatorToMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Constructor for class rx.internal.operators.OperatorToMap
-
ToMap with key selector, value selector and custom Map factory.
- OperatorToMap.DefaultToMapFactory<K,V> - Class in rx.internal.operators
-
The default map factory.
- OperatorToMultimap<T,K,V> - Class in rx.internal.operators
-
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.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector, default HashMap factory and default ArrayList collection factory.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector, custom Map factory and default ArrayList collection factory.
- OperatorToMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Constructor for class rx.internal.operators.OperatorToMultimap
-
ToMultimap with key selector, custom value selector, custom Map factory and custom collection factory.
- OperatorToMultimap.DefaultMultimapCollectionFactory<K,V> - Class in rx.internal.operators
-
The default collection factory for a key in the multimap returning an ArrayList independent of the key.
- OperatorToMultimap.DefaultToMultimapFactory<K,V> - Class in rx.internal.operators
-
The default multimap factory returning a HashMap.
- OperatorToObservableList<T> - Class in rx.internal.operators
-
Returns an
Observable
that emits a single item, a list composed of all the items emitted by the sourceObservable
. - OperatorToObservableList() - Constructor for class rx.internal.operators.OperatorToObservableList
- OperatorToObservableList.Holder - Class in rx.internal.operators
-
Lazy initialization via inner-class holder.
- OperatorToObservableSortedList<T> - Class in rx.internal.operators
-
Return an
Observable
that emits the items emitted by the sourceObservable
, in a sorted order (each item emitted by theObservable
must implementComparable
with respect to all other items in the sequence, or you must pass in a sort function). - OperatorToObservableSortedList(int) - Constructor for class rx.internal.operators.OperatorToObservableSortedList
- OperatorToObservableSortedList(Func2<? super T, ? super T, Integer>, int) - Constructor for class rx.internal.operators.OperatorToObservableSortedList
- OperatorToObservableSortedList.DefaultComparableFunction - Class in rx.internal.operators
- OperatorUnsubscribeOn<T> - Class in rx.internal.operators
-
Unsubscribes on the specified Scheduler.
- OperatorUnsubscribeOn(Scheduler) - Constructor for class rx.internal.operators.OperatorUnsubscribeOn
- OperatorWindowWithObservable<T,U> - Class in rx.internal.operators
-
Creates non-overlapping windows of items where each window is terminated by an event from a secondary observable and a new window is started immediately.
- OperatorWindowWithObservable(Observable<U>) - Constructor for class rx.internal.operators.OperatorWindowWithObservable
- OperatorWindowWithObservable.BoundarySubscriber<T,U> - Class in rx.internal.operators
-
Observes the boundary.
- OperatorWindowWithObservable.SourceSubscriber<T> - Class in rx.internal.operators
-
Observes the source.
- OperatorWindowWithObservableFactory<T,U> - Class in rx.internal.operators
-
Creates non-overlapping windows of items where each window is terminated by an event from a secondary observable and a new window is started immediately.
- OperatorWindowWithObservableFactory(Func0<? extends Observable<? extends U>>) - Constructor for class rx.internal.operators.OperatorWindowWithObservableFactory
- OperatorWindowWithObservableFactory.BoundarySubscriber<T,U> - Class in rx.internal.operators
-
Observes the boundary.
- OperatorWindowWithObservableFactory.SourceSubscriber<T,U> - Class in rx.internal.operators
-
Observes the source.
- OperatorWindowWithSize<T> - Class in rx.internal.operators
-
Creates windows of values into the source sequence with skip frequency and size bounds.
- OperatorWindowWithSize(int, int) - Constructor for class rx.internal.operators.OperatorWindowWithSize
- OperatorWindowWithSize.WindowExact<T> - Class in rx.internal.operators
- OperatorWindowWithSize.WindowOverlap<T> - Class in rx.internal.operators
- OperatorWindowWithSize.WindowOverlap.WindowOverlapProducer - Class in rx.internal.operators
- OperatorWindowWithSize.WindowSkip<T> - Class in rx.internal.operators
- OperatorWindowWithSize.WindowSkip.WindowSkipProducer - Class in rx.internal.operators
- OperatorWindowWithStartEndObservable<T,U,V> - Class in rx.internal.operators
-
Creates potentially overlapping windows of the source items where each window is started by a value emitted by an observable and closed when an associated Observable emits a value or completes.
- OperatorWindowWithStartEndObservable(Observable<? extends U>, Func1<? super U, ? extends Observable<? extends V>>) - Constructor for class rx.internal.operators.OperatorWindowWithStartEndObservable
- OperatorWindowWithStartEndObservable.SerializedSubject<T> - Class in rx.internal.operators
-
Serialized access to the subject.
- OperatorWindowWithStartEndObservable.SourceSubscriber - Class in rx.internal.operators
- OperatorWindowWithTime<T> - Class in rx.internal.operators
-
Creates windows of values into the source sequence with timed window creation, length and size bounds.
- OperatorWindowWithTime(long, long, TimeUnit, int, Scheduler) - Constructor for class rx.internal.operators.OperatorWindowWithTime
- OperatorWindowWithTime.CountedSerializedSubject<T> - Class in rx.internal.operators
-
Record to store the subject and the emission count.
- OperatorWindowWithTime.ExactSubscriber - Class in rx.internal.operators
-
Subscriber with exact, non-overlapping windows.
- OperatorWindowWithTime.InexactSubscriber - Class in rx.internal.operators
-
Subscriber with inexact, potentially overlapping or discontinuous windows.
- OperatorWindowWithTime.State<T> - Class in rx.internal.operators
-
The immutable windowing state with one subject.
- OperatorWithLatestFrom<T,U,R> - Class in rx.internal.operators
-
Combines values from two sources only when the main source emits.
- OperatorWithLatestFrom(Observable<? extends U>, Func2<? super T, ? super U, ? extends R>) - Constructor for class rx.internal.operators.OperatorWithLatestFrom
- OperatorWithLatestFromMany<T,R> - Class in rx.internal.operators
- OperatorWithLatestFromMany(Observable<T>, Observable<?>[], Iterable<Observable<?>>, FuncN<R>) - Constructor for class rx.internal.operators.OperatorWithLatestFromMany
- OperatorWithLatestFromMany.WithLatestMainSubscriber<T,R> - Class in rx.internal.operators
- OperatorWithLatestFromMany.WithLatestOtherSubscriber - Class in rx.internal.operators
- OperatorZip<R> - Class in rx.internal.operators
-
Returns an Observable that emits the results of a function applied to sets of items emitted, in sequence, by two or more other Observables.
- OperatorZip(Func2) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func3) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func4) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func5) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func6) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func7) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func8) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(Func9) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip(FuncN<? extends R>) - Constructor for class rx.internal.operators.OperatorZip
- OperatorZip.Zip<R> - Class in rx.internal.operators
- OperatorZip.Zip.InnerSubscriber - Class in rx.internal.operators
- OperatorZip.ZipProducer<R> - Class in rx.internal.operators
- OperatorZip.ZipSubscriber - Class in rx.internal.operators
- OperatorZipIterable<T1,T2,R> - Class in rx.internal.operators
- OperatorZipIterable(Iterable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Constructor for class rx.internal.operators.OperatorZipIterable
- originalSingle - Variable in class rx.internal.operators.SingleOperatorOnErrorResumeNext
- other - Variable in class rx.internal.operators.CompletableOnSubscribeTimeout
- other - Variable in class rx.internal.operators.OnSubscribeDelaySubscriptionOther
- other - Variable in class rx.internal.operators.OperatorSkipUntil
- other - Variable in class rx.internal.operators.OperatorTakeUntil
- other - Variable in class rx.internal.operators.OperatorTimeoutBase
- other - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- other - Variable in class rx.internal.operators.OperatorWindowWithObservable
- other - Variable in class rx.internal.operators.OperatorWithLatestFrom
- other - Variable in class rx.internal.operators.SingleOnSubscribeDelaySubscriptionOther
- other - Variable in class rx.internal.util.InternalObservableUtils.EqualsWithFunc1
- otherFactory - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory
- otherFactory - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- others - Variable in class rx.internal.operators.OperatorWithLatestFromMany
- othersIterable - Variable in class rx.internal.operators.OperatorWithLatestFromMany
- outer - Variable in class rx.internal.operators.OperatorMapPair.OuterInnerMapper
- OuterInnerMapper(T, Func2<? super T, ? super U, ? extends R>) - Constructor for class rx.internal.operators.OperatorMapPair.OuterInnerMapper
- outstanding - Variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- overflowStrategy - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- overflowStrategy - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer
P
- P_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.MpmcArrayQueueProducerField
- P_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpmcArrayQueueProducerField
- P_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpscArrayQueueProducerFields
- P_INDEX_OFFSET - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- P_NODE_OFFSET - Static variable in class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- p0 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p00 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p00 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p00 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p00 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p01 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p01 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p01 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p01 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p02 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p02 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p02 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p02 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p03 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p03 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p03 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p03 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p04 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p04 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p04 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p04 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p05 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p05 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p05 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p05 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p06 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p06 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p06 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p06 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p07 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p07 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p07 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p07 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p1 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p10 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p10 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p10 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p10 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p11 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p11 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p11 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p11 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p12 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p12 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p12 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p12 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p13 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p13 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p13 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p14 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p14 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p14 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p15 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p15 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p15 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p16 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p16 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p16 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p2 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p20 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p20 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p20 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p20 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p21 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p21 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p21 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p21 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p22 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p22 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p22 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p22 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p23 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p23 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p23 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p23 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p24 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p24 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p24 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p24 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p25 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p25 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p25 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p25 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p26 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p26 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p26 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p26 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p3 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p30 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p30 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p30 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p30 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p30 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p30 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p30 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p30 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p30 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p30 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p30 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p30 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p30 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p30 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p31 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p31 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p31 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p31 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p31 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p31 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p31 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p31 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p31 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p31 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p31 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p31 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p31 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p31 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p32 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p32 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p32 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p32 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p32 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p32 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p32 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p32 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p32 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p32 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p32 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p32 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p32 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p32 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p33 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p33 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p33 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p33 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p33 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p33 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p33 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p33 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p33 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p33 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p33 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p33 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p33 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p33 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p34 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p34 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p34 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p34 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p34 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p34 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p34 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p34 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p34 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p34 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p34 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p34 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p34 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p34 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p35 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p35 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p35 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p35 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p35 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p35 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p35 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p35 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p35 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p35 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p35 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p35 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p35 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p35 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p36 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p36 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p36 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p36 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p36 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p36 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p36 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p36 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p36 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p36 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p36 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p36 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p36 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p36 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p37 - Variable in class rx.internal.util.unsafe.BaseLinkedQueue
- p37 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad0
- p37 - Variable in class rx.internal.util.unsafe.BaseLinkedQueuePad1
- p37 - Variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueueL0Pad
- p37 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p37 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL1Pad
- p37 - Variable in class rx.internal.util.unsafe.MpmcArrayQueueL2Pad
- p37 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- p37 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- p37 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p37 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- p37 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- p37 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- p37 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p4 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p40 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p40 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p40 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p41 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p41 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p41 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p42 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p42 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p42 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p43 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p43 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p43 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p44 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p44 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p44 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p45 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p45 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p45 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p46 - Variable in class rx.internal.util.unsafe.MpmcArrayQueue
- p46 - Variable in class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- p46 - Variable in class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- p5 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p6 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p7 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p8 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- p9 - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- pa - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- parent - Variable in class rx.internal.operators.DeferredScalarSubscriber.InnerProducer
- parent - Variable in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- parent - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerScalarProducer
- parent - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- parent - Variable in class rx.internal.operators.OnSubscribeDetach.DetachProducer
- parent - Variable in class rx.internal.operators.OnSubscribeLift
- parent - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
The subscriber that can be 'connected' to the upstream source.
- parent - Variable in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
-
The parent object to request draining or removal.
- parent - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- parent - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterProducer
- parent - Variable in class rx.internal.operators.OperatorGroupBy.GroupByProducer
- parent - Variable in class rx.internal.operators.OperatorGroupBy.State
- parent - Variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- parent - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- parent - Variable in class rx.internal.operators.OperatorPublish.InnerProducer
-
The parent subscriber-to-source used to allow removing the child in case of child unsubscription.
- parent - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
The parent subscriber-to-source used to allow removing the child in case of child unsubscription.
- parent - Variable in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- parent - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- parent - Variable in class rx.internal.schedulers.ScheduledAction.Remover
- parent - Variable in class rx.internal.schedulers.ScheduledAction.Remover2
- parent - Variable in class rx.Observable.OnSubscribeExtend
- parent - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- parent - Variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- parent - Variable in class rx.subscriptions.RefCountSubscription.InnerSubscription
- ParentSubscriber(OnSubscribePublishMulticast<T>) - Constructor for class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
- ParentSubscriber(Subscriber<? super Notification<T>>) - Constructor for class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- ParentSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- ParentSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorTakeUntilPredicate.ParentSubscriber
- ParentSubscriber(Subscriber<? super T>, boolean, T) - Constructor for class rx.internal.operators.OperatorSingle.ParentSubscriber
- ParentSubscriber(Subscriber<? super T>, SerialSubscription, ProducerArbiter, Observable<? extends T>) - Constructor for class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- peek() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- peek() - Method in class rx.internal.util.atomic.MpscLinkedAtomicQueue
- peek() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- peek() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- peek() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- peek() - Method in class rx.internal.util.atomic.SpscLinkedAtomicQueue
- peek() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- peek() - Method in interface rx.internal.util.BackpressureDrainManager.BackpressureQueueCallback
-
Override this method to peek for the next element, null meaning no next element available now.
- peek() - Method in class rx.internal.util.RxRingBuffer
- peek() - Method in class rx.internal.util.SynchronizedQueue
- peek() - Method in interface rx.internal.util.unsafe.MessagePassingQueue
-
Called from the consumer thread subject to the restrictions appropriate to the implementation and according to the
Queue.peek()
interface. - peek() - Method in class rx.internal.util.unsafe.MpmcArrayQueue
- peek() - Method in class rx.internal.util.unsafe.MpscLinkedQueue
- peek() - Method in class rx.internal.util.unsafe.SpmcArrayQueue
- peek() - Method in class rx.internal.util.unsafe.SpscArrayQueue
-
Called from the consumer thread subject to the restrictions appropriate to the implementation and according to the
Queue.peek()
interface. - peek() - Method in class rx.internal.util.unsafe.SpscLinkedQueue
- peek() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- period - Variable in class rx.internal.operators.OnSubscribeTimerPeriodically
- periodicTask - Variable in class rx.internal.util.ObjectPool
- PlatformDependent - Class in rx.internal.util
-
Allow platform dependent logic such as checks for Android.
- PlatformDependent() - Constructor for class rx.internal.util.PlatformDependent
-
Utility class.
- pluginError(Throwable) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- pluginError(Throwable) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- PlusOneFunc2() - Constructor for class rx.internal.util.InternalObservableUtils.PlusOneFunc2
- PlusOneLongFunc2() - Constructor for class rx.internal.util.InternalObservableUtils.PlusOneLongFunc2
- poll() - Method in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- poll() - Method in class rx.internal.util.atomic.MpscLinkedAtomicQueue
-
- poll() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- poll() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- poll() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- poll() - Method in class rx.internal.util.atomic.SpscLinkedAtomicQueue
-
IMPLEMENTATION NOTES:
Poll is allowed from a SINGLE thread.
Poll reads the next node from the consumerNode and: If it is null, the queue is empty. - poll() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- poll() - Method in interface rx.internal.util.BackpressureDrainManager.BackpressureQueueCallback
-
Override this method to poll (consume) the next element, null meaning no next element available now.
- poll() - Method in class rx.internal.util.RxRingBuffer
- poll() - Method in class rx.internal.util.SynchronizedQueue
- poll() - Method in interface rx.internal.util.unsafe.MessagePassingQueue
-
Called from the consumer thread subject to the restrictions appropriate to the implementation and according to the
Queue.poll()
interface. - poll() - Method in class rx.internal.util.unsafe.MpmcArrayQueue
-
Called from the consumer thread subject to the restrictions appropriate to the implementation and according to the
Queue.poll()
interface. - poll() - Method in class rx.internal.util.unsafe.MpscLinkedQueue
-
- poll() - Method in class rx.internal.util.unsafe.SpmcArrayQueue
- poll() - Method in class rx.internal.util.unsafe.SpscArrayQueue
-
Called from the consumer thread subject to the restrictions appropriate to the implementation and according to the
Queue.poll()
interface. - poll() - Method in class rx.internal.util.unsafe.SpscLinkedQueue
-
IMPLEMENTATION NOTES:
Poll is allowed from a SINGLE thread.
Poll reads the next node from the consumerNode and: If it is null, the queue is empty. - poll() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- pool - Variable in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- pool - Variable in class rx.internal.schedulers.CachedThreadScheduler
- pool - Variable in class rx.internal.schedulers.EventLoopsScheduler
- pool - Variable in class rx.internal.util.ObjectPool
- pool - Variable in class rx.internal.util.RxRingBuffer
- POOL - Static variable in class rx.internal.util.IndexedRingBuffer
- poolWorker - Variable in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- PoolWorker(ThreadFactory) - Constructor for class rx.internal.schedulers.EventLoopsScheduler.PoolWorker
- postCompleteDone(AtomicLong, Queue<T>, Subscriber<? super R>, Func1<? super T, ? extends R>) - Static method in class rx.internal.operators.BackpressureUtils
-
Signals the completion of the main sequence and switches to post-completion replay mode and allows exit transformation on the queued values.
- postCompleteDone(AtomicLong, Queue<T>, Subscriber<? super T>) - Static method in class rx.internal.operators.BackpressureUtils
-
Signals the completion of the main sequence and switches to post-completion replay mode.
- postCompleteDrain(AtomicLong, Queue<T>, Subscriber<? super R>, Func1<? super T, ? extends R>) - Static method in class rx.internal.operators.BackpressureUtils
-
Drains the queue based on the outstanding requests in post-completed mode (only!) and allows exit transformation on the queued values.
- postCompleteRequest(AtomicLong, long, Queue<T>, Subscriber<? super R>, Func1<? super T, ? extends R>) - Static method in class rx.internal.operators.BackpressureUtils
-
Accumulates requests (validated) and handles the completed mode draining of the queue based on the requests and allows exit transformation on the queued values.
- postCompleteRequest(AtomicLong, long, Queue<T>, Subscriber<? super T>) - Static method in class rx.internal.operators.BackpressureUtils
-
Accumulates requests (validated) and handles the completed mode draining of the queue based on the requests.
- Pow2 - Class in rx.internal.util.unsafe
- Pow2() - Constructor for class rx.internal.util.unsafe.Pow2
- predicate - Variable in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- predicate - Variable in class rx.internal.operators.OnSubscribeFilter
- predicate - Variable in class rx.internal.operators.OnSubscribeRedo.RetryWithPredicate
- predicate - Variable in class rx.internal.operators.OperatorAll
- predicate - Variable in class rx.internal.operators.OperatorAny
- predicate - Variable in class rx.internal.operators.OperatorRetryWithPredicate
- predicate - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- predicate - Variable in class rx.internal.operators.OperatorSkipWhile
- predicate - Variable in class rx.internal.operators.OperatorTakeWhile
- prefetch - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- prefetch - Variable in class rx.internal.operators.CompletableOnSubscribeConcat
- prefetch - Variable in class rx.internal.operators.OnSubscribeConcatMap
- prefetch - Variable in class rx.internal.operators.OnSubscribeFlattenIterable
- prefetch - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
The number of items to prefetch from the upstreams source.
- prefix - Variable in class rx.internal.util.RxThreadFactory
- Primitives() - Constructor for class rx.exceptions.OnErrorThrowable.OnNextValue.Primitives
- println(Object) - Method in class rx.exceptions.CompositeException.PrintStreamOrWriter
-
Prints the specified string as a line on this StreamOrWriter
- println(Object) - Method in class rx.exceptions.CompositeException.WrappedPrintStream
- println(Object) - Method in class rx.exceptions.CompositeException.WrappedPrintWriter
- printStackTrace() - Method in exception rx.exceptions.CompositeException
-
All of the following
printStackTrace
functionality is derived from JDKThrowable
printStackTrace
. - printStackTrace(PrintStream) - Method in exception rx.exceptions.CompositeException
- printStackTrace(PrintWriter) - Method in exception rx.exceptions.CompositeException
- printStackTrace(CompositeException.PrintStreamOrWriter) - Method in exception rx.exceptions.CompositeException
-
Special handling for printing out a
CompositeException
. - printStream - Variable in class rx.exceptions.CompositeException.WrappedPrintStream
- PrintStreamOrWriter() - Constructor for class rx.exceptions.CompositeException.PrintStreamOrWriter
- printWriter - Variable in class rx.exceptions.CompositeException.WrappedPrintWriter
- produced - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- produced - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- produced - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- produced - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- produced - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- produced(int) - Method in class rx.internal.operators.OperatorMerge.MergeProducer
- produced(long) - Method in class rx.internal.operators.CachedObservable.ReplayProducer
-
Updates the request count to reflect values have been produced.
- produced(long) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- produced(long) - Method in class rx.internal.operators.OperatorPublish.InnerProducer
-
Indicate that values have been emitted to this child subscriber by the dispatch() method.
- produced(long) - Method in class rx.internal.operators.OperatorReplay.InnerProducer
-
Indicate that values have been emitted to this child subscriber by the dispatch() method.
- produced(long) - Method in class rx.internal.producers.ProducerArbiter
- produced(AtomicLong, long) - Static method in class rx.internal.operators.BackpressureUtils
-
Atomically subtracts a value from the requested amount unless it's at Long.MAX_VALUE.
- producer - Variable in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- producer - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Holds the upstream producer if any, set through the parent subscriber.
- producer - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- producer - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- producer - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- producer - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- producer - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
The upstream producer.
- producer - Variable in class rx.internal.operators.OperatorScan.InitialProducer
-
The current producer.
- producer - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- producer - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
-
Accessed from the serialized part.
- producer - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
-
Accessed from the serialized part.
- producer - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable.SerializedSubject
- producer - Variable in class rx.internal.operators.OperatorWindowWithTime.CountedSerializedSubject
- producer - Variable in class rx.internal.operators.OperatorWindowWithTime.State
- producer - Variable in class rx.internal.operators.OperatorZip.ZipSubscriber
- producer - Variable in class rx.Subscriber
- Producer - Interface in rx
-
Interface that establishes a request-channel between an Observable and a Subscriber and allows the Subscriber to request a certain amount of items from the Observable (otherwise known as backpressure).
- ProducerArbiter - Class in rx.internal.producers
-
Producer that allows changing an underlying producer atomically and correctly resume with the accumulated requests.
- ProducerArbiter() - Constructor for class rx.internal.producers.ProducerArbiter
- producerBuffer - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- producerBuffer - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- producerBuffer - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerColdFields
- producerIndex - Variable in class rx.internal.util.atomic.SpscAtomicArrayQueue
- producerIndex - Variable in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- producerIndex - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- producerIndex - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- producerIndex - Variable in class rx.internal.util.unsafe.MpmcArrayQueueProducerField
- producerIndex - Variable in class rx.internal.util.unsafe.SpmcArrayQueueProducerField
- producerIndex - Variable in class rx.internal.util.unsafe.SpscArrayQueueProducerFields
- producerIndex - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerFields
- producerIndexCache - Variable in class rx.internal.util.unsafe.SpmcArrayQueueProducerIndexCacheField
- producerLookAhead - Variable in class rx.internal.util.atomic.SpscAtomicArrayQueue
- producerLookAhead - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- producerLookAhead - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- producerLookAhead - Variable in class rx.internal.util.unsafe.SpscArrayQueueProducerFields
- producerLookAhead - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerColdFields
- producerLookAheadStep - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- producerLookAheadStep - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- producerLookAheadStep - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerColdFields
- producerMask - Variable in class rx.internal.util.atomic.SpscLinkedArrayQueue
- producerMask - Variable in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- producerMask - Variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerColdFields
- producerNode - Variable in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- producerNode - Variable in class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- ProducerObserverArbiter<T> - Class in rx.internal.producers
-
Producer that serializes any event emission with requesting and producer changes.
- ProducerObserverArbiter(Subscriber<? super T>) - Constructor for class rx.internal.producers.ProducerObserverArbiter
- producers - Variable in class rx.internal.operators.CachedObservable.CacheState
-
Guarded by connection (not this).
- producers - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Tracks the subscribed producers.
- producers - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Tracks the subscribed producers.
- producersCache - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Contains a copy of the producers.
- producersCacheVersion - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Contains the number of modifications that the producersCache holds.
- producersVersion - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Contains number of modifications to the producers set.
- propagate(Throwable) - Static method in class rx.exceptions.Exceptions
-
Convenience method to throw a
RuntimeException
andError
directly or wrap any other exception type into aRuntimeException
. - publish() - Method in class rx.Observable
-
Returns a
ConnectableObservable
, which is a variety of Observable that waits until itsconnect
method is called before it begins emitting items to thoseObserver
s that have subscribed to it. - publish(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
-
Returns an Observable that emits the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the underlying sequence. - PublishProducer(Subscriber<? super T>, OnSubscribePublishMulticast<T>) - Constructor for class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
- PublishSubject<T> - Class in rx.subjects
-
Subject that, once an
Observer
has subscribed, emits all subsequently observed items to the subscriber. - PublishSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>) - Constructor for class rx.subjects.PublishSubject
- PublishSubscriber(AtomicReference<OperatorPublish.PublishSubscriber<T>>) - Constructor for class rx.internal.operators.OperatorPublish.PublishSubscriber
- PURGE - Static variable in class rx.internal.schedulers.NewThreadWorker
- PURGE_FORCE_KEY - Static variable in class rx.internal.schedulers.NewThreadWorker
-
Force the use of purge (true/false).
- PURGE_FREQUENCY - Static variable in class rx.internal.schedulers.NewThreadWorker
-
The purge frequency in milliseconds.
- PURGE_THREAD_PREFIX - Static variable in class rx.internal.schedulers.NewThreadWorker
- purgeExecutors() - Static method in class rx.internal.schedulers.NewThreadWorker
-
Purges each registered executor and eagerly evicts shutdown executors.
- pushRemovedIndex(int) - Method in class rx.internal.util.IndexedRingBuffer
Q
- queue - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- queue - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- queue - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- queue - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- queue - Variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- queue - Variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- queue - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
The prefetch queue holding onto a fixed amount of items until all all child subscribers have requested something.
- queue - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- queue - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- queue - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- queue - Variable in class rx.internal.operators.OperatorGroupBy.State
- queue - Variable in class rx.internal.operators.OperatorMerge.InnerSubscriber
- queue - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- queue - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- queue - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- queue - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Holds notifications from upstream.
- queue - Variable in class rx.internal.operators.OperatorScan.InitialProducer
- queue - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- queue - Variable in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- queue - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- queue - Variable in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
-
Guarded by guard.
- queue - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
-
Guarded by guard.
- queue - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- queue - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
-
Guarded by guard.
- queue - Variable in class rx.internal.producers.ProducerObserverArbiter
- queue - Variable in class rx.internal.producers.QueuedProducer
- queue - Variable in class rx.internal.producers.QueuedValueProducer
- queue - Variable in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- queue - Variable in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- queue - Variable in class rx.internal.util.RxRingBuffer
- queue - Variable in class rx.observers.SerializedObserver
-
If not null, it indicates more work.
- queue - Variable in class rx.schedulers.TestScheduler
- queue - Variable in class rx.subjects.SubjectSubscriptionManager.SubjectObserver
-
Guarded by this.
- queue - Variable in class rx.subjects.UnicastSubject.State
-
The queue holding values until the subscriber arrives and catches up.
- QueuedProducer<T> - Class in rx.internal.producers
-
Producer that holds an unbounded (or custom) queue, handles terminal events, enqueues values and relays them to a child subscriber on request.
- QueuedProducer(Subscriber<? super T>) - Constructor for class rx.internal.producers.QueuedProducer
-
Constructs an instance with the target child subscriber and an Spsc Linked (Atomic) Queue as the queue implementation.
- QueuedProducer(Subscriber<? super T>, Queue<Object>) - Constructor for class rx.internal.producers.QueuedProducer
-
Constructs an instance with the target child subscriber and a custom queue implementation
- QueuedValueProducer<T> - Class in rx.internal.producers
-
Producer that holds an unbounded (or custom) queue to enqueue values and relays them to a child subscriber on request.
- QueuedValueProducer(Subscriber<? super T>) - Constructor for class rx.internal.producers.QueuedValueProducer
-
Constructs an instance with the target child subscriber and an Spsc Linked (Atomic) Queue as the queue implementation.
- QueuedValueProducer(Subscriber<? super T>, Queue<Object>) - Constructor for class rx.internal.producers.QueuedValueProducer
-
Constructs an instance with the target child subscriber and a custom queue implementation
- QueueProgressIndicators - Interface in rx.internal.util.unsafe
-
This interface is provided for monitoring purposes only and is only available on queues where it is easy to provide it.
- queueScalar(OperatorMerge.InnerSubscriber<T>, T) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- queueScalar(T) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- queueTimes - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
R
- range(int, int) - Static method in class rx.Observable
-
Returns an Observable that emits a sequence of Integers within a specified range.
- range(int, int, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits a sequence of Integers within a specified range, on a specified Scheduler.
- RangeProducer(Subscriber<? super Integer>, int, int) - Constructor for class rx.internal.operators.OnSubscribeRange.RangeProducer
- ready - Variable in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- rebatch(int) - Static method in class rx.internal.operators.OperatorObserveOn
- rebatchRequests(int) - Method in class rx.Observable
-
Requests
n
initially from the upstream and then 75% ofn
subsequently after 75% ofn
values have been emitted to the downstream. - received - Variable in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- recursiveScheduler - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- redo(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
- REDO_INFINITE - Static variable in class rx.internal.operators.OnSubscribeRedo
- RedoFinite(long) - Constructor for class rx.internal.operators.OnSubscribeRedo.RedoFinite
- reduce(R, Func2<R, ? super T, R>) - Method in class rx.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable and a specified seed value, then feeds the result of that function along with the second item emitted by an Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the final result from the final call to your function as its sole item.
- reduce(Func2<T, T, T>) - Method in class rx.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, and emits the final result from the final call to your function as its sole item.
- reducer - Variable in class rx.internal.operators.OnSubscribeReduce
- reducer - Variable in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- reducer - Variable in class rx.internal.operators.OnSubscribeReduceSeed
- reducer - Variable in class rx.internal.operators.OnSubscribeReduceSeed.ReduceSeedSubscriber
- ReduceSeedSubscriber(Subscriber<? super R>, R, Func2<R, ? super T, R>) - Constructor for class rx.internal.operators.OnSubscribeReduceSeed.ReduceSeedSubscriber
- ReduceSubscriber(Subscriber<? super T>, Func2<T, T, T>) - Constructor for class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- ref - Variable in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- REF_ARRAY_BASE - Static variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- REF_ARRAY_BASE - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- REF_ELEMENT_SHIFT - Static variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- REF_ELEMENT_SHIFT - Static variable in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- refCount - Variable in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc
- refCount() - Method in class rx.observables.ConnectableObservable
-
Returns an
Observable
that stays connected to thisConnectableObservable
as long as there is at least one subscription to thisConnectableObservable
. - RefCountSubscription - Class in rx.subscriptions
-
Keeps track of the sub-subscriptions and unsubscribes the underlying subscription once all sub-subscriptions have unsubscribed.
- RefCountSubscription(Subscription) - Constructor for class rx.subscriptions.RefCountSubscription
-
Creates a
RefCountSubscription
by wrapping the given non-nullSubscription
. - RefCountSubscription.InnerSubscription - Class in rx.subscriptions
-
The individual sub-subscriptions.
- RefCountSubscription.State - Class in rx.subscriptions
- registerCompletableExecutionHook(RxJavaCompletableExecutionHook) - Method in class rx.plugins.RxJavaPlugins
-
Register an
RxJavaCompletableExecutionHook
implementation as a global override of any injected or default implementations. - registerErrorHandler(RxJavaErrorHandler) - Method in class rx.plugins.RxJavaPlugins
-
Registers an
RxJavaErrorHandler
implementation as a global override of any injected or default implementations. - registerExecutor(ScheduledThreadPoolExecutor) - Static method in class rx.internal.schedulers.NewThreadWorker
-
Registers the given executor service and starts the purge thread if not already started.
- registerObservableExecutionHook(RxJavaObservableExecutionHook) - Method in class rx.plugins.RxJavaPlugins
-
Register an
RxJavaObservableExecutionHook
implementation as a global override of any injected or default implementations. - registerSchedulersHook(RxJavaSchedulersHook) - Method in class rx.plugins.RxJavaPlugins
-
Registers an
RxJavaSchedulersHook
implementation as a global override of any injected or default implementations. - registerSingleExecutionHook(RxJavaSingleExecutionHook) - Method in class rx.plugins.RxJavaPlugins
-
Register an
RxJavaSingleExecutionHook
implementation as a global override of any injected or default implementations. - rehash() - Method in class rx.internal.util.OpenHashSet
- release() - Method in class rx.internal.util.RxRingBuffer
- release(CachedThreadScheduler.ThreadWorker) - Method in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- releaseToPool() - Method in class rx.internal.util.IndexedRingBuffer
-
This resets the arrays, nulls out references and returns it to the pool.
- remove() - Method in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- remove() - Method in class rx.internal.operators.BlockingOperatorNext.NextIterator
- remove() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- remove() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- remove() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- remove() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- remove() - Method in class rx.internal.util.SynchronizedQueue
- remove(int) - Method in class rx.internal.util.IndexedRingBuffer
- remove(Object) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- remove(Object) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- remove(Object) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- remove(Object) - Method in class rx.internal.util.SynchronizedQueue
- remove(OnSubscribePublishMulticast.PublishProducer<T>) - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Atomically removes the given wrapper, if present, from the subscribers array.
- remove(OperatorPublish.InnerProducer<T>) - Method in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Atomically removes the given producer from the producers array.
- remove(OperatorReplay.InnerProducer<T>) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Atomically removes the given producer from the producers array.
- remove(ReplaySubject.ReplayProducer<T>) - Method in class rx.subjects.ReplaySubject.ReplayState
- remove(SubjectSubscriptionManager.SubjectObserver) - Method in class rx.subjects.SubjectSubscriptionManager.State
- remove(SubjectSubscriptionManager.SubjectObserver<T>) - Method in class rx.subjects.SubjectSubscriptionManager
-
Atomically remove the specified SubjectObserver from the active observers.
- remove(Subscription) - Method in class rx.internal.util.SubscriptionList
- remove(Subscription) - Method in class rx.subscriptions.CompositeSubscription
- remove(T) - Method in class rx.internal.util.OpenHashSet
- removeAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- removeAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- removeAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- removeAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
- removeChild() - Method in class rx.subscriptions.RefCountSubscription.State
- removed - Variable in class rx.internal.util.IndexedRingBuffer
- removedIndex - Variable in class rx.internal.util.IndexedRingBuffer
- removeEntry(int, T[], int) - Method in class rx.internal.util.OpenHashSet
- removeFirst() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Remove the first node from the linked list.
- removeInner(OperatorMerge.InnerSubscriber<T>) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- removeProducer(CachedObservable.ReplayProducer<T>) - Method in class rx.internal.operators.CachedObservable.CacheState
-
Removes the ReplayProducer (if present) from the producers array atomically.
- Remover(ScheduledAction, CompositeSubscription) - Constructor for class rx.internal.schedulers.ScheduledAction.Remover
- Remover2(ScheduledAction, SubscriptionList) - Constructor for class rx.internal.schedulers.ScheduledAction.Remover2
- removeSome(int) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- render(Object) - Method in class rx.plugins.RxJavaErrorHandler
-
Override this method to provide rendering for specific types other than primitive types and null.
- renderValue(Object) - Static method in exception rx.exceptions.OnErrorThrowable.OnNextValue
-
Render the object if it is a basic type.
- repeat() - Method in class rx.Completable
-
Returns a Completable that repeatedly subscribes to this Completable until cancelled.
- repeat() - Method in class rx.Observable
-
Returns an Observable that repeats the sequence of items emitted by the source Observable indefinitely.
- repeat(long) - Method in class rx.Completable
-
Returns a Completable that subscribes repeatedly at most the given times to this Completable.
- repeat(long) - Method in class rx.Observable
-
Returns an Observable that repeats the sequence of items emitted by the source Observable at most
count
times. - repeat(long, Scheduler) - Method in class rx.Observable
-
Returns an Observable that repeats the sequence of items emitted by the source Observable at most
count
times, on a particular Scheduler. - repeat(Observable<T>) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Observable<T>, long) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Observable<T>, long, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Observable<T>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
- repeat(Scheduler) - Method in class rx.Observable
-
Returns an Observable that repeats the sequence of items emitted by the source Observable indefinitely, on a particular Scheduler.
- RepeatNotificationDematerializer(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Constructor for class rx.internal.util.InternalObservableUtils.RepeatNotificationDematerializer
- repeatWhen(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Method in class rx.Completable
-
Returns a Completable instance that repeats when the Publisher returned by the handler emits an item or completes when this Publisher emits a completed event.
- repeatWhen(Func1<? super Observable<? extends Void>, ? extends Observable<?>>) - Method in class rx.Observable
-
Returns an Observable that emits the same values as the source Observable with the exception of an
onCompleted
. - repeatWhen(Func1<? super Observable<? extends Void>, ? extends Observable<?>>, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits the same values as the source Observable with the exception of an
onCompleted
. - replaceSubject() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- replaceSubject() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- replaceSubject() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- replaceWindow() - Method in class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- replaceWindow() - Method in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- replay() - Method in class rx.internal.operators.CachedObservable.ReplayProducer
-
Continue replaying available values if there are requests for them.
- replay() - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Tries to replay the buffer contents to all known subscribers.
- replay() - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the underlying Observable that will replay all of its items and notifications to any futureObserver
. - replay() - Method in class rx.subjects.UnicastSubject.State
-
Tries to replay the contents of the queue.
- replay(int) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable that replays at mostbufferSize
items emitted by that Observable. - replay(int, long, TimeUnit) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable and replays at mostbufferSize
items that were emitted during a specified time window. - replay(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable and that replays a maximum ofbufferSize
items that are emitted within a specified time window. - replay(int, Scheduler) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable and replays at mostbufferSize
items emitted by that Observable. - replay(long, TimeUnit) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window. - replay(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable and replays all items emitted by that Observable within a specified time window. - replay(Func1<? super Observable<T>, ? extends Observable<R>>) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on the items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, int) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replayingbufferSize
notifications. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replaying no more thanbufferSize
items that were emitted within a specified time window. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replaying no more thanbufferSize
items that were emitted within a specified time window. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, int, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replaying a maximum ofbufferSize
items. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable, replaying all items that were emitted within a specified time window. - replay(Func1<? super Observable<T>, ? extends Observable<R>>, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits items that are the results of invoking a specified selector on items emitted by a
ConnectableObservable
that shares a single subscription to the source Observable. - replay(OperatorReplay.InnerProducer<T>) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- replay(OperatorReplay.InnerProducer<T>) - Method in interface rx.internal.operators.OperatorReplay.ReplayBuffer
-
Tries to replay the buffered values to the subscriber inside the output if there is new value and requests available at the same time.
- replay(OperatorReplay.InnerProducer<T>) - Method in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- replay(Scheduler) - Method in class rx.Observable
-
Returns a
ConnectableObservable
that shares a single subscription to the source Observable that will replay all of its items and notifications to any futureObserver
on the givenScheduler
. - ReplayProducer(Subscriber<? super T>, CachedObservable.CacheState<T>) - Constructor for class rx.internal.operators.CachedObservable.ReplayProducer
- ReplayProducer(Subscriber<? super T>, ReplaySubject.ReplayState<T>) - Constructor for class rx.subjects.ReplaySubject.ReplayProducer
- ReplaySizeAndTimeBoundBuffer(int, long, Scheduler) - Constructor for class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- ReplaySizeBoundBuffer(int) - Constructor for class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- ReplayState(ReplaySubject.ReplayBuffer<T>) - Constructor for class rx.subjects.ReplaySubject.ReplayState
- ReplaySubject<T> - Class in rx.subjects
-
Subject that buffers all items it observes and replays them to any
Observer
that subscribes. - ReplaySubject(ReplaySubject.ReplayState<T>) - Constructor for class rx.subjects.ReplaySubject
- ReplaySubject.ReplayBuffer<T> - Interface in rx.subjects
-
The base interface for buffering signals to be replayed to individual Subscribers.
- ReplaySubject.ReplayProducer<T> - Class in rx.subjects
-
A producer and subscription implementation that tracks the current replay position of a particular subscriber.
- ReplaySubject.ReplaySizeAndTimeBoundBuffer<T> - Class in rx.subjects
- ReplaySubject.ReplaySizeAndTimeBoundBuffer.TimedNode<T> - Class in rx.subjects
- ReplaySubject.ReplaySizeBoundBuffer<T> - Class in rx.subjects
- ReplaySubject.ReplaySizeBoundBuffer.Node<T> - Class in rx.subjects
- ReplaySubject.ReplayState<T> - Class in rx.subjects
-
Holds onto the array of Subscriber-wrapping ReplayProducers and the buffer that holds values to be replayed; it manages subscription and signal dispatching.
- ReplaySubject.ReplayUnboundedBuffer<T> - Class in rx.subjects
-
An unbounded ReplayBuffer implementation that uses linked-arrays to avoid copy-on-grow situation with ArrayList.
- ReplaySubscriber(OperatorReplay.ReplayBuffer<T>) - Constructor for class rx.internal.operators.OperatorReplay.ReplaySubscriber
- ReplaySupplierBuffer(Observable<T>, int) - Constructor for class rx.internal.util.InternalObservableUtils.ReplaySupplierBuffer
- ReplaySupplierBufferTime(Observable<T>, long, TimeUnit, Scheduler) - Constructor for class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- ReplaySupplierNoParams(Observable<T>) - Constructor for class rx.internal.util.InternalObservableUtils.ReplaySupplierNoParams
- ReplaySupplierTime(Observable<T>, int, long, TimeUnit, Scheduler) - Constructor for class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- ReplayUnboundedBuffer(int) - Constructor for class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- reportError() - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- request - Variable in class rx.internal.operators.OperatorDoOnRequest
- request(long) - Method in class rx.internal.operators.CachedObservable.ReplayProducer
- request(long) - Method in class rx.internal.operators.DeferredScalarSubscriber.InnerProducer
- request(long) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- request(long) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerScalarProducer
- request(long) - Method in class rx.internal.operators.OnSubscribeDetach.DetachProducer
- request(long) - Method in enum rx.internal.operators.OnSubscribeDetach.TerminatedProducer
- request(long) - Method in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- request(long) - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- request(long) - Method in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- request(long) - Method in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
- request(long) - Method in class rx.internal.operators.OnSubscribeRange.RangeProducer
- request(long) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap.BufferOverlapProducer
- request(long) - Method in class rx.internal.operators.OperatorBufferWithSize.BufferSkip.BufferSkipProducer
- request(long) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterProducer
- request(long) - Method in class rx.internal.operators.OperatorElementAt.InnerProducer
- request(long) - Method in class rx.internal.operators.OperatorGroupBy.GroupByProducer
- request(long) - Method in class rx.internal.operators.OperatorGroupBy.State
- request(long) - Method in class rx.internal.operators.OperatorMerge.MergeProducer
- request(long) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- request(long) - Method in class rx.internal.operators.OperatorPublish.InnerProducer
- request(long) - Method in class rx.internal.operators.OperatorReplay.InnerProducer
- request(long) - Method in class rx.internal.operators.OperatorScan.InitialProducer
- request(long) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap.WindowOverlapProducer
- request(long) - Method in class rx.internal.operators.OperatorWindowWithSize.WindowSkip.WindowSkipProducer
- request(long) - Method in class rx.internal.operators.OperatorZip.ZipProducer
- request(long) - Method in class rx.internal.producers.ProducerArbiter
- request(long) - Method in class rx.internal.producers.ProducerObserverArbiter
- request(long) - Method in class rx.internal.producers.QueuedProducer
- request(long) - Method in class rx.internal.producers.QueuedValueProducer
- request(long) - Method in class rx.internal.producers.SingleDelayedProducer
- request(long) - Method in class rx.internal.producers.SingleProducer
- request(long) - Method in class rx.internal.util.BackpressureDrainManager
- request(long) - Method in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- request(long) - Method in class rx.internal.util.ScalarSynchronousObservable.WeakSingleProducer
- request(long) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- request(long) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- request(long) - Method in interface rx.Producer
-
Request a certain maximum number of items from this Producer.
- request(long) - Method in class rx.subjects.ReplaySubject.ReplayProducer
- request(long) - Method in class rx.subjects.UnicastSubject.State
- request(long) - Method in class rx.Subscriber
-
Request a certain maximum number of emitted items from the Observable this Subscriber is subscribed to.
- requested - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- requested - Variable in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- requested - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- requested - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- requested - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- requested - Variable in class rx.internal.operators.OperatorGroupBy.State
- requested - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- requested - Variable in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- requested - Variable in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- requested - Variable in class rx.internal.operators.OperatorScan.InitialProducer
-
The current requested amount.
- requested - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- requested - Variable in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- requested - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- requested - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- requested - Variable in class rx.internal.operators.OperatorZip.Zip
- requested - Variable in class rx.internal.producers.ProducerArbiter
- requested - Variable in class rx.internal.producers.ProducerObserverArbiter
- requested - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
Holds the current requested amount.
- requested - Variable in class rx.Subscriber
- requested() - Method in interface rx.AsyncEmitter
-
The current outstanding request amount.
- requested() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- REQUESTED_MASK - Static variable in class rx.internal.operators.BackpressureUtils
-
Masks the request amount bits, i.e., 0x7FFF_FFFF_FFFF_FFFF.
- REQUESTED_MASK - Static variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- requestInner(long) - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- requestMore(long) - Method in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- requestMore(long) - Method in class rx.internal.operators.OnSubscribeCombineLatest.CombinerSubscriber
- requestMore(long) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- requestMore(long) - Method in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorDoOnRequest.ParentSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorEagerConcatMap.EagerInnerSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorMerge.InnerSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- requestMore(long) - Method in class rx.internal.operators.OperatorZip.Zip.InnerSubscriber
- requestMore(long) - Method in class rx.observers.TestSubscriber
-
Allows calling the protected
Subscriber.request(long)
from unit tests. - requestRemaining(long) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
-
Called when a source has produced less than its provision (completed prematurely); this will trigger the generation of another source that will hopefully emit the missing amount.
- requests - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- requireNonNull(T) - Static method in class rx.Completable
-
Java 7 backport: throws a NullPointerException if o is null.
- reset() - Static method in class rx.plugins.RxJavaHooks
-
Reset all hook callbacks to those of the current RxJavaPlugins handlers.
- reset() - Method in class rx.plugins.RxJavaPlugins
-
Reset
RxJavaPlugins
instance - reset() - Static method in class rx.schedulers.Schedulers
-
Resets the current
Schedulers
instance. - resetAssemblyTracking() - Static method in class rx.plugins.RxJavaHooks
-
Resets the assembly tracking hooks to their default delegates to RxJavaPlugins.
- resize(E[], long, long, E, long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- resize(AtomicReferenceArray<Object>, long, int, T, long) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- resize(AtomicReferenceArray<Object>, long, int, T, long) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- resolveAndroidApiVersion() - Static method in class rx.internal.util.PlatformDependent
-
Resolves version of Android API.
- resource - Variable in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- resourceFactory - Variable in class rx.internal.operators.OnSubscribeUsing
- resourceFactory - Variable in class rx.internal.operators.SingleOnSubscribeUsing
- resultFactory - Variable in class rx.internal.operators.OnSubscribeFromCallable
- ResultManager(Subscriber<? super R>) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- resultSelector - Variable in class rx.internal.operators.OnSubscribeGroupJoin
- resultSelector - Variable in class rx.internal.operators.OnSubscribeJoin
- resultSelector - Variable in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- resultSelector - Variable in class rx.internal.operators.OperatorMapPair.OuterInnerMapper
- resultSelector - Variable in class rx.internal.operators.OperatorMapPair
- resultSelector - Variable in class rx.internal.operators.OperatorWithLatestFrom
- ResultSink(Subscriber<? super R>) - Constructor for class rx.internal.operators.OnSubscribeJoin.ResultSink
- resumeFunction - Variable in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- resumeFunctionInCaseOfError - Variable in class rx.internal.operators.SingleOperatorOnErrorResumeNext
- retainAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- retainAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- retainAll(Collection<?>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- retainAll(Collection<?>) - Method in class rx.internal.util.SynchronizedQueue
- retry() - Method in class rx.Completable
-
Returns a Completable that retries this Completable as long as it emits an onError event.
- retry() - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls
onError
(infinite retry count). - retry() - Method in class rx.Single
-
Returns a Single that mirrors the source Single, resubscribing to it if it calls
onError
(infinite retry count). - retry(long) - Method in class rx.Completable
-
Returns a Completable that when this Completable emits an error, retries at most the given number of times before giving up and emitting the last error.
- retry(long) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls
onError
up to a specified number of retries. - retry(long) - Method in class rx.Single
-
Returns an Single that mirrors the source Single, resubscribing to it if it calls
onError
up to a specified number of retries. - retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.Completable
-
Returns a Completable that retries this Completable in case of an error as long as the predicate returns true.
- retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, resubscribing to it if it calls
onError
and the predicate returns true for that specific exception and retry count. - retry(Func2<Integer, Throwable, Boolean>) - Method in class rx.Single
-
Returns an Single that mirrors the source Single, resubscribing to it if it calls
onError
and the predicate returns true for that specific exception and retry count. - retry(Observable<T>) - Static method in class rx.internal.operators.OnSubscribeRedo
- retry(Observable<T>, long) - Static method in class rx.internal.operators.OnSubscribeRedo
- retry(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>) - Static method in class rx.internal.operators.OnSubscribeRedo
- retry(Observable<T>, Func1<? super Observable<? extends Notification<?>>, ? extends Observable<?>>, Scheduler) - Static method in class rx.internal.operators.OnSubscribeRedo
- RetryNotificationDematerializer(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Constructor for class rx.internal.util.InternalObservableUtils.RetryNotificationDematerializer
- retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Completable
-
Returns a Completable which given a Publisher and when this Completable emits an error, delivers that error through an Observable and the Publisher should return a value indicating a retry in response or a terminal event indicating a termination.
- retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Observable
-
Returns an Observable that emits the same values as the source observable with the exception of an
onError
. - retryWhen(Func1<? super Observable<? extends Throwable>, ? extends Observable<?>>, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits the same values as the source observable with the exception of an
onError
. - retryWhen(Func1<Observable<? extends Throwable>, ? extends Observable<?>>) - Method in class rx.Single
-
Returns a Single that emits the same values as the source Single with the exception of an
onError
. - RetryWithPredicate(Func2<Integer, Throwable, Boolean>) - Constructor for class rx.internal.operators.OnSubscribeRedo.RetryWithPredicate
- returnObject(T) - Method in class rx.internal.util.ObjectPool
-
Returns object back to the pool.
- returnOnEmpty - Variable in class rx.internal.operators.OperatorAny
- RETURNS_VOID - Static variable in enum rx.internal.util.InternalObservableUtils
- ReturnsVoidFunc1() - Constructor for class rx.internal.util.InternalObservableUtils.ReturnsVoidFunc1
- right - Variable in class rx.internal.operators.OnSubscribeGroupJoin
- right - Variable in class rx.internal.operators.OnSubscribeJoin
- rightDone - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- rightDone - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- rightDuration - Variable in class rx.internal.operators.OnSubscribeGroupJoin
- RightDurationObserver(int) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightDurationObserver
- rightDurationSelector - Variable in class rx.internal.operators.OnSubscribeJoin
- RightDurationSubscriber(int) - Constructor for class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber.RightDurationSubscriber
- rightId - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- rightIds - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- rightMap - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
-
Guarded by guard.
- rightMap - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
-
Guarded by guard.
- RightObserver() - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.ResultManager.RightObserver
- RightSubscriber() - Constructor for class rx.internal.operators.OnSubscribeJoin.ResultSink.RightSubscriber
- roundRobin - Static variable in class rx.internal.schedulers.GenericScheduledExecutorService
-
We don't use atomics with this because thread-assignment is random anyway.
- roundToPowerOfTwo(int) - Static method in class rx.internal.util.unsafe.Pow2
-
Find the next larger positive power of two value up from the given value.
- run() - Method in class rx.internal.operators.OnSubscribeJoin.ResultSink
- run() - Method in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- run() - Method in class rx.internal.schedulers.ScheduledAction
- rx - package rx
-
Base reactive classes: Observable, Single and Completable; base reactive consumers; other common base interfaces.
- rx.annotations - package rx.annotations
-
Annotations for indicating experimental and beta operators, classes, methods, types or fields.
- rx.exceptions - package rx.exceptions
-
Exception handling utilities, safe subscriber exception classes, lifecycle exception classes.
- rx.functions - package rx.functions
-
Functional interfaces of functions and actions of arity 0 to 9 and related utility classes.
- rx.internal.operators - package rx.internal.operators
-
Operators that allow composing Observables to transform and manipulate data in an asynchronous, functional and thread-safe manner.
- rx.internal.producers - package rx.internal.producers
- rx.internal.schedulers - package rx.internal.schedulers
- rx.internal.util - package rx.internal.util
- rx.internal.util.atomic - package rx.internal.util.atomic
- rx.internal.util.unsafe - package rx.internal.util.unsafe
- rx.observables - package rx.observables
-
Classes extending the Observable base reactive class, synchronous and asynchronous event generators.
- rx.observers - package rx.observers
-
Default wrappers and implementations for the base reactive consumer classes and interfaces; utility classes for creating them from callbacks.
- rx.plugins - package rx.plugins
-
Callback types and a central plugin handler class to hook into the lifecycle of the base reactive types and schedulers.
- rx.schedulers - package rx.schedulers
-
Scheduler implementations, value+time record classes and the standard factory class to return standard RxJava schedulers or wrap any Executor-based (thread pool) instances.
- rx.singles - package rx.singles
-
Classes extending the Single base reactive class.
- rx.subjects - package rx.subjects
-
Classes extending the Observable base reactive class and implementing the Observer interface at the same time (aka hot Observables).
- rx.subscriptions - package rx.subscriptions
-
Default implementations for Subscription-based resource management (Subscription container types) and utility classes to construct Subscriptions from callbacks and other types.
- RxJavaCompletableExecutionHook - Class in rx.plugins
-
Abstract ExecutionHook with invocations at different lifecycle points of
Completable
execution with a default no-op implementation. - RxJavaCompletableExecutionHook() - Constructor for class rx.plugins.RxJavaCompletableExecutionHook
- RxJavaErrorHandler - Class in rx.plugins
-
Abstract class for defining error handling logic in addition to the normal
onError(Throwable)
behavior. - RxJavaErrorHandler() - Constructor for class rx.plugins.RxJavaErrorHandler
- RxJavaHooks - Class in rx.plugins
-
Utility class that holds hooks for various Observable, Single and Completable lifecycle-related points as well as Scheduler hooks.
- RxJavaHooks() - Constructor for class rx.plugins.RxJavaHooks
-
Utility class.
- RxJavaObservableExecutionHook - Class in rx.plugins
-
Abstract ExecutionHook with invocations at different lifecycle points of
Observable
execution with a default no-op implementation. - RxJavaObservableExecutionHook() - Constructor for class rx.plugins.RxJavaObservableExecutionHook
- RxJavaObservableExecutionHookDefault - Class in rx.plugins
-
Default no-op implementation of
RxJavaObservableExecutionHook
- RxJavaObservableExecutionHookDefault() - Constructor for class rx.plugins.RxJavaObservableExecutionHookDefault
-
Utility class.
- RxJavaPlugins - Class in rx.plugins
-
Registry for plugin implementations that allows global override and handles the retrieval of correct implementation based on order of precedence: plugin registered globally via
register
methods in this class plugin registered and retrieved usingSystem.getProperty(String)
(see get methods for property names) default implementation - RxJavaPlugins() - Constructor for class rx.plugins.RxJavaPlugins
- RxJavaSchedulersHook - Class in rx.plugins
-
This plugin class provides 2 ways to customize
Scheduler
functionality 1. - RxJavaSchedulersHook() - Constructor for class rx.plugins.RxJavaSchedulersHook
- RxJavaSingleExecutionHook - Class in rx.plugins
-
Abstract ExecutionHook with invocations at different lifecycle points of
Single
execution with a default no-op implementation. - RxJavaSingleExecutionHook() - Constructor for class rx.plugins.RxJavaSingleExecutionHook
- RxJavaSingleExecutionHookDefault - Class in rx.plugins
-
Default no-op implementation of
RxJavaSingleExecutionHook
- RxJavaSingleExecutionHookDefault() - Constructor for class rx.plugins.RxJavaSingleExecutionHookDefault
-
Utility class.
- RxRingBuffer - Class in rx.internal.util
-
This assumes Spsc or Spmc usage.
- RxRingBuffer() - Constructor for class rx.internal.util.RxRingBuffer
- RxRingBuffer(Queue<Object>, int) - Constructor for class rx.internal.util.RxRingBuffer
- RxRingBuffer(ObjectPool<Queue<Object>>, int) - Constructor for class rx.internal.util.RxRingBuffer
- RxThreadFactory - Class in rx.internal.util
- RxThreadFactory(String) - Constructor for class rx.internal.util.RxThreadFactory
S
- s - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- s - Variable in class rx.internal.schedulers.ScheduledAction.Remover
- s - Variable in class rx.internal.schedulers.ScheduledAction.Remover2
- s - Variable in class rx.observers.SafeCompletableSubscriber
- s - Variable in class rx.observers.SerializedSubscriber
- s - Variable in class rx.schedulers.TestScheduler.InnerTestScheduler
- SafeCompletableSubscriber - Class in rx.observers
-
Wraps another CompletableSubscriber and handles exceptions thrown from onError and onCompleted.
- SafeCompletableSubscriber(Completable.CompletableSubscriber) - Constructor for class rx.observers.SafeCompletableSubscriber
- SafeSubscriber<T> - Class in rx.observers
-
SafeSubscriber
is a wrapper aroundSubscriber
that ensures that theSubscriber
complies with the Observable contract. - SafeSubscriber(Subscriber<? super T>) - Constructor for class rx.observers.SafeSubscriber
- sample(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits the most recently emitted item (if any) emitted by the source Observable within periodic time intervals.
- sample(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits the most recently emitted item (if any) emitted by the source Observable within periodic time intervals, where the intervals are defined on a particular Scheduler.
- sample(Observable<U>) - Method in class rx.Observable
-
Returns an Observable that, when the specified
sampler
Observable emits an item or completes, emits the most recently emitted item (if any) emitted by the source Observable since the previous emission from thesampler
Observable. - sampler - Variable in class rx.internal.operators.OperatorSampleWithObservable
- SamplerSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- saturated - Variable in class rx.internal.operators.OperatorOnBackpressureBuffer.BufferSubscriber
- ScalarAsyncOnSubscribe(T, Func1<Action0, Subscription>) - Constructor for class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncOnSubscribe
- ScalarAsyncProducer(Subscriber<? super T>, T, Func1<Action0, Subscription>) - Constructor for class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- scalarEmissionCount - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- scalarEmissionLimit - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
- scalarFlatMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.internal.util.ScalarSynchronousObservable
-
Given this scalar source as input to a flatMap, avoid one step of subscription and subscribes to the single Observable returned by the function.
- scalarFlatMap(Func1<? super T, ? extends Single<? extends R>>) - Method in class rx.internal.util.ScalarSynchronousSingle
- scalarScheduleOn(Scheduler) - Method in class rx.internal.util.ScalarSynchronousObservable
-
Customized observeOn/subscribeOn implementation which emits the scalar value directly or with less overhead on the specified scheduler.
- scalarScheduleOn(Scheduler) - Method in class rx.internal.util.ScalarSynchronousSingle
-
Customized observeOn/subscribeOn implementation which emits the scalar value directly or with less overhead on the specified scheduler.
- ScalarSynchronousObservable<T> - Class in rx.internal.util
-
An Observable that emits a single constant scalar value to Subscribers.
- ScalarSynchronousObservable(T) - Constructor for class rx.internal.util.ScalarSynchronousObservable
- ScalarSynchronousObservable.JustOnSubscribe<T> - Class in rx.internal.util
-
The OnSubscribe callback for the Observable constructor.
- ScalarSynchronousObservable.ScalarAsyncOnSubscribe<T> - Class in rx.internal.util
-
The OnSubscribe implementation that creates the ScalarAsyncProducer for each incoming subscriber.
- ScalarSynchronousObservable.ScalarAsyncProducer<T> - Class in rx.internal.util
-
Represents a producer which schedules the emission of a scalar value on the first positive request via the given scheduler callback.
- ScalarSynchronousObservable.WeakSingleProducer<T> - Class in rx.internal.util
-
This is the weak version of SingleProducer that uses plain fields to avoid reentrancy and as such is not threadsafe for concurrent request() calls.
- ScalarSynchronousSingle<T> - Class in rx.internal.util
- ScalarSynchronousSingle(T) - Constructor for class rx.internal.util.ScalarSynchronousSingle
- ScalarSynchronousSingle.DirectScheduledEmission<T> - Class in rx.internal.util
-
Optimized observeOn for scalar value observed on the EventLoopsScheduler.
- ScalarSynchronousSingle.NormalScheduledEmission<T> - Class in rx.internal.util
-
Emits a scalar value on a general scheduler.
- ScalarSynchronousSingle.ScalarSynchronousSingleAction<T> - Class in rx.internal.util
-
Action that emits a single value when called.
- ScalarSynchronousSingleAction(SingleSubscriber<? super T>, T) - Constructor for class rx.internal.util.ScalarSynchronousSingle.ScalarSynchronousSingleAction
- scan(R, Func2<R, ? super T, R>) - Method in class rx.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable and a seed value, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the result of each of these iterations.
- scan(Func2<T, T, T>) - Method in class rx.Observable
-
Returns an Observable that applies a specified accumulator function to the first item emitted by a source Observable, then feeds the result of that function along with the second item emitted by the source Observable into the same function, and so on until all items have been emitted by the source Observable, emitting the result of each of these iterations.
- schedule() - Method in class rx.internal.operators.OperatorObserveOn.ObserveOnSubscriber
- schedule(Action0) - Method in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- schedule(Action0) - Method in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- schedule(Action0) - Method in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- schedule(Action0) - Method in class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- schedule(Action0) - Method in class rx.internal.schedulers.NewThreadWorker
- schedule(Action0) - Method in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- schedule(Action0) - Method in class rx.Scheduler.Worker
-
Schedules an Action for execution.
- schedule(Action0) - Method in class rx.schedulers.TestScheduler.InnerTestScheduler
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.NewThreadWorker
- schedule(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- schedule(Action0, long, TimeUnit) - Method in class rx.Scheduler.Worker
-
Schedules an Action for execution at some point in the future.
- schedule(Action0, long, TimeUnit) - Method in class rx.schedulers.TestScheduler.InnerTestScheduler
- scheduleActual(Action0, long, TimeUnit) - Method in class rx.internal.schedulers.NewThreadWorker
-
Schedules the given action by wrapping it into a ScheduledAction on the underlying ExecutorService, returning the ScheduledAction.
- scheduleActual(Action0, long, TimeUnit, SubscriptionList) - Method in class rx.internal.schedulers.NewThreadWorker
- scheduleActual(Action0, long, TimeUnit, CompositeSubscription) - Method in class rx.internal.schedulers.NewThreadWorker
- scheduleChunk() - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- scheduleChunk() - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- ScheduledAction - Class in rx.internal.schedulers
-
A
Runnable
that executes anAction0
and can be cancelled. - ScheduledAction() - Constructor for class rx.internal.schedulers.SchedulerWhen.ScheduledAction
- ScheduledAction(Action0) - Constructor for class rx.internal.schedulers.ScheduledAction
- ScheduledAction(Action0, SubscriptionList) - Constructor for class rx.internal.schedulers.ScheduledAction
- ScheduledAction(Action0, CompositeSubscription) - Constructor for class rx.internal.schedulers.ScheduledAction
- ScheduledAction.FutureCompleter - Class in rx.internal.schedulers
-
Cancels the captured future if the caller of the call method is not the same as the runner of the outer ScheduledAction to prevent unnecessary self-interrupting if the unsubscription happens from the same thread.
- ScheduledAction.Remover - Class in rx.internal.schedulers
-
Remove a child subscription from a composite when unsubscribing.
- ScheduledAction.Remover2 - Class in rx.internal.schedulers
-
Remove a child subscription from a composite when unsubscribing.
- scheduleDirect(Action0) - Method in class rx.internal.schedulers.EventLoopsScheduler
-
Schedules the action directly on one of the event loop workers without the additional infrastructure and checking.
- scheduleExact() - Method in class rx.internal.operators.OperatorBufferWithTime.ExactSubscriber
- scheduleExact() - Method in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- schedulePeriodically(Action0, long, long, TimeUnit) - Method in class rx.Scheduler.Worker
-
Schedules a cancelable action to be executed periodically.
- scheduler - Variable in class rx.internal.operators.CompletableOnSubscribeTimeout
- scheduler - Variable in class rx.internal.operators.OnSubscribeDelaySubscription
- scheduler - Variable in class rx.internal.operators.OnSubscribeRedo
- scheduler - Variable in class rx.internal.operators.OnSubscribeTimerOnce
- scheduler - Variable in class rx.internal.operators.OnSubscribeTimerPeriodically
- scheduler - Variable in class rx.internal.operators.OperatorBufferWithTime
- scheduler - Variable in class rx.internal.operators.OperatorDebounceWithTime
- scheduler - Variable in class rx.internal.operators.OperatorDelay
- scheduler - Variable in class rx.internal.operators.OperatorObserveOn
- scheduler - Variable in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- scheduler - Variable in class rx.internal.operators.OperatorSampleWithTime
- scheduler - Variable in class rx.internal.operators.OperatorSkipLastTimed
- scheduler - Variable in class rx.internal.operators.OperatorSkipTimed
- scheduler - Variable in class rx.internal.operators.OperatorSubscribeOn
- scheduler - Variable in class rx.internal.operators.OperatorTakeLastTimed
- scheduler - Variable in class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- scheduler - Variable in class rx.internal.operators.OperatorTakeTimed
- scheduler - Variable in class rx.internal.operators.OperatorThrottleFirst
- scheduler - Variable in class rx.internal.operators.OperatorTimeInterval
- scheduler - Variable in class rx.internal.operators.OperatorTimeoutBase
- scheduler - Variable in class rx.internal.operators.OperatorTimestamp
- scheduler - Variable in class rx.internal.operators.OperatorUnsubscribeOn
- scheduler - Variable in class rx.internal.operators.OperatorWindowWithTime
- scheduler - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- scheduler - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- scheduler - Variable in class rx.internal.util.InternalObservableUtils.SelectorAndObserveOn
- scheduler - Variable in class rx.internal.util.ScalarSynchronousSingle.NormalScheduledEmission
- scheduler - Variable in class rx.schedulers.TestScheduler.TimedAction
- scheduler - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- Scheduler - Class in rx
-
A
Scheduler
is an object that schedules units of work. - Scheduler() - Constructor for class rx.Scheduler
- Scheduler.Worker - Class in rx
-
Sequential Scheduler for executing actions on a single thread or event loop.
- SchedulerLifecycle - Interface in rx.internal.schedulers
-
Represents the capability of a Scheduler to be start or shut down its maintained threads.
- Schedulers - Class in rx.schedulers
-
Static factory methods for creating Schedulers.
- Schedulers() - Constructor for class rx.schedulers.Schedulers
- schedulersHook - Variable in class rx.plugins.RxJavaPlugins
- SchedulerWhen - Class in rx.internal.schedulers
-
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.
- SchedulerWhen(Func1<Observable<Observable<Completable>>, Completable>, Scheduler) - Constructor for class rx.internal.schedulers.SchedulerWhen
- SchedulerWhen.DelayedAction - Class in rx.internal.schedulers
- SchedulerWhen.ImmediateAction - Class in rx.internal.schedulers
- SchedulerWhen.ScheduledAction - Class in rx.internal.schedulers
- sd - Variable in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- sd - Variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- selection - Variable in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- Selection() - Constructor for class rx.internal.operators.OnSubscribeAmb.Selection
- selector - Variable in class rx.internal.operators.OperatorDebounceWithSelector
- selector - Variable in class rx.internal.util.InternalObservableUtils.SelectorAndObserveOn
- SelectorAndObserveOn(Func1<? super Observable<T>, ? extends Observable<R>>, Scheduler) - Constructor for class rx.internal.util.InternalObservableUtils.SelectorAndObserveOn
- sequenceBuffer - Variable in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- sequenceEqual(Observable<? extends T>, Observable<? extends T>) - Static method in class rx.Observable
-
Returns an Observable that emits a Boolean value that indicates whether two Observable sequences are the same by comparing the items emitted by each Observable pairwise.
- sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.internal.operators.OperatorSequenceEqual
-
Tests whether two
Observable
sequences are identical, emittingtrue
if both sequences complete without differing, andfalse
if the two sequences diverge at any point. - sequenceEqual(Observable<? extends T>, Observable<? extends T>, Func2<? super T, ? super T, Boolean>) - Static method in class rx.Observable
-
Returns an Observable that emits a Boolean value that indicates whether two Observable sequences are the same by comparing the items emitted by each Observable pairwise based on the results of a specified equality function.
- serial - Variable in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- serial - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- serial - Variable in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- serialize() - Method in class rx.Observable
-
Forces an Observable's emissions and notifications to be serialized and for it to obey the Observable contract in other ways.
- SerializedObserver<T> - Class in rx.observers
-
Enforces single-threaded, serialized, ordered execution of
SerializedObserver.onNext(T)
,SerializedObserver.onCompleted()
, andSerializedObserver.onError(java.lang.Throwable)
. - SerializedObserver(Observer<? super T>) - Constructor for class rx.observers.SerializedObserver
- SerializedObserver.FastList - Class in rx.observers
- SerializedSubject<T,R> - Class in rx.subjects
-
Wraps a
Subject
so that it is safe to call its variouson
methods from different threads. - SerializedSubject(Observer<T>, Observable<T>) - Constructor for class rx.internal.operators.OperatorWindowWithStartEndObservable.SerializedSubject
- SerializedSubject(Subject<T, R>) - Constructor for class rx.subjects.SerializedSubject
- serializedSubscriber - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- serializedSubscriber - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- SerializedSubscriber<T> - Class in rx.observers
-
Enforces single-threaded, serialized, ordered execution of
SerializedSubscriber.onNext(T)
,SerializedSubscriber.onCompleted()
, andSerializedSubscriber.onError(java.lang.Throwable)
. - SerializedSubscriber(Subscriber<? super T>) - Constructor for class rx.observers.SerializedSubscriber
- SerializedSubscriber(Subscriber<? super T>, boolean) - Constructor for class rx.observers.SerializedSubscriber
-
Constructor for wrapping and serializing a subscriber optionally sharing the same underlying subscription list.
- serialSubscription - Variable in class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- SerialSubscription - Class in rx.subscriptions
-
Represents a subscription whose underlying subscription can be swapped for another subscription which causes the previous underlying subscription to be unsubscribed.
- SerialSubscription() - Constructor for class rx.subscriptions.SerialSubscription
- SerialSubscription.State - Class in rx.subscriptions
- serialVersionUID - Static variable in exception rx.exceptions.AssemblyStackTraceException
- serialVersionUID - Static variable in exception rx.exceptions.CompositeException.CompositeExceptionCausalChain
- serialVersionUID - Static variable in exception rx.exceptions.CompositeException
- serialVersionUID - Static variable in exception rx.exceptions.MissingBackpressureException
- serialVersionUID - Static variable in exception rx.exceptions.OnCompletedFailedException
- serialVersionUID - Static variable in exception rx.exceptions.OnErrorFailedException
- serialVersionUID - Static variable in exception rx.exceptions.OnErrorNotImplementedException
- serialVersionUID - Static variable in exception rx.exceptions.OnErrorThrowable.OnNextValue
- serialVersionUID - Static variable in exception rx.exceptions.OnErrorThrowable
- serialVersionUID - Static variable in exception rx.exceptions.UnsubscribeFailedException
- serialVersionUID - Static variable in class rx.internal.operators.BufferUntilSubscriber.State
- serialVersionUID - Static variable in class rx.internal.operators.CachedObservable.CachedSubscribe
- serialVersionUID - Static variable in class rx.internal.operators.CachedObservable.ReplayProducer
- serialVersionUID - Static variable in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- serialVersionUID - Static variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- serialVersionUID - Static variable in class rx.internal.operators.NotificationLite.OnErrorSentinel
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.CancellableSubscription
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.DropAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.ErrorAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.NoneAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromAsync.NoOverflowBaseAsyncEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribePublishMulticast
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeRange.RangeProducer
- serialVersionUID - Static variable in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- serialVersionUID - Static variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap.BufferOverlapProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip.BufferSkipProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorElementAt.InnerProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorGroupBy.State
- serialVersionUID - Static variable in class rx.internal.operators.OperatorMerge.MergeProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- serialVersionUID - Static variable in class rx.internal.operators.OperatorPublish.InnerProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.InnerProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.Node
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.SizeBoundReplayBuffer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap.WindowOverlapProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip.WindowSkipProducer
- serialVersionUID - Static variable in class rx.internal.operators.OperatorZip.Zip
- serialVersionUID - Static variable in class rx.internal.operators.OperatorZip.ZipProducer
- serialVersionUID - Static variable in class rx.internal.producers.QueuedProducer
- serialVersionUID - Static variable in class rx.internal.producers.QueuedValueProducer
- serialVersionUID - Static variable in class rx.internal.producers.SingleDelayedProducer
- serialVersionUID - Static variable in class rx.internal.producers.SingleProducer
- serialVersionUID - Static variable in class rx.internal.schedulers.ScheduledAction.Remover
- serialVersionUID - Static variable in class rx.internal.schedulers.ScheduledAction.Remover2
- serialVersionUID - Static variable in class rx.internal.schedulers.ScheduledAction
- serialVersionUID - Static variable in class rx.internal.util.atomic.LinkedQueueNode
- serialVersionUID - Static variable in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- serialVersionUID - Static variable in class rx.internal.util.BackpressureDrainManager
- serialVersionUID - Static variable in class rx.internal.util.RxThreadFactory
- serialVersionUID - Static variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- serialVersionUID - Static variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- serialVersionUID - Static variable in class rx.subjects.ReplaySubject.ReplayProducer
- serialVersionUID - Static variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer.TimedNode
- serialVersionUID - Static variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer.Node
- serialVersionUID - Static variable in class rx.subjects.ReplaySubject.ReplayState
- serialVersionUID - Static variable in class rx.subjects.SubjectSubscriptionManager
- serialVersionUID - Static variable in class rx.subjects.UnicastSubject.State
- serialVersionUID - Static variable in class rx.subscriptions.RefCountSubscription.InnerSubscription
- service - Variable in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- set - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- set(int, int) - Method in class rx.internal.util.IndexedRingBuffer.IndexSection
- set(Subscription) - Method in class rx.subscriptions.MultipleAssignmentSubscription
-
Sets the underlying subscription.
- set(Subscription) - Method in class rx.subscriptions.MultipleAssignmentSubscription.State
- set(Subscription) - Method in class rx.subscriptions.SerialSubscription
-
Swaps out the old
Subscription
for the specifiedSubscription
. - set(Subscription) - Method in class rx.subscriptions.SerialSubscription.State
- SET_PRODUCER - Static variable in class rx.observables.BlockingObservable
-
Constant indicating the setProducer method should be called.
- SET_REMOVE_ON_CANCEL_POLICY_METHOD_NOT_SUPPORTED - Static variable in class rx.internal.schedulers.NewThreadWorker
-
Possible value of
NewThreadWorker.cachedSetRemoveOnCancelPolicyMethod
which means that cancel policy is not supported. - setCancellation(AsyncEmitter.Cancellable) - Method in interface rx.AsyncEmitter
-
Sets a Cancellable on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
- setCancellation(AsyncEmitter.Cancellable) - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- setConcatProducer(Producer) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- setExpirationTime(long) - Method in class rx.internal.schedulers.CachedThreadScheduler.ThreadWorker
- setFirst(OperatorReplay.Node) - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Arranges the given node is the new head from now on.
- setLatest(Object) - Method in class rx.subjects.SubjectSubscriptionManager
-
Set the latest NotificationLite value.
- setOnCompletableCreate(Func1<Completable.CompletableOnSubscribe, Completable.CompletableOnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the Completable's onCreate hook function unless a lockdown is in effect.
- setOnCompletableLift(Func1<Completable.CompletableOperator, Completable.CompletableOperator>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called with an operator when an Completable operator built with lift() gets subscribed to.
- setOnCompletableStart(Func2<Completable, Completable.CompletableOnSubscribe, Completable.CompletableOnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function that is called when a subscriber subscribes to a Completable unless a lockdown is in effect.
- setOnCompletableSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called when the Completable.subscribe() call fails with an exception.
- setOnComputationScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function for returning a scheduler when the Schedulers.computation() is called unless a lockdown is in effect.
- setOnError(Action1<Throwable>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the global error consumer action unless a lockdown is in effect.
- setOnGenericScheduledExecutorService(Func0<? extends ScheduledExecutorService>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function for returning a ScheduledExecutorService used by the GenericScheduledExecutorService for background tasks.
- setOnIOScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function for returning a scheduler when the Schedulers.io() is called unless a lockdown is in effect.
- setOnNewThreadScheduler(Func1<Scheduler, Scheduler>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function for returning a scheduler when the Schedulers.newThread() is called unless a lockdown is in effect.
- setOnObservableCreate(Func1<Observable.OnSubscribe, Observable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the Observable onCreate hook function unless a lockdown is in effect.
- setOnObservableLift(Func1<Observable.Operator, Observable.Operator>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called with an operator when an Observable operator built with lift() gets subscribed to.
- setOnObservableReturn(Func1<Subscription, Subscription>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called when the Observable.subscribe() call is about to return a Subscription unless a lockdown is in effect.
- setOnObservableStart(Func2<Observable, Observable.OnSubscribe, Observable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function that is called when a subscriber subscribes to a Observable unless a lockdown is in effect.
- setOnObservableSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called when the Observable.subscribe() call fails with an exception.
- setOnScheduleAction(Func1<Action0, Action0>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function that is called before an action is scheduled, allowing decorating that function, unless a lockdown is in effect.
- setOnSingleCreate(Func1<Single.OnSubscribe, Single.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the Single onCreate hook function unless a lockdown is in effect.
- setOnSingleLift(Func1<Observable.Operator, Observable.Operator>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called with an operator when an Single operator built with lift() gets subscribed to.
- setOnSingleReturn(Func1<Subscription, Subscription>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called when the Single.subscribe() call is about to return a Subscription unless a lockdown is in effect.
- setOnSingleStart(Func2<Single, Observable.OnSubscribe, Observable.OnSubscribe>) - Static method in class rx.plugins.RxJavaHooks
-
Sets the hook function that is called when a subscriber subscribes to a Single unless a lockdown is in effect.
- setOnSingleSubscribeError(Func1<Throwable, Throwable>) - Static method in class rx.plugins.RxJavaHooks
-
Sets a hook function that is called when the Single.subscribe() call fails with an exception.
- setProducer(Producer) - Method in class rx.internal.operators.DeferredScalarSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribeDetach.DetachSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribeFilter.FilterSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribeMap.MapSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Sets the main producer and issues the prefetch amount.
- setProducer(Producer) - Method in class rx.internal.operators.OperatorCast.CastSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorMapPair.MapPairSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorReplay.ReplaySubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorScan.InitialProducer
- setProducer(Producer) - Method in class rx.internal.operators.OperatorSwitch.InnerSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.AlternateSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- setProducer(Producer) - Method in class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- setProducer(Producer) - Method in class rx.internal.producers.ProducerArbiter
- setProducer(Producer) - Method in class rx.internal.producers.ProducerObserverArbiter
- setProducer(Producer) - Method in class rx.Subscriber
-
If other subscriber is set (by calling constructor
Subscriber(Subscriber)
orSubscriber(Subscriber, boolean)
) then this method callssetProducer
on the other subscriber. - setSubscription(Subscription) - Method in interface rx.AsyncEmitter
-
Sets a Subscription on this emitter; any previous Subscription or Cancellation will be unsubscribed/cancelled.
- setSubscription(Subscription) - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- setupDownstream() - Method in class rx.internal.operators.DeferredScalarSubscriber
- setValue(T) - Method in class rx.internal.producers.SingleDelayedProducer
- setWaiting(int) - Method in class rx.internal.operators.BlockingOperatorNext.NextObserver
- share() - Method in class rx.Observable
-
Returns a new
Observable
that multicasts (shares) the originalObservable
. - sharedProducer - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- SHOULD_TRY_ENABLE_CANCEL_POLICY - Static variable in class rx.internal.schedulers.NewThreadWorker
- shouldConnect - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Atomically changed from false to true by connect to make sure the connection is only performed by one thread.
- shouldConnect - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Atomically changed from false to true by connect to make sure the connection is only performed by one thread.
- shutdown() - Method in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- shutdown() - Method in class rx.internal.schedulers.CachedThreadScheduler
- shutdown() - Method in class rx.internal.schedulers.EventLoopsScheduler.FixedSchedulerPool
- shutdown() - Method in class rx.internal.schedulers.EventLoopsScheduler
- shutdown() - Method in class rx.internal.schedulers.GenericScheduledExecutorService
- shutdown() - Method in interface rx.internal.schedulers.SchedulerLifecycle
-
Instructs the Scheduler instance to stop threads and stop accepting tasks on any outstanding Workers.
- shutdown() - Method in class rx.internal.util.ObjectPool
-
Shutdown this pool.
- shutdown() - Static method in class rx.schedulers.Schedulers
-
Shuts down those standard Schedulers which support the SchedulerLifecycle interface.
- SHUTDOWN - Static variable in class rx.internal.schedulers.GenericScheduledExecutorService
- SHUTDOWN_THREADWORKER - Static variable in class rx.internal.schedulers.CachedThreadScheduler
- SHUTDOWN_WORKER - Static variable in class rx.internal.schedulers.EventLoopsScheduler
- shutdownInstance() - Method in class rx.schedulers.Schedulers
-
Start the instance-specific schedulers.
- signalError(Throwable) - Method in class rx.internal.schedulers.ScheduledAction
- signalUncaught(Throwable) - Static method in class rx.plugins.RxJavaHooks
- single - Variable in class rx.singles.BlockingSingle
- single() - Method in class rx.Observable
-
Returns an Observable that emits the single item emitted by the source Observable, if that Observable emits only a single item.
- single() - Method in class rx.observables.BlockingObservable
-
If this
BlockingObservable
completes after emitting a single item, return that item, otherwise throw aNoSuchElementException
. - single(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits the single item emitted by the source Observable that matches a specified predicate, if that Observable emits one such item.
- single(Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
If this
BlockingObservable
completes after emitting a single item that matches a given predicate, return that item, otherwise throw aNoSuchElementException
. - Single<T> - Class in rx
-
The Single class implements the Reactive Pattern for a single value response.
- Single(Observable.OnSubscribe<T>) - Constructor for class rx.Single
- Single(Single.OnSubscribe<T>) - Constructor for class rx.Single
-
Creates a Single with a Function to execute when it is subscribed to (executed).
- Single.OnSubscribe<T> - Interface in rx
-
Invoked when Single.execute is called.
- Single.Transformer<T,R> - Interface in rx
-
Transformer function used by
Single.compose(rx.Single.Transformer<? super T, ? extends R>)
. - SingleDelayedProducer<T> - Class in rx.internal.producers
-
Producer that emits a single value and completes the child subscriber once that single value is set on it and the child requested items (maybe both asynchronously).
- SingleDelayedProducer(Subscriber<? super T>) - Constructor for class rx.internal.producers.SingleDelayedProducer
-
Constructor, wraps the target child subscriber.
- SingleDoAfterTerminate<T> - Class in rx.internal.operators
-
Execute an action after onSuccess or onError has been delivered.
- SingleDoAfterTerminate(Single<T>, Action0) - Constructor for class rx.internal.operators.SingleDoAfterTerminate
- SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber<T> - Class in rx.internal.operators
- SingleDoAfterTerminateSubscriber(SingleSubscriber<? super T>, Action0) - Constructor for class rx.internal.operators.SingleDoAfterTerminate.SingleDoAfterTerminateSubscriber
- singleExecutionHook - Variable in class rx.plugins.RxJavaPlugins
- singleFactory - Variable in class rx.internal.operators.SingleOnSubscribeUsing
- SingleOnSubscribeDelaySubscriptionOther<T> - Class in rx.internal.operators
-
Delays the subscription to the Single until the Observable fires an event or completes.
- SingleOnSubscribeDelaySubscriptionOther(Single<? extends T>, Observable<?>) - Constructor for class rx.internal.operators.SingleOnSubscribeDelaySubscriptionOther
- SingleOnSubscribeMap<T,R> - Class in rx.internal.operators
-
Applies a function of your choosing to every item emitted by an
Single
, and emits the results of this transformation as a newSingle
. - SingleOnSubscribeMap(Single<T>, Func1<? super T, ? extends R>) - Constructor for class rx.internal.operators.SingleOnSubscribeMap
- SingleOnSubscribeMap.MapSubscriber<T,R> - Class in rx.internal.operators
- SingleOnSubscribeUsing<T,Resource> - Class in rx.internal.operators
-
Generates a resource, derives a Single from it and disposes that resource once the Single terminates.
- SingleOnSubscribeUsing(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>, boolean) - Constructor for class rx.internal.operators.SingleOnSubscribeUsing
- SingleOperatorOnErrorResumeNext<T> - Class in rx.internal.operators
- SingleOperatorOnErrorResumeNext(Single<? extends T>, Func1<Throwable, ? extends Single<? extends T>>) - Constructor for class rx.internal.operators.SingleOperatorOnErrorResumeNext
- SingleOperatorZip - Class in rx.internal.operators
- SingleOperatorZip() - Constructor for class rx.internal.operators.SingleOperatorZip
-
Utility class.
- singleOrDefault(T) - Method in class rx.Observable
-
Returns an Observable that emits the single item emitted by the source Observable, if that Observable emits only a single item, or a default item if the source Observable emits no items.
- singleOrDefault(T) - Method in class rx.observables.BlockingObservable
-
If this
BlockingObservable
completes after emitting a single item, return that item; if it emits more than one item, throw anIllegalArgumentException
; if it emits no items, return a default value. - singleOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits the single item emitted by the source Observable that matches a predicate, if that Observable emits only one such item, or a default item if the source Observable emits no such items.
- singleOrDefault(T, Func1<? super T, Boolean>) - Method in class rx.observables.BlockingObservable
-
If this
BlockingObservable
completes after emitting a single item that matches a predicate, return that item; if it emits more than one such item, throw anIllegalArgumentException
; if it emits no items, return a default value. - SingleProducer<T> - Class in rx.internal.producers
-
A producer which emits a single value and completes the child on the first positive request.
- SingleProducer(Subscriber<? super T>, T) - Constructor for class rx.internal.producers.SingleProducer
-
Constructs the producer with the given target child and value to be emitted.
- SingleSubscriber<T> - Class in rx
-
Provides a mechanism for receiving push-based notifications.
- SingleSubscriber() - Constructor for class rx.SingleSubscriber
- size - Variable in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- size - Variable in class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
-
The total number of events in the buffer.
- size - Variable in class rx.internal.operators.OperatorWindowWithSize
- size - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- size - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- size - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- size - Variable in class rx.internal.operators.OperatorWindowWithTime
- size - Variable in class rx.internal.util.LinkedArrayList
-
The total size of the list; written after elements have been added (release) and and when read, the value indicates how many elements can be safely read (acquire).
- size - Variable in class rx.internal.util.OpenHashSet
- size - Variable in class rx.internal.util.RxRingBuffer
- size - Variable in class rx.internal.util.SynchronizedQueue
- size - Variable in class rx.observers.SerializedObserver.FastList
- size - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- size - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- size - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- size() - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
-
- size() - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- size() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- size() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- size() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- size() - Method in class rx.internal.util.LinkedArrayList
-
Returns the total size of the list.
- size() - Method in class rx.internal.util.SynchronizedQueue
- size() - Method in class rx.internal.util.unsafe.BaseLinkedQueue
-
- size() - Method in interface rx.internal.util.unsafe.MessagePassingQueue
-
This method's accuracy is subject to concurrent modifications happening as the size is estimated and as such is a best effort rather than absolute value.
- size() - Method in class rx.internal.util.unsafe.MpmcArrayQueue
- size() - Method in class rx.internal.util.unsafe.SpmcArrayQueue
- size() - Method in class rx.internal.util.unsafe.SpscArrayQueue
- size() - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- size() - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- size() - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- size() - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- size() - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- size() - Method in class rx.subjects.ReplaySubject
-
Returns the current number of items (non-terminal events) available for replay.
- SIZE - Static variable in class rx.internal.util.IndexedRingBuffer
- SIZE - Static variable in class rx.internal.util.RxRingBuffer
- SizeAndTimeBoundReplayBuffer(int, long, Scheduler) - Constructor for class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- SizeBoundReplayBuffer(int) - Constructor for class rx.internal.operators.OperatorReplay.SizeBoundReplayBuffer
- skip - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferOverlap
- skip - Variable in class rx.internal.operators.OperatorBufferWithSize.BufferSkip
- skip - Variable in class rx.internal.operators.OperatorBufferWithSize
- skip - Variable in class rx.internal.operators.OperatorWindowWithSize
- skip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- skip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- skip(int) - Method in class rx.Observable
-
Returns an Observable that skips the first
count
items emitted by the source Observable and emits the remainder. - skip(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that skips values emitted by the source Observable before a specified time window elapses.
- skip(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that skips values emitted by the source Observable before a specified time window on a specified
Scheduler
elapses. - skipLast(int) - Method in class rx.Observable
-
Returns an Observable that drops a specified number of items from the end of the sequence emitted by the source Observable.
- skipLast(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that drops items emitted by the source Observable during a specified time window before the source completes.
- skipLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that drops items emitted by the source Observable during a specified time window (defined on a specified scheduler) before the source completes.
- skipUntil(Observable<U>) - Method in class rx.Observable
-
Returns an Observable that skips items emitted by the source Observable until a second Observable emits an item.
- skipWhile(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that skips all items emitted by the source Observable as long as a specified condition holds true, but emits all further source items as soon as the condition becomes false.
- SleepingAction - Class in rx.internal.schedulers
- SleepingAction(Action0, Scheduler.Worker, long) - Constructor for class rx.internal.schedulers.SleepingAction
- slowpath(long) - Method in class rx.internal.operators.OnSubscribeFromIterable.IterableProducer
- slowpath(long) - Method in class rx.internal.operators.OnSubscribeRange.RangeProducer
-
Emits as many values as requested or remaining from the range, whichever is smaller.
- slowPath(long) - Method in class rx.internal.operators.OnSubscribeFromArray.FromArrayProducer
- slowPath(long) - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- soConsumerIndex(long) - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- soConsumerIndex(long) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- soConsumerIndex(long) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- soConsumerIndex(long) - Method in class rx.internal.util.unsafe.SpscArrayQueue
- soConsumerIndex(long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- soElement(int, E) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- soElement(long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
An ordered store(store + StoreStore barrier) of an element to a given offset
- soElement(E[], long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
An ordered store(store + StoreStore barrier) of an element to a given offset
- soElement(Object[], long, Object) - Static method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- soElement(AtomicReferenceArray<E>, int, E) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- soElement(AtomicReferenceArray<Object>, int, Object) - Static method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- soElement(AtomicReferenceArray<Object>, int, Object) - Static method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- soNext(E[], E[]) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- soNext(AtomicReferenceArray<Object>, AtomicReferenceArray<Object>) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- soNext(AtomicReferenceArray<Object>, AtomicReferenceArray<Object>) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- soNext(LinkedQueueNode<E>) - Method in class rx.internal.util.atomic.LinkedQueueNode
- soProducerIndex(long) - Method in class rx.internal.util.atomic.SpscAtomicArrayQueue
- soProducerIndex(long) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- soProducerIndex(long) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- soProducerIndex(long) - Method in class rx.internal.util.unsafe.SpscArrayQueue
- soProducerIndex(long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- sortFunction - Variable in class rx.internal.operators.OperatorToObservableSortedList
- soSequence(long[], long, long) - Method in class rx.internal.util.unsafe.ConcurrentSequencedCircularArrayQueue
- soTail(long) - Method in class rx.internal.util.unsafe.SpmcArrayQueueProducerField
- source - Variable in class rx.internal.operators.CachedObservable.CacheState
-
The source observable to connect to.
- source - Variable in class rx.internal.operators.CompletableOnSubscribeMerge
- source - Variable in class rx.internal.operators.CompletableOnSubscribeTimeout
- source - Variable in class rx.internal.operators.OnSubscribeAutoConnect
- source - Variable in class rx.internal.operators.OnSubscribeCollect
- source - Variable in class rx.internal.operators.OnSubscribeConcatMap
- source - Variable in class rx.internal.operators.OnSubscribeDelaySubscription
- source - Variable in class rx.internal.operators.OnSubscribeDelaySubscriptionWithSelector
- source - Variable in class rx.internal.operators.OnSubscribeDetach
- source - Variable in class rx.internal.operators.OnSubscribeFilter
- source - Variable in class rx.internal.operators.OnSubscribeFlattenIterable
- source - Variable in class rx.internal.operators.OnSubscribeMap
- source - Variable in class rx.internal.operators.OnSubscribeOnAssembly
- source - Variable in class rx.internal.operators.OnSubscribeOnAssemblyCompletable
- source - Variable in class rx.internal.operators.OnSubscribeOnAssemblySingle
- source - Variable in class rx.internal.operators.OnSubscribeRedo
- source - Variable in class rx.internal.operators.OnSubscribeReduce
- source - Variable in class rx.internal.operators.OnSubscribeReduceSeed
- source - Variable in class rx.internal.operators.OnSubscribeRefCount
- source - Variable in class rx.internal.operators.OnSubscribeTakeLastOne
- source - Variable in class rx.internal.operators.OperatorDelayWithSelector
- source - Variable in class rx.internal.operators.OperatorMulticast
- source - Variable in class rx.internal.operators.OperatorPublish
-
The source observable.
- source - Variable in class rx.internal.operators.OperatorReplay
-
The source observable.
- source - Variable in class rx.internal.operators.OperatorSubscribeOn
- source - Variable in class rx.internal.operators.SingleDoAfterTerminate
- source - Variable in class rx.internal.operators.SingleOnSubscribeMap
- source - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBuffer
- source - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- source - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierNoParams
- source - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- sourceDone - Variable in class rx.internal.operators.CachedObservable.CacheState
-
Indicates that the source has completed emitting values or the Observable was forcefully terminated.
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeConcat
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeConcatArray.ConcatInnerSubscriber
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeConcatArray
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable.ConcatInnerSubscriber
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeConcatIterable
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeMergeArray
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorArray
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeMergeDelayErrorIterable
- sources - Variable in class rx.internal.operators.CompletableOnSubscribeMergeIterable
- sources - Variable in class rx.internal.operators.OnSubscribeAmb
- sources - Variable in class rx.internal.operators.OnSubscribeCombineLatest
- sourcesIterable - Variable in class rx.internal.operators.OnSubscribeCombineLatest
- SourceSubscriber(Subscriber<? super Observable<T>>) - Constructor for class rx.internal.operators.OperatorWindowWithObservable.SourceSubscriber
- SourceSubscriber(Subscriber<? super Observable<T>>, Func0<? extends Observable<? extends U>>) - Constructor for class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- SourceSubscriber(Subscriber<? super Observable<T>>, CompositeSubscription) - Constructor for class rx.internal.operators.OperatorWindowWithStartEndObservable.SourceSubscriber
- SourceSubscriber(Subscriber<? super T>, Func2<Integer, Throwable, Boolean>, Scheduler.Worker, SerialSubscription, ProducerArbiter) - Constructor for class rx.internal.operators.OperatorRetryWithPredicate.SourceSubscriber
- SPARSE_SHIFT - Static variable in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
- spConsumerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- spConsumerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.unsafe.BaseLinkedQueueConsumerNodeRef
- spElement(int, E) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- spElement(long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain store (no ordering/fences) of an element to a given offset
- spElement(E[], long, E) - Method in class rx.internal.util.unsafe.ConcurrentCircularArrayQueue
-
A plain store (no ordering/fences) of an element to a given offset
- spElement(AtomicReferenceArray<E>, int, E) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- SPMC_POOL - Static variable in class rx.internal.util.RxRingBuffer
- SpmcArrayQueue<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueue(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueue
- SpmcArrayQueueConsumerField<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueConsumerField(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueConsumerField
- SpmcArrayQueueL1Pad<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueL1Pad(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueL1Pad
- SpmcArrayQueueL2Pad<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueL2Pad(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueL2Pad
- SpmcArrayQueueL3Pad<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueL3Pad(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueL3Pad
- SpmcArrayQueueMidPad<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueMidPad(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueMidPad
- SpmcArrayQueueProducerField<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueProducerField(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueProducerField
- SpmcArrayQueueProducerIndexCacheField<E> - Class in rx.internal.util.unsafe
- SpmcArrayQueueProducerIndexCacheField(int) - Constructor for class rx.internal.util.unsafe.SpmcArrayQueueProducerIndexCacheField
- spProducerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- spProducerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.unsafe.BaseLinkedQueueProducerNodeRef
- SPSC_POOL - Static variable in class rx.internal.util.RxRingBuffer
- SpscArrayQueue<E> - Class in rx.internal.util.unsafe
-
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer.
- SpscArrayQueue(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueue
- SpscArrayQueueColdField<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueColdField(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueColdField
- SpscArrayQueueConsumerField<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueConsumerField(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueConsumerField
- SpscArrayQueueL1Pad<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueL1Pad(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueL1Pad
- SpscArrayQueueL2Pad<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueL2Pad(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueL2Pad
- SpscArrayQueueL3Pad<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueL3Pad(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueL3Pad
- SpscArrayQueueProducerFields<E> - Class in rx.internal.util.unsafe
- SpscArrayQueueProducerFields(int) - Constructor for class rx.internal.util.unsafe.SpscArrayQueueProducerFields
- SpscAtomicArrayQueue<E> - Class in rx.internal.util.atomic
-
A Single-Producer-Single-Consumer queue backed by a pre-allocated buffer.
- SpscAtomicArrayQueue(int) - Constructor for class rx.internal.util.atomic.SpscAtomicArrayQueue
- SpscExactAtomicArrayQueue<T> - Class in rx.internal.util.atomic
-
A single-producer single-consumer bounded queue with exact capacity tracking.
- SpscExactAtomicArrayQueue(int) - Constructor for class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- SpscLinkedArrayQueue<T> - Class in rx.internal.util.atomic
-
A single-producer single-consumer array-backed queue which can allocate new arrays in case the consumer is slower than the producer.
- SpscLinkedArrayQueue(int) - Constructor for class rx.internal.util.atomic.SpscLinkedArrayQueue
- SpscLinkedAtomicQueue<E> - Class in rx.internal.util.atomic
-
This is a weakened version of the MPSC algorithm as presented on 1024 Cores by D.
- SpscLinkedAtomicQueue() - Constructor for class rx.internal.util.atomic.SpscLinkedAtomicQueue
- SpscLinkedQueue<E> - Class in rx.internal.util.unsafe
-
This is a weakened version of the MPSC algorithm as presented on 1024 Cores by D.
- SpscLinkedQueue() - Constructor for class rx.internal.util.unsafe.SpscLinkedQueue
- SpscUnboundedArrayQueue<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueue(int) - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- SpscUnboundedArrayQueueConsumerColdField<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueueConsumerColdField() - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueueConsumerColdField
- SpscUnboundedArrayQueueConsumerField<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueueConsumerField() - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueueConsumerField
- SpscUnboundedArrayQueueL2Pad<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueueL2Pad() - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueueL2Pad
- SpscUnboundedArrayQueueProducerColdFields<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueueProducerColdFields() - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerColdFields
- SpscUnboundedArrayQueueProducerFields<E> - Class in rx.internal.util.unsafe
- SpscUnboundedArrayQueueProducerFields() - Constructor for class rx.internal.util.unsafe.SpscUnboundedArrayQueueProducerFields
- SpscUnboundedAtomicArrayQueue<T> - Class in rx.internal.util.atomic
-
A single-producer single-consumer queue with unbounded capacity.
- SpscUnboundedAtomicArrayQueue(int) - Constructor for class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- spValue(E) - Method in class rx.internal.util.atomic.LinkedQueueNode
- sr - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- ssub - Variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- ssub - Variable in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- ssub - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.SourceSubscriber
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssembly.OnAssemblySubscriber
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssembly
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssemblyCompletable.OnAssemblyCompletableSubscriber
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssemblyCompletable
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssemblySingle.OnAssemblySingleSubscriber
- stacktrace - Variable in class rx.internal.operators.OnSubscribeOnAssemblySingle
- start() - Method in class rx.internal.schedulers.CachedThreadScheduler
- start() - Method in class rx.internal.schedulers.EventLoopsScheduler
- start() - Method in class rx.internal.schedulers.GenericScheduledExecutorService
- start() - Method in interface rx.internal.schedulers.SchedulerLifecycle
-
Allows the Scheduler instance to start threads and accept tasks on them.
- start() - Method in class rx.internal.util.ObjectPool
- start() - Static method in class rx.schedulers.Schedulers
-
Starts those standard Schedulers which support the SchedulerLifecycle interface.
- start(Observable[], AtomicLong) - Method in class rx.internal.operators.OperatorZip.Zip
- startBuffer(TOpening) - Method in class rx.internal.operators.OperatorBufferWithStartEndObservable.BufferingSubscriber
- started - Variable in class rx.internal.operators.BlockingOperatorNext.NextIterator
- started - Variable in class rx.internal.operators.OperatorZip.ZipSubscriber
- startIndex - Variable in class rx.internal.operators.OnSubscribeRange
- startInstance() - Method in class rx.schedulers.Schedulers
-
Start the instance-specific schedulers.
- startNewChunk() - Method in class rx.internal.operators.OperatorBufferWithTime.InexactSubscriber
- startNewChunk() - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- startWith(Iterable<T>) - Method in class rx.Observable
-
Returns an Observable that emits the items in a specified
Iterable
before it begins to emit items emitted by the source Observable. - startWith(Completable) - Method in class rx.Completable
-
Returns a Completable which first runs the other Completable then this completable if the other completed normally.
- startWith(Observable<T>) - Method in class rx.Completable
-
Returns an Observable which first delivers the events of the other Observable then runs this Completable.
- startWith(Observable<T>) - Method in class rx.Observable
-
Returns an Observable that emits the items in a specified
Observable
before it begins to emit items emitted by the source Observable. - startWith(T) - Method in class rx.Observable
-
Returns an Observable that emits a specified item before it begins to emit items emitted by the source Observable.
- startWith(T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T, T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- startWith(T, T, T, T, T, T, T, T, T) - Method in class rx.Observable
-
Returns an Observable that emits the specified items before it begins to emit items emitted by the source Observable.
- state - Variable in class rx.internal.operators.BufferUntilSubscriber.OnSubscribeAction
- state - Variable in class rx.internal.operators.BufferUntilSubscriber
- state - Variable in class rx.internal.operators.CachedObservable.CachedSubscribe
- state - Variable in class rx.internal.operators.CachedObservable.ReplayProducer
-
The cache state object.
- state - Variable in class rx.internal.operators.CachedObservable
-
The cache and replay state.
- state - Variable in class rx.internal.operators.DeferredScalarSubscriber
-
The state, see the constants below.
- state - Variable in class rx.internal.operators.OnSubscribePublishMulticast.ParentSubscriber
-
The reference to the parent state where the events are forwarded to.
- state - Variable in class rx.internal.operators.OperatorGroupBy.GroupedUnicast
- state - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- state - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- state - Variable in class rx.observables.AsyncOnSubscribe.UnicastSubject
- state - Variable in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- state - Variable in class rx.subjects.AsyncSubject
- state - Variable in class rx.subjects.BehaviorSubject
- state - Variable in class rx.subjects.PublishSubject
- state - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
Holds the back-reference to the replay state object.
- state - Variable in class rx.subjects.ReplaySubject
-
The state storing the history and the references.
- state - Variable in class rx.subjects.TestSubject
- state - Variable in class rx.subjects.UnicastSubject
- state - Variable in class rx.subscriptions.MultipleAssignmentSubscription
- state - Variable in class rx.subscriptions.RefCountSubscription
- state - Variable in class rx.subscriptions.SerialSubscription
- State() - Constructor for class rx.internal.operators.BufferUntilSubscriber.State
- State() - Constructor for class rx.observables.AsyncOnSubscribe.UnicastSubject.State
- State(boolean, int) - Constructor for class rx.subscriptions.RefCountSubscription.State
- State(boolean, SubjectSubscriptionManager.SubjectObserver[]) - Constructor for class rx.subjects.SubjectSubscriptionManager.State
- State(boolean, Subscription) - Constructor for class rx.subscriptions.MultipleAssignmentSubscription.State
- State(boolean, Subscription) - Constructor for class rx.subscriptions.SerialSubscription.State
- State(int, Action0) - Constructor for class rx.subjects.UnicastSubject.State
-
Constructor.
- State(int, OperatorGroupBy.GroupBySubscriber<?, K, T>, K, boolean) - Constructor for class rx.internal.operators.OperatorGroupBy.State
- State(Observer<T>, Observable<T>, int) - Constructor for class rx.internal.operators.OperatorWindowWithTime.State
- stopOnComplete - Variable in class rx.internal.operators.OnSubscribeRedo
- stopOnError - Variable in class rx.internal.operators.OnSubscribeRedo
- stopPredicate - Variable in class rx.internal.operators.OperatorTakeUntilPredicate
- STRONG_MODE - Static variable in class rx.internal.util.ScalarSynchronousObservable
-
Indicates that the Producer used by this Observable should be fully threadsafe.
- sub - Variable in class rx.internal.operators.OperatorWindowWithObservable.BoundarySubscriber
- sub - Variable in class rx.internal.operators.OperatorWindowWithObservableFactory.BoundarySubscriber
- Subject<T,R> - Class in rx.subjects
-
Represents an object that is both an Observable and an Observer.
- Subject(Observable.OnSubscribe<R>) - Constructor for class rx.subjects.Subject
- subjectFactory - Variable in class rx.internal.operators.OperatorMulticast
- SubjectObserver(Subscriber<? super T>) - Constructor for class rx.subjects.SubjectSubscriptionManager.SubjectObserver
- SubjectSubscriptionManager<T> - Class in rx.subjects
-
Represents the typical state and OnSubscribe logic for a Subject implementation.
- SubjectSubscriptionManager() - Constructor for class rx.subjects.SubjectSubscriptionManager
- SubjectSubscriptionManager.State<T> - Class in rx.subjects
-
State-machine representing the termination state and active SubjectObservers.
- SubjectSubscriptionManager.SubjectObserver<T> - Class in rx.subjects
-
Observer wrapping the actual Subscriber and providing various emission facilities.
- subscribe - Variable in class rx.internal.operators.OperatorDoOnSubscribe
- subscribe() - Method in class rx.Completable
-
Subscribes to this Completable and returns a Subscription which can be used to cancel the subscription.
- subscribe() - Method in class rx.Observable
-
Subscribes to an Observable and ignores
onNext
andonCompleted
emissions. - subscribe() - Method in class rx.observables.BlockingObservable
-
Runs the source observable to a terminal event, ignoring any values and rethrowing any exception.
- subscribe() - Method in class rx.Single
-
Subscribes to a Single but ignore its emission or notification.
- subscribe(Completable.CompletableSubscriber) - Method in class rx.Completable
-
Subscribes the given CompletableSubscriber to this Completable instance and handles exceptions thrown by its onXXX methods.
- subscribe(Action0) - Method in class rx.Completable
-
Subscribes to this Completable and calls the given Action0 when this Completable completes normally.
- subscribe(Action0, Action1<? super Throwable>) - Method in class rx.Completable
-
Subscribes to this Completable and calls back either the onError or onComplete functions.
- subscribe(Action1<? super T>) - Method in class rx.Observable
-
Subscribes to an Observable and provides a callback to handle the items it emits.
- subscribe(Action1<? super T>) - Method in class rx.observables.BlockingObservable
-
Subscribes to the source and calls the given action on the current thread and rethrows any exception wrapped into OnErrorNotImplementedException.
- subscribe(Action1<? super T>) - Method in class rx.Single
-
Subscribes to a Single and provides a callback to handle the item it emits.
- subscribe(Action1<? super T>, Action1<? super Throwable>) - Method in class rx.observables.BlockingObservable
-
Subscribes to the source and calls the given actions on the current thread.
- subscribe(Action1<? super T>, Action1<? super Throwable>, Action0) - Method in class rx.observables.BlockingObservable
-
Subscribes to the source and calls the given actions on the current thread.
- subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Observable
-
Subscribes to an Observable and provides callbacks to handle the items it emits and any error notification it issues.
- subscribe(Action1<? super T>, Action1<Throwable>) - Method in class rx.Single
-
Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it issues.
- subscribe(Action1<? super T>, Action1<Throwable>, Action0) - Method in class rx.Observable
-
Subscribes to an Observable and provides callbacks to handle the items it emits and any error or completion notification it issues.
- subscribe(Observable<? extends T>[]) - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- subscribe(Observer<? super T>) - Method in class rx.Observable
-
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.
- subscribe(Observer<? super T>) - Method in class rx.observables.BlockingObservable
-
Subscribes to the source and calls back the Observer methods on the current thread.
- subscribe(Observer<? super T>) - Method in class rx.Single
-
Subscribes an Observer to this single and returns a Subscription that allows unsubscription.
- subscribe(SingleSubscriber<? super T>) - Method in class rx.Single
-
Subscribes to a Single and provides a
SingleSubscriber
that implements functions to handle the item the Single emits or any error notification it issues. - subscribe(Subscriber<? super T>) - Method in class rx.Observable
-
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.
- subscribe(Subscriber<? super T>) - Method in class rx.observables.BlockingObservable
-
Subscribes to the source and calls the Subscriber methods on the current thread.
- subscribe(Subscriber<? super T>) - Method in class rx.Single
-
Subscribes to a Single and provides a Subscriber that implements functions to handle the item the Single emits or any error notification it issues.
- subscribe(Subscriber<? super T>, Observable<T>) - Static method in class rx.Observable
- subscribe(Subscriber<T>) - Method in class rx.Completable
-
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.
- subscribeBufferToObservable(Observable<? extends T>) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- SUBSCRIBED - Static variable in class rx.internal.schedulers.SchedulerWhen
- subscribeOn(Scheduler) - Method in class rx.Completable
-
Returns a Completable which subscribes the child subscriber on the specified scheduler, making sure the subscription side-effects happen on that specific thread of the scheduler.
- subscribeOn(Scheduler) - Method in class rx.Observable
-
Asynchronously subscribes Observers to this Observable on the specified
Scheduler
. - subscribeOn(Scheduler) - Method in class rx.Single
-
Asynchronously subscribes subscribers to this Single on the specified
Scheduler
. - subscriber - Variable in class rx.internal.operators.OnSubscribeAmb.AmbSubscriber
- subscriber - Variable in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- subscriber - Variable in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- subscriber - Variable in class rx.internal.operators.OnSubscribeJoin.ResultSink
- subscriber - Variable in class rx.internal.operators.OperatorMerge.MergeProducer
- subscriber - Variable in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
- subscriber - Variable in class rx.internal.util.ScalarSynchronousSingle.ScalarSynchronousSingleAction
- subscriber - Variable in class rx.observables.AsyncOnSubscribe.UnicastSubject.State
- subscriber - Variable in class rx.subjects.UnicastSubject.State
-
The single subscriber.
- subscriber - Variable in class rx.Subscriber
- subscriber() - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Returns the input subscriber of this class that must be subscribed to the upstream source.
- Subscriber<T> - Class in rx
-
Provides a mechanism for receiving push-based notifications from Observables, and permits manual unsubscribing from these Observables.
- Subscriber() - Constructor for class rx.Subscriber
- Subscriber(Subscriber<?>) - Constructor for class rx.Subscriber
-
Construct a Subscriber by using another Subscriber for backpressure and for holding the subscription list (when
this.add(sub)
is called this will in fact callsubscriber.add(sub)
). - Subscriber(Subscriber<?>, boolean) - Constructor for class rx.Subscriber
-
Construct a Subscriber by using another Subscriber for backpressure and optionally for holding the subscription list (if
shareSubscriptions
istrue
then whenthis.add(sub)
is called this will in fact callsubscriber.add(sub)
). - subscriberCount() - Method in class rx.subjects.BehaviorSubject
- subscriberCount() - Method in class rx.subjects.ReplaySubject
- SubscriberIterator() - Constructor for class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- subscribers - Variable in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- subscribers - Variable in class rx.internal.operators.OnSubscribePublishMulticast
-
A copy-on-write array of currently subscribed child subscribers' wrapper structure.
- subscribers - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- subscribers - Variable in class rx.internal.operators.OperatorZip.Zip
- Subscribers - Class in rx.observers
-
Helper methods and utilities for creating and working with
Subscriber
objects. - Subscribers() - Constructor for class rx.observers.Subscribers
- subscribeTo(Observable<? extends T>) - Method in class rx.internal.operators.DeferredScalarSubscriber
-
Links up with the downstream Subscriber (cancellation, backpressure) and subscribes to the source Observable.
- subscribeToAlternate() - Method in class rx.internal.operators.OperatorSwitchIfEmpty.ParentSubscriber
- subscription - Variable in class rx.internal.operators.OperatorMulticast
-
Guarded by guard.
- subscription - Variable in class rx.internal.schedulers.SchedulerWhen
- subscription - Variable in class rx.subscriptions.MultipleAssignmentSubscription.State
- subscription - Variable in class rx.subscriptions.SerialSubscription.State
- Subscription - Interface in rx
-
Subscription returns from
Observable.subscribe(Subscriber)
to allow unsubscribing. - subscriptionCount - Variable in class rx.internal.operators.OnSubscribeRefCount
- subscriptionDelay - Variable in class rx.internal.operators.OnSubscribeDelaySubscriptionWithSelector
- SubscriptionList - Class in rx.internal.util
-
Subscription that represents a group of Subscriptions that are unsubscribed together.
- SubscriptionList() - Constructor for class rx.internal.util.SubscriptionList
-
Constructs an empty SubscriptionList.
- SubscriptionList(Subscription) - Constructor for class rx.internal.util.SubscriptionList
-
Constructs a SubscriptionList with the given initial child subscription.
- SubscriptionList(Subscription...) - Constructor for class rx.internal.util.SubscriptionList
-
Constructs a SubscriptionList with the given initial child subscriptions.
- SubscriptionProducer(Subscriber<? super T>, SyncOnSubscribe<S, T>, S) - Constructor for class rx.observables.SyncOnSubscribe.SubscriptionProducer
- subscriptions - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Tracks the active subscriptions to sources.
- subscriptions - Variable in class rx.internal.util.SubscriptionList
- subscriptions - Variable in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- subscriptions - Variable in class rx.Subscriber
- subscriptions - Variable in class rx.subscriptions.CompositeSubscription
- Subscriptions - Class in rx.subscriptions
-
Helper methods and utilities for creating and working with
Subscription
objects - Subscriptions() - Constructor for class rx.subscriptions.Subscriptions
- Subscriptions.FutureSubscription - Class in rx.subscriptions
-
Naming classes helps with debugging.
- Subscriptions.Unsubscribed - Class in rx.subscriptions
-
Naming classes helps with debugging.
- SuppressAnimalSniffer - Annotation Type in rx.internal.util
-
Suppress errors by the AnimalSniffer plugin.
- svElement(AtomicReferenceArray<E>, int, E) - Method in class rx.internal.util.atomic.AtomicReferenceArrayQueue
- svProducerIndexCache(long) - Method in class rx.internal.util.unsafe.SpmcArrayQueueProducerIndexCacheField
- switchIfEmpty(Observable<? extends T>) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable or the items of an alternate Observable if the source Observable is empty.
- switchMap(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Returns a new Observable by applying a function that you supply to each item emitted by the source Observable that returns an Observable, and then emitting the items emitted by the most recently emitted of these Observables.
- switchMapDelayError(Func1<? super T, ? extends Observable<? extends R>>) - Method in class rx.Observable
-
Returns a new Observable by applying a function that you supply to each item emitted by the source Observable that returns an Observable, and then emitting the items emitted by the most recently emitted of these Observables and delays any error until all Observables terminate.
- switchOnNext(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Converts an Observable that emits Observables into an Observable that emits the items emitted by the most recently emitted of those Observables.
- switchOnNextDelayError(Observable<? extends Observable<? extends T>>) - Static method in class rx.Observable
-
Converts an Observable that emits Observables into an Observable that emits the items emitted by the most recently emitted of those Observables and delays any exception until all Observables terminate.
- SwitchSubscriber(Subscriber<? super T>, boolean) - Constructor for class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- SynchronizedQueue<T> - Class in rx.internal.util
-
Intended for use when the `sun.misc.Unsafe` implementations can't be used.
- SynchronizedQueue() - Constructor for class rx.internal.util.SynchronizedQueue
- SynchronizedQueue(int) - Constructor for class rx.internal.util.SynchronizedQueue
- SyncOnSubscribe<S,T> - Class in rx.observables
-
A utility class to create
OnSubscribe<T>
functions that respond correctly to back pressure requests from subscribers. - SyncOnSubscribe() - Constructor for class rx.observables.SyncOnSubscribe
- SyncOnSubscribe.SubscriptionProducer<S,T> - Class in rx.observables
-
Contains the producer loop that reacts to downstream requests of work.
- SyncOnSubscribe.SyncOnSubscribeImpl<S,T> - Class in rx.observables
-
An implementation of SyncOnSubscribe that delegates
SyncOnSubscribe#next(Object, Subscriber)
,SyncOnSubscribe.generateState()
, andSyncOnSubscribe.onUnsubscribe(Object)
to provided functions/closures. - SyncOnSubscribeImpl(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>) - Constructor for class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- SyncOnSubscribeImpl(Func0<? extends S>, Func2<? super S, ? super Observer<? super T>, ? extends S>, Action1<? super S>) - Constructor for class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- SyncOnSubscribeImpl(Func2<S, Observer<? super T>, S>) - Constructor for class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
- SyncOnSubscribeImpl(Func2<S, Observer<? super T>, S>, Action1<? super S>) - Constructor for class rx.observables.SyncOnSubscribe.SyncOnSubscribeImpl
T
- t - Variable in class rx.internal.util.ScalarSynchronousObservable
-
The constant scalar value to emit on request.
- tail - Variable in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
- tail - Variable in class rx.internal.util.LinkedArrayList
-
The tail array where new elements will be added.
- tail - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- tail - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- tail - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- tail() - Method in class rx.internal.util.LinkedArrayList
-
Returns the tail buffer segment or null if the list is empty.
- tailIndex - Variable in class rx.subjects.ReplaySubject.ReplayProducer
-
Unbounded buffer.drain() uses this index within its current node to indicate how many items were replayed from that particular node so far.
- tailIndex - Variable in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- take() - Method in class rx.internal.operators.BlockingOperatorToIterator.SubscriberIterator
- take(int) - Method in class rx.Observable
-
Returns an Observable that emits only the first
count
items emitted by the source Observable. - take(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits those items emitted by source Observable before a specified time runs out.
- take(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits those items emitted by source Observable before a specified time (on a specified Scheduler) runs out.
- takeFirst(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits only the very first item emitted by the source Observable that satisfies a specified condition.
- takeLast(int) - Method in class rx.Observable
-
Returns an Observable that emits at most the last
count
items emitted by the source Observable. - takeLast(int, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits at most a specified number of items from the source Observable that were emitted in a specified window of time before the Observable completed.
- takeLast(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits at most a specified number of items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a given Scheduler.
- takeLast(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits the items from the source Observable that were emitted in a specified window of time before the Observable completed.
- takeLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits the items from the source Observable that were emitted in a specified window of time before the Observable completed, where the timing information is provided by a specified Scheduler.
- takeLastBuffer(int) - Method in class rx.Observable
-
Returns an Observable that emits a single List containing at most the last
count
elements emitted by the source Observable. - takeLastBuffer(int, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits a single List containing at most
count
items from the source Observable that were emitted during a specified window of time before the source Observable completed. - takeLastBuffer(int, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits a single List containing at most
count
items from the source Observable that were emitted during a specified window of time (on a specified Scheduler) before the source Observable completed. - takeLastBuffer(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed.
- takeLastBuffer(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits a single List containing those items from the source Observable that were emitted during a specified window of time before the source Observable completed, where the timing information is provided by the given Scheduler.
- TakeLastOneSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OnSubscribeTakeLastOne.TakeLastOneSubscriber
- TakeLastSubscriber(Subscriber<? super T>, int) - Constructor for class rx.internal.operators.OperatorTakeLast.TakeLastSubscriber
- TakeLastTimedSubscriber(Subscriber<? super T>, int, long, Scheduler) - Constructor for class rx.internal.operators.OperatorTakeLastTimed.TakeLastTimedSubscriber
- takeNext() - Method in class rx.internal.operators.BlockingOperatorNext.NextObserver
- TakeSubscriber(Subscriber<? super T>) - Constructor for class rx.internal.operators.OperatorTakeTimed.TakeSubscriber
- takeUntil(Completable) - Method in class rx.Single
-
Returns a Single that emits the item emitted by the source Single until a Completable terminates.
- takeUntil(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits items emitted by the source Observable, checks the specified predicate for each item, and then completes if the condition is satisfied.
- takeUntil(Observable<? extends E>) - Method in class rx.Observable
-
Returns an Observable that emits the items emitted by the source Observable until a second Observable emits an item.
- takeUntil(Observable<? extends E>) - Method in class rx.Single
-
Returns a Single that emits the item emitted by the source Single until an Observable emits an item.
- takeUntil(Single<? extends E>) - Method in class rx.Single
-
Returns a Single that emits the item emitted by the source Single until a second Single emits an item.
- takeWhile(Func1<? super T, Boolean>) - Method in class rx.Observable
-
Returns an Observable that emits items emitted by the source Observable so long as each item satisfied a specified condition, and then completes as soon as this condition is not satisfied.
- tasks - Variable in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- terminal - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
-
Written before done, read after done.
- TERMINAL_ERROR - Static variable in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- terminalEvent - Variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Contains either an onCompleted or an onError token from upstream.
- terminalNotification - Variable in class rx.internal.operators.OperatorMaterialize.ParentSubscriber
- terminalState - Variable in class rx.internal.util.RxRingBuffer
-
We store the terminal state separately so it doesn't count against the size.
- terminate - Variable in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
-
Guarded by this.
- terminate() - Method in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- terminate() - Method in class rx.internal.operators.OnSubscribePublishMulticast
-
Atomically swaps in the terminated state.
- terminate() - Method in class rx.internal.util.BackpressureDrainManager
-
Move into a terminal state.
- terminate() - Method in class rx.internal.util.OpenHashSet
- terminate(Object) - Method in class rx.subjects.SubjectSubscriptionManager
-
Atomically set the terminal NotificationLite value (which could be any of the 3), clear the active observers and return the last active observers.
- terminate(Throwable) - Method in class rx.internal.util.BackpressureDrainManager
-
Move into a terminal state with an exception.
- terminate(AtomicReference<Throwable>) - Static method in enum rx.internal.util.ExceptionsUtils
-
Atomically swaps in the terminal Throwable and returns the previous contents of the field
- terminateAndDrain() - Method in class rx.internal.util.BackpressureDrainManager
-
Move into a terminal state and drain.
- terminateAndDrain(Throwable) - Method in class rx.internal.util.BackpressureDrainManager
-
Move into a terminal state with an exception and drain.
- terminateChunk(OperatorWindowWithTime.CountedSerializedSubject<T>) - Method in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- terminated - Variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Indicates no further InnerProducers are accepted.
- terminated - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
-
Guarded by this.
- terminated - Variable in class rx.internal.util.BackpressureDrainManager
-
Indicates a terminal state.
- terminated - Variable in class rx.observers.SerializedObserver
-
Set to true if a terminal event was received.
- terminated - Variable in class rx.subjects.SubjectSubscriptionManager.State
- TERMINATED - Static variable in class rx.internal.operators.OnSubscribePublishMulticast
-
Represents a final state for this class that prevents new subscribers from subscribing to it.
- TERMINATED - Static variable in class rx.internal.operators.OperatorPublish.PublishSubscriber
-
Indicates a terminated PublishSubscriber.
- TERMINATED - Static variable in class rx.internal.operators.OperatorReplay.ReplaySubscriber
-
Indicates a terminated ReplaySubscriber.
- TERMINATED - Static variable in enum rx.internal.util.ExceptionsUtils
-
The single instance of a Throwable indicating a terminal state.
- TERMINATED - Static variable in class rx.subjects.ReplaySubject.ReplayState
- TERMINATED - Static variable in class rx.subjects.SubjectSubscriptionManager.State
- TerminatedProducer() - Constructor for enum rx.internal.operators.OnSubscribeDetach.TerminatedProducer
- terminateOnce - Variable in class rx.subjects.UnicastSubject.State
-
Atomically set to true on terminal condition.
- test() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
TestScheduler
, which is useful for debugging. - TestObserver<T> - Class in rx.observers
-
Deprecated.use the
TestSubscriber
insteand. - TestObserver() - Constructor for class rx.observers.TestObserver
-
Deprecated.
- TestObserver(Observer<T>) - Constructor for class rx.observers.TestObserver
-
Deprecated.
- TestScheduler - Class in rx.schedulers
-
The
TestScheduler
is useful for debugging. - TestScheduler() - Constructor for class rx.schedulers.TestScheduler
- TestScheduler.CompareActionsByTime - Class in rx.schedulers
- TestScheduler.InnerTestScheduler - Class in rx.schedulers
- TestScheduler.TimedAction - Class in rx.schedulers
- TestSubject<T> - Class in rx.subjects
-
A variety of Subject that is useful for testing purposes.
- TestSubject(Observable.OnSubscribe<T>, SubjectSubscriptionManager<T>, TestScheduler) - Constructor for class rx.subjects.TestSubject
- TestSubscriber<T> - Class in rx.observers
-
A
TestSubscriber
is a variety ofSubscriber
that you can use for unit testing, to perform assertions, inspect received events, or wrap a mockedSubscriber
. - TestSubscriber() - Constructor for class rx.observers.TestSubscriber
-
Constructs a TestSubscriber with an initial request of Long.MAX_VALUE and no delegation.
- TestSubscriber(long) - Constructor for class rx.observers.TestSubscriber
-
Constructs a TestSubscriber with the initial request to be requested from upstream.
- TestSubscriber(Observer<T>) - Constructor for class rx.observers.TestSubscriber
-
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to the given Observer.
- TestSubscriber(Observer<T>, long) - Constructor for class rx.observers.TestSubscriber
-
Constructs a TestSubscriber with the initial request to be requested from upstream and a delegate Observer to wrap.
- TestSubscriber(Subscriber<T>) - Constructor for class rx.observers.TestSubscriber
-
Constructs a TestSubscriber which requests Long.MAX_VALUE and delegates events to the given Subscriber.
- that - Variable in class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- THREAD_FACTORY - Static variable in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
- THREAD_NAME_PREFIX - Static variable in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
- threadFactory - Variable in class rx.internal.schedulers.CachedThreadScheduler.CachedWorkerPool
- threadFactory - Variable in class rx.internal.schedulers.CachedThreadScheduler
- threadFactory - Variable in class rx.internal.schedulers.EventLoopsScheduler
- threadFactory - Variable in class rx.internal.schedulers.NewThreadScheduler
- threadFactory() - Static method in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
- threadWorker - Variable in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- ThreadWorker(ThreadFactory) - Constructor for class rx.internal.schedulers.CachedThreadScheduler.ThreadWorker
- THRESHOLD - Static variable in class rx.internal.operators.OperatorZip.Zip
- throttleFirst(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits only the first item emitted by the source Observable during sequential time windows of a specified duration.
- throttleFirst(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits only the first item emitted by the source Observable during sequential time windows of a specified duration, where the windows are managed by a specified Scheduler.
- throttleLast(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable during sequential time windows of a specified duration.
- throttleLast(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits only the last item emitted by the source Observable during sequential time windows of a specified duration, where the duration is governed by a specified Scheduler.
- throttleWithTimeout(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that only emits those items emitted by the source Observable that are not followed by another emitted item within a specified time window.
- throttleWithTimeout(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that only emits those items emitted by the source Observable that are not followed by another emitted item within a specified time window, where the time window is governed by a specified Scheduler.
- throwable - Variable in class rx.Notification
- throwIfAny(List<? extends Throwable>) - Static method in class rx.exceptions.Exceptions
-
Throws a single or multiple exceptions contained in the collection, wrapping it into
CompositeException
if necessary. - throwIfFatal(Throwable) - Static method in class rx.exceptions.Exceptions
-
Throws a particular
Throwable
only if it belongs to a set of "fatal" error varieties. - throwOrReport(Throwable, Observer<?>) - Static method in class rx.exceptions.Exceptions
-
Forwards a fatal exception or reports it to the given Observer.
- throwOrReport(Throwable, Observer<?>, Object) - Static method in class rx.exceptions.Exceptions
-
Forwards a fatal exception or reports it along with the value caused it to the given Observer.
- throwOrReport(Throwable, SingleSubscriber<?>) - Static method in class rx.exceptions.Exceptions
-
Forwards a fatal exception or reports it to the given Observer.
- tick() - Method in class rx.internal.operators.OperatorZip.Zip
-
check if we have values for each and emit if we do This will only allow one thread at a time to do the work, but ensures via `counter` increment/decrement that there is always once who acts on each `tick`.
- time - Variable in class rx.internal.operators.OnSubscribeDelaySubscription
- time - Variable in class rx.internal.operators.OnSubscribeTimerOnce
- time - Variable in class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- time - Variable in class rx.internal.operators.OperatorSampleWithTime
- time - Variable in class rx.internal.operators.OperatorSkipTimed
- time - Variable in class rx.internal.operators.OperatorTakeTimed
- time - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- time - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- time - Variable in class rx.schedulers.TestScheduler
- time - Variable in class rx.schedulers.TestScheduler.TimedAction
- timed - Variable in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- TimedAction(Action0, Long, int) - Constructor for class rx.internal.schedulers.TrampolineScheduler.TimedAction
- TimedAction(Scheduler.Worker, long, Action0) - Constructor for class rx.schedulers.TestScheduler.TimedAction
- TimedNode(T, long) - Constructor for class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer.TimedNode
- timeInMillis - Variable in class rx.internal.operators.OperatorSkipLastTimed
- timeInMilliseconds - Variable in class rx.internal.operators.OperatorThrottleFirst
- timeInterval() - Method in class rx.Observable
-
Returns an Observable that emits records of the time interval between consecutive items emitted by the source Observable.
- timeInterval(Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits records of the time interval between consecutive items emitted by the source Observable, where this interval is computed on a specified Scheduler.
- TimeInterval<T> - Class in rx.schedulers
-
A
TimeInterval
represents an item emitted by anObservable
along with the amount of time that elapsed either since the emission of the previous item or (if there was no previous item) since theObservable
was first subscribed to. - TimeInterval(long, T) - Constructor for class rx.schedulers.TimeInterval
-
Creates a
TimeInterval
object. - timeout - Variable in class rx.internal.operators.CompletableOnSubscribeTimeout
- timeout - Variable in class rx.internal.operators.OperatorDebounceWithTime
- timeout(long, TimeUnit) - Method in class rx.Completable
-
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time.
- timeout(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item.
- timeout(long, TimeUnit) - Method in class rx.Single
-
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
- timeout(long, TimeUnit, Completable) - Method in class rx.Completable
-
Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time.
- timeout(long, TimeUnit, Observable<? extends T>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item.
- timeout(long, TimeUnit, Observable<? extends T>, Scheduler) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item using a specified Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class rx.Completable
-
Returns a Completable that runs this Completable and emits a TimeoutException in case this Completable doesn't complete within the given time while "waiting" on the specified Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable but applies a timeout policy for each emitted item, where this policy is governed on a specified Scheduler.
- timeout(long, TimeUnit, Scheduler) - Method in class rx.Single
-
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, where this policy is governed on a specified Scheduler.
- timeout(long, TimeUnit, Scheduler, Completable) - Method in class rx.Completable
-
Returns a Completable that runs this Completable and switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.
- timeout(long, TimeUnit, Single<? extends T>) - Method in class rx.Single
-
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
- timeout(long, TimeUnit, Single<? extends T>, Scheduler) - Method in class rx.Single
-
Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, using a specified Scheduler.
- timeout(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, but notifies observers of a
TimeoutException
if either the first item emitted by the source Observable or any subsequent item doesn't arrive within time windows defined by other Observables. - timeout(Func0<? extends Observable<U>>, Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, but switches to a fallback Observable if either the first item emitted by the source Observable or any subsequent item doesn't arrive within time windows defined by other Observables.
- timeout(Func1<? super T, ? extends Observable<V>>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, but notifies observers of a
TimeoutException
if an item emitted by the source Observable doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an Observable that is a function of the previous item. - timeout(Func1<? super T, ? extends Observable<V>>, Observable<? extends T>) - Method in class rx.Observable
-
Returns an Observable that mirrors the source Observable, but that switches to a fallback Observable if an item emitted by the source Observable doesn't arrive within a window of time after the emission of the previous item, where that period of time is measured by an Observable that is a function of the previous item.
- timeout0(long, TimeUnit, Scheduler, Completable) - Method in class rx.Completable
-
Returns a Completable that runs this Completable and optionally switches to the other Completable in case this Completable doesn't complete within the given time while "waiting" on the specified scheduler.
- timeoutStub - Variable in class rx.internal.operators.OperatorTimeoutBase
- timeoutStub - Variable in class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- TimeoutSubscriber(SerializedSubscriber<T>, OperatorTimeoutBase.TimeoutStub<T>, SerialSubscription, Observable<? extends T>, Scheduler.Worker) - Constructor for class rx.internal.operators.OperatorTimeoutBase.TimeoutSubscriber
- timer(long, long, TimeUnit) - Static method in class rx.Observable
-
Deprecated.use
Observable.interval(long, long, TimeUnit)
instead - timer(long, long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Deprecated.
- timer(long, TimeUnit) - Static method in class rx.Completable
-
Returns a Completable instance that fires its onComplete event after the given delay elapsed.
- timer(long, TimeUnit) - Static method in class rx.Observable
-
Returns an Observable that emits one item after a specified delay, and then completes.
- timer(long, TimeUnit, Scheduler) - Static method in class rx.Completable
-
Returns a Completable instance that fires its onCompleted event after the given delay elapsed by using the supplied scheduler.
- timer(long, TimeUnit, Scheduler) - Static method in class rx.Observable
-
Returns an Observable that emits one item after a specified delay, on a specified Scheduler, and then completes.
- timeshift - Variable in class rx.internal.operators.OperatorBufferWithTime
- timeshift - Variable in class rx.internal.operators.OperatorWindowWithTime
-
Period of creating new windows.
- timespan - Variable in class rx.internal.operators.OperatorBufferWithTime
- timespan - Variable in class rx.internal.operators.OperatorWindowWithTime
-
Length of each window.
- timestamp - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer.TimedNode
- timestamp() - Method in class rx.Observable
-
Returns an Observable that emits each item emitted by the source Observable, wrapped in a
Timestamped
object. - timestamp(Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits each item emitted by the source Observable, wrapped in a
Timestamped
object whose timestamps are provided by a specified Scheduler. - Timestamped<T> - Class in rx.schedulers
-
Composite class that takes a value and a timestamp and wraps them.
- Timestamped(long, T) - Constructor for class rx.schedulers.Timestamped
- timestampMillis - Variable in class rx.schedulers.Timestamped
- to(Func1<? super Completable, U>) - Method in class rx.Completable
-
Allows fluent conversion to another type via a function callback.
- TO_ARRAY - Static variable in enum rx.internal.util.InternalObservableUtils
-
A function that converts a List of Observables into an array of Observables.
- toAction1(Action0) - Static method in class rx.functions.Actions
-
Wraps an Action0 instance into an Action1 instance where the latter calls the former.
- toArray() - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- toArray() - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- toArray() - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- toArray() - Method in class rx.internal.util.SynchronizedQueue
- toArray(E[]) - Method in class rx.internal.util.atomic.SpscExactAtomicArrayQueue
- toArray(E[]) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- toArray(E[]) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
- toArray(R[]) - Method in class rx.internal.util.SynchronizedQueue
- toArray(T[]) - Method in interface rx.subjects.ReplaySubject.ReplayBuffer
- toArray(T[]) - Method in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer
- toArray(T[]) - Method in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer
- toArray(T[]) - Method in class rx.subjects.ReplaySubject.ReplayUnboundedBuffer
- ToArrayFunc1() - Constructor for class rx.internal.util.InternalObservableUtils.ToArrayFunc1
- toBlocking() - Method in class rx.Observable
-
Converts an Observable into a
BlockingObservable
(an Observable with blocking operators). - toBlocking() - Method in class rx.Single
-
Converts a Single into a
BlockingSingle
(a Single with blocking operators). - toCompletable() - Method in class rx.Observable
-
Returns a Completable that discards all onNext emissions (similar to
ignoreAllElements()
) and calls onCompleted when this source observable calls onCompleted. - toCompletable() - Method in class rx.Single
-
Returns a
Completable
that discards result of theSingle
(similar toObservable.ignoreElements()
) and callsonCompleted
when this sourceSingle
callsonSuccess
. - toFunc(Action0) - Static method in class rx.functions.Actions
-
Converts an
Action0
to a function that calls the action and returnsnull
. - toFunc(Action0, R) - Static method in class rx.functions.Actions
-
Converts an
Action0
to a function that calls the action and returns a specified value. - toFunc(Action1<T1>) - Static method in class rx.functions.Actions
-
Converts an
Action1
to a function that calls the action and returnsnull
. - toFunc(Action1<T1>, R) - Static method in class rx.functions.Actions
-
Converts an
Action1
to a function that calls the action and returns a specified value. - toFunc(Action2<T1, T2>) - Static method in class rx.functions.Actions
-
Converts an
Action2
to a function that calls the action and returnsnull
. - toFunc(Action2<T1, T2>, R) - Static method in class rx.functions.Actions
-
Converts an
Action2
to a function that calls the action and returns a specified value. - toFunc(Action3<T1, T2, T3>) - Static method in class rx.functions.Actions
-
Converts an
Action3
to a function that calls the action and returnsnull
. - toFunc(Action3<T1, T2, T3>, R) - Static method in class rx.functions.Actions
-
Converts an
Action3
to a function that calls the action and returns a specified value. - toFunc(Action4<T1, T2, T3, T4>) - Static method in class rx.functions.Actions
-
Converts an
Action4
to a function that calls the action and returnsnull
. - toFunc(Action4<T1, T2, T3, T4>, R) - Static method in class rx.functions.Actions
-
Converts an
Action4
to a function that calls the action and returns a specified value. - toFunc(Action5<T1, T2, T3, T4, T5>) - Static method in class rx.functions.Actions
-
Converts an
Action5
to a function that calls the action and returnsnull
. - toFunc(Action5<T1, T2, T3, T4, T5>, R) - Static method in class rx.functions.Actions
-
Converts an
Action5
to a function that calls the action and returns a specified value. - toFunc(Action6<T1, T2, T3, T4, T5, T6>) - Static method in class rx.functions.Actions
-
Converts an
Action6
to a function that calls the action and returnsnull
. - toFunc(Action6<T1, T2, T3, T4, T5, T6>, R) - Static method in class rx.functions.Actions
-
Converts an
Action6
to a function that calls the action and returns a specified value. - toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>) - Static method in class rx.functions.Actions
-
Converts an
Action7
to a function that calls the action and returnsnull
. - toFunc(Action7<T1, T2, T3, T4, T5, T6, T7>, R) - Static method in class rx.functions.Actions
-
Converts an
Action7
to a function that calls the action and returns a specified value. - toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>) - Static method in class rx.functions.Actions
-
Converts an
Action8
to a function that calls the action and returnsnull
. - toFunc(Action8<T1, T2, T3, T4, T5, T6, T7, T8>, R) - Static method in class rx.functions.Actions
-
Converts an
Action8
to a function that calls the action and returns a specified value. - toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>) - Static method in class rx.functions.Actions
-
Converts an
Action9
to a function that calls the action and returnsnull
. - toFunc(Action9<T1, T2, T3, T4, T5, T6, T7, T8, T9>, R) - Static method in class rx.functions.Actions
-
Converts an
Action9
to a function that calls the action and returns a specified value. - toFunc(ActionN) - Static method in class rx.functions.Actions
-
Converts an
ActionN
to a function that calls the action and returnsnull
. - toFunc(ActionN, R) - Static method in class rx.functions.Actions
-
Converts an
ActionN
to a function that calls the action and returns a specified value. - toFuture() - Method in class rx.observables.BlockingObservable
-
Returns a
Future
representing the single value emitted by thisBlockingObservable
. - toFuture() - Method in class rx.singles.BlockingSingle
-
Returns a
Future
representing the value emitted by thisBlockingSingle
. - toFuture(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorToFuture
-
Returns a Future that expects a single item from the observable.
- toIterable() - Method in class rx.observables.BlockingObservable
-
Converts this
BlockingObservable
into anIterable
. - toIterator(Observable<? extends T>) - Static method in class rx.internal.operators.BlockingOperatorToIterator
-
Returns an iterator that iterates all values of the observable.
- toList() - Method in class rx.internal.util.LinkedArrayList
- toList() - Method in class rx.Observable
-
Returns an Observable that emits a single item, a list composed of all the items emitted by the source Observable.
- toMap(Func1<? super T, ? extends K>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap containing all items emitted by the source Observable, mapped by the keys returned by a specified
keySelector
function. - toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap containing values corresponding to items emitted by the source Observable, mapped by the keys returned by a specified
keySelector
function. - toMap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, V>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified
mapFactory
function, that contains keys and values extracted from the items emitted by the source Observable. - toMultimap(Func1<? super T, ? extends K>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap that contains an ArrayList of items emitted by the source Observable keyed by a specified
keySelector
function. - toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>) - Method in class rx.Observable
-
Returns an Observable that emits a single HashMap that contains an ArrayList of values extracted by a specified
valueSelector
function from items emitted by the source Observable, keyed by a specifiedkeySelector
function. - toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified
mapFactory
function, that contains an ArrayList of values, extracted by a specifiedvalueSelector
function from items emitted by the source Observable and keyed by thekeySelector
function. - toMultimap(Func1<? super T, ? extends K>, Func1<? super T, ? extends V>, Func0<? extends Map<K, Collection<V>>>, Func1<? super K, ? extends Collection<V>>) - Method in class rx.Observable
-
Returns an Observable that emits a single Map, returned by a specified
mapFactory
function, that contains a custom collection of values, extracted by a specifiedvalueSelector
function from items emitted by the source Observable, and keyed by thekeySelector
function. - toNpe(Throwable) - Static method in class rx.Completable
-
Creates a NullPointerException instance and sets the given Throwable as its initial cause.
- toObservable() - Method in class rx.Completable
-
Returns an Observable which when subscribed to subscribes to this Completable and relays the terminal events to the subscriber.
- toObservable() - Method in class rx.Single
-
Converts this Single into an
Observable
. - toObservableFuture(Future<? extends T>) - Static method in class rx.internal.operators.OnSubscribeToObservableFuture
- toObservableFuture(Future<? extends T>, long, TimeUnit) - Static method in class rx.internal.operators.OnSubscribeToObservableFuture
- ToObservableFuture(Future<? extends T>) - Constructor for class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- ToObservableFuture(Future<? extends T>, long, TimeUnit) - Constructor for class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- toPredicate2(Func1<? super T, Boolean>) - Static method in class rx.internal.operators.OperatorSkipWhile
-
Convert to Func2 type predicate.
- toSerialized() - Method in class rx.subjects.Subject
-
Wraps a
Subject
so that it is safe to call its variouson
methods from different threads. - toSingle() - Method in class rx.Observable
-
Returns a Single that emits the single item emitted by the source Observable, if that Observable emits only a single item.
- toSingle(Func0<? extends T>) - Method in class rx.Completable
-
Converts this Completable into a Single which when this Completable completes normally, calls the given supplier and emits its returned value through onSuccess.
- toSingleDefault(T) - Method in class rx.Completable
-
Converts this Completable into a Single which when this Completable completes normally, emits the given value through onSuccess.
- toSkip - Variable in class rx.internal.operators.OperatorSkip
- toSortedList() - Method in class rx.Observable
-
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order.
- toSortedList(int) - Method in class rx.Observable
-
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order.
- toSortedList(Func2<? super T, ? super T, Integer>) - Method in class rx.Observable
-
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order based on a specified comparison function.
- toSortedList(Func2<? super T, ? super T, Integer>, int) - Method in class rx.Observable
-
Returns an Observable that emits a list that contains the items emitted by the source Observable, in a sorted order based on a specified comparison function.
- toString() - Method in class rx.internal.operators.NotificationLite.OnErrorSentinel
- toString() - Method in class rx.internal.util.LinkedArrayList
- toString() - Method in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- toString() - Method in class rx.internal.util.SynchronizedQueue
- toString() - Method in class rx.Notification
- toString() - Method in class rx.schedulers.TestScheduler.TimedAction
- toString() - Method in class rx.schedulers.TimeInterval
- toString() - Method in class rx.schedulers.Timestamped
- totalRequested - Variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
Keeps the sum of all requested amounts.
- trampoline() - Static method in class rx.schedulers.Schedulers
-
Creates and returns a
Scheduler
that queues work on the current thread to be executed after the current work completes. - TrampolineScheduler - Class in rx.internal.schedulers
-
Schedules work on the current thread but does not execute immediately.
- TrampolineScheduler - Class in rx.schedulers
-
Deprecated.This type was never publicly instantiable. Use
Schedulers.trampoline()
. - TrampolineScheduler() - Constructor for class rx.internal.schedulers.TrampolineScheduler
- TrampolineScheduler() - Constructor for class rx.schedulers.TrampolineScheduler
-
Deprecated.
- TrampolineScheduler.InnerCurrentThreadScheduler - Class in rx.internal.schedulers
- TrampolineScheduler.TimedAction - Class in rx.internal.schedulers
- transformer - Variable in class rx.internal.operators.OnSubscribeMap
- transformer - Variable in class rx.internal.operators.SingleOnSubscribeMap
- triggerActions() - Method in class rx.schedulers.TestScheduler
-
Triggers any actions that have not yet been triggered and that are scheduled to be triggered at or before this Scheduler's present time.
- triggerActions(long) - Method in class rx.schedulers.TestScheduler
- truncate() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Override this method to truncate a non-terminated buffer based on its current properties.
- truncate() - Method in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- truncate() - Method in class rx.internal.operators.OperatorReplay.SizeBoundReplayBuffer
- truncateFinal() - Method in class rx.internal.operators.OperatorReplay.BoundedReplayBuffer
-
Override this method to truncate a terminated buffer based on its properties (i.e., truncate but the very last node).
- truncateFinal() - Method in class rx.internal.operators.OperatorReplay.SizeAndTimeBoundReplayBuffer
- tryEmit() - Method in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- tryEmit(long) - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- tryEmit(OperatorMerge.InnerSubscriber<T>, T) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Tries to emit the value directly to the child if no concurrent emission is happening at the moment.
- tryEmit(T) - Method in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Tries to emit the value directly to the child if no concurrent emission is happening at the moment.
- tryEnableCancelPolicy(ScheduledExecutorService) - Static method in class rx.internal.schedulers.NewThreadWorker
-
Tries to enable the Java 7+ setRemoveOnCancelPolicy.
- tryUnsubscribe() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
U
- UnboundedReplayBuffer(int) - Constructor for class rx.internal.operators.OperatorReplay.UnboundedReplayBuffer
- underlying - Variable in class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc
- underlying - Variable in class rx.internal.schedulers.SleepingAction
- UnicastSubject<T> - Class in rx.subjects
-
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.
- UnicastSubject(AsyncOnSubscribe.UnicastSubject.State<T>) - Constructor for class rx.observables.AsyncOnSubscribe.UnicastSubject
- UnicastSubject(UnicastSubject.State<T>) - Constructor for class rx.subjects.UnicastSubject
- UnicastSubject.State<T> - Class in rx.subjects
-
The single-consumption replaying state.
- uniqueId - Variable in class rx.internal.operators.OperatorMerge.MergeSubscriber
-
Used to generate unique InnerSubscriber IDs.
- unit - Variable in class rx.internal.operators.CompletableOnSubscribeTimeout
- unit - Variable in class rx.internal.operators.OnSubscribeDelaySubscription
- unit - Variable in class rx.internal.operators.OnSubscribeTimerOnce
- unit - Variable in class rx.internal.operators.OnSubscribeTimerPeriodically
- unit - Variable in class rx.internal.operators.OnSubscribeToObservableFuture.ToObservableFuture
- unit - Variable in class rx.internal.operators.OperatorBufferWithTime
- unit - Variable in class rx.internal.operators.OperatorDebounceWithTime
- unit - Variable in class rx.internal.operators.OperatorDelay
- unit - Variable in class rx.internal.operators.OperatorSampleWithTime
- unit - Variable in class rx.internal.operators.OperatorSkipTimed
- unit - Variable in class rx.internal.operators.OperatorTakeTimed
- unit - Variable in class rx.internal.operators.OperatorWindowWithTime
- unit - Variable in class rx.internal.schedulers.SchedulerWhen.DelayedAction
- unit - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierBufferTime
- unit - Variable in class rx.internal.util.InternalObservableUtils.ReplaySupplierTime
- UNSAFE - Static variable in class rx.internal.util.unsafe.UnsafeAccess
- UnsafeAccess - Class in rx.internal.util.unsafe
-
All use of this class MUST first check that UnsafeAccess.isUnsafeAvailable() == true otherwise NPEs will happen in environments without "suc.misc.Unsafe" such as Android.
- UnsafeAccess() - Constructor for class rx.internal.util.unsafe.UnsafeAccess
- unsafeArray - Variable in class rx.internal.util.IndexedRingBuffer.IndexSection
- unsafeSubscribe(Completable.CompletableSubscriber) - Method in class rx.Completable
-
Subscribes the given CompletableSubscriber to this Completable instance.
- unsafeSubscribe(Subscriber<? super T>) - Method in class rx.Observable
-
Subscribes to an Observable and invokes
Observable.OnSubscribe
function without any contract protection, error handling, unsubscribe, or execution hooks. - unsafeSubscribe(Subscriber<? super T>) - Method in class rx.Single
-
Subscribes to a Single and invokes the
Single.OnSubscribe
function without any contract protection, error handling, unsubscribe, or execution hooks. - unsafeSubscribe(Subscriber<T>) - Method in class rx.Completable
-
Subscribes a regular Subscriber to this Completable instance which will receive only an onError or onComplete event.
- unsafeSubscribe(Subscriber<T>, boolean) - Method in class rx.Completable
-
Performs the actual unsafe subscription and calls the onStart if required.
- unsubscribe - Variable in class rx.internal.operators.OperatorDoOnUnsubscribe
- unsubscribe() - Method in class rx.internal.operators.CachedObservable.ReplayProducer
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeCombineLatest.LatestCoordinator
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeDetach.DetachProducer
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeFromAsync.BaseAsyncEmitter
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeFromAsync.CancellableSubscription
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeGroupJoin.ResultManager
- unsubscribe() - Method in class rx.internal.operators.OnSubscribePublishMulticast.PublishProducer
- unsubscribe() - Method in class rx.internal.operators.OnSubscribePublishMulticast
- unsubscribe() - Method in class rx.internal.operators.OnSubscribeUsing.DisposeAction
- unsubscribe() - Method in class rx.internal.operators.OperatorGroupBy.State
- unsubscribe() - Method in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- unsubscribe() - Method in class rx.internal.operators.OperatorPublish.InnerProducer
- unsubscribe() - Method in class rx.internal.operators.OperatorReplay.InnerProducer
- unsubscribe() - Method in class rx.internal.schedulers.CachedThreadScheduler.EventLoopWorker
- unsubscribe() - Method in class rx.internal.schedulers.EventLoopsScheduler.EventLoopWorker
- unsubscribe() - Method in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- unsubscribe() - Method in class rx.internal.schedulers.ImmediateScheduler.InnerImmediateScheduler
- unsubscribe() - Method in class rx.internal.schedulers.NewThreadWorker
- unsubscribe() - Method in class rx.internal.schedulers.ScheduledAction.FutureCompleter
- unsubscribe() - Method in class rx.internal.schedulers.ScheduledAction.Remover
- unsubscribe() - Method in class rx.internal.schedulers.ScheduledAction.Remover2
- unsubscribe() - Method in class rx.internal.schedulers.ScheduledAction
- unsubscribe() - Method in class rx.internal.schedulers.SchedulerWhen.ScheduledAction
- unsubscribe() - Method in class rx.internal.schedulers.SchedulerWhen
- unsubscribe() - Method in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- unsubscribe() - Method in class rx.internal.util.IndexedRingBuffer
- unsubscribe() - Method in class rx.internal.util.RxRingBuffer
- unsubscribe() - Method in class rx.internal.util.SubscriptionList
-
Unsubscribe from all of the subscriptions in the list, which stops the receipt of notifications on the associated
Subscriber
. - unsubscribe() - Method in class rx.observables.AsyncOnSubscribe.AsyncOuterManager
- unsubscribe() - Method in class rx.observables.SyncOnSubscribe.SubscriptionProducer
- unsubscribe() - Method in class rx.observers.AsyncCompletableSubscriber
- unsubscribe() - Method in class rx.observers.AsyncCompletableSubscriber.Unsubscribed
- unsubscribe() - Method in class rx.observers.SafeCompletableSubscriber
- unsubscribe() - Method in class rx.schedulers.TestScheduler.InnerTestScheduler
- unsubscribe() - Method in class rx.SingleSubscriber
- unsubscribe() - Method in class rx.subjects.ReplaySubject.ReplayProducer
- unsubscribe() - Method in class rx.subjects.UnicastSubject.State
-
Terminates the state by setting the done flag and tries to clear the queue.
- unsubscribe() - Method in class rx.Subscriber
- unsubscribe() - Method in interface rx.Subscription
-
Stops the receipt of notifications on the
Subscriber
that was registered when this Subscription was received. - unsubscribe() - Method in class rx.subscriptions.BooleanSubscription
- unsubscribe() - Method in class rx.subscriptions.CompositeSubscription
-
Unsubscribes itself and all inner subscriptions.
- unsubscribe() - Method in class rx.subscriptions.MultipleAssignmentSubscription.State
- unsubscribe() - Method in class rx.subscriptions.MultipleAssignmentSubscription
- unsubscribe() - Method in class rx.subscriptions.RefCountSubscription.InnerSubscription
- unsubscribe() - Method in class rx.subscriptions.RefCountSubscription.State
- unsubscribe() - Method in class rx.subscriptions.RefCountSubscription
- unsubscribe() - Method in class rx.subscriptions.SerialSubscription.State
- unsubscribe() - Method in class rx.subscriptions.SerialSubscription
- unsubscribe() - Method in class rx.subscriptions.Subscriptions.FutureSubscription
- unsubscribe() - Method in class rx.subscriptions.Subscriptions.Unsubscribed
- UNSUBSCRIBE - Static variable in class rx.observables.BlockingObservable
-
Indicates an unsubscription happened
- unsubscribeAChild() - Method in class rx.subscriptions.RefCountSubscription
- unsubscribeActualIfApplicable(RefCountSubscription.State) - Method in class rx.subscriptions.RefCountSubscription
- unsubscribeAmbSubscribers(Collection<OnSubscribeAmb.AmbSubscriber<T>>) - Static method in class rx.internal.operators.OnSubscribeAmb
- unsubscribed - Variable in class rx.internal.util.SubscriptionList
- unsubscribed - Variable in class rx.subscriptions.CompositeSubscription
- unsubscribed() - Static method in class rx.subscriptions.Subscriptions
-
Returns a
Subscription
to whichunsubscribe
does nothing, as it is already unsubscribed. - Unsubscribed() - Constructor for class rx.observers.AsyncCompletableSubscriber.Unsubscribed
- Unsubscribed() - Constructor for class rx.subscriptions.Subscriptions.Unsubscribed
- UNSUBSCRIBED - Static variable in class rx.internal.operators.OperatorPublish.InnerProducer
-
Indicates this child has been unsubscribed: the state is swapped in atomically and will prevent the dispatch() to emit (too many) values to a terminated child subscriber.
- UNSUBSCRIBED - Static variable in class rx.internal.operators.OperatorReplay.InnerProducer
-
Indicates this child has been unsubscribed: the state is swapped in atomically and will prevent the dispatch() to emit (too many) values to a terminated child subscriber.
- UNSUBSCRIBED - Static variable in class rx.internal.schedulers.SchedulerWhen
- UNSUBSCRIBED - Static variable in class rx.observers.AsyncCompletableSubscriber
-
Indicates the unsubscribed state.
- UNSUBSCRIBED - Static variable in class rx.subscriptions.Subscriptions
-
A
Subscription
that does nothing when its unsubscribe method is called. - UnsubscribeFailedException - Exception in rx.exceptions
-
Represents an exception used to re-throw errors thrown from
Subscriber.unsubscribe()
. - UnsubscribeFailedException(String, Throwable) - Constructor for exception rx.exceptions.UnsubscribeFailedException
-
Customizes the
Throwable
with a custom message and wraps it before it is to be re-thrown as anUnsubscribeFailedException
. - UnsubscribeFailedException(Throwable) - Constructor for exception rx.exceptions.UnsubscribeFailedException
-
Wraps the
Throwable
before it is to be re-thrown as anOnErrorFailedException
. - unsubscribeFromAll(Collection<Subscription>) - Static method in class rx.internal.util.SubscriptionList
- unsubscribeFromAll(Collection<Subscription>) - Static method in class rx.subscriptions.CompositeSubscription
- unsubscribeLosers() - Method in class rx.internal.operators.OnSubscribeAmb.Selection
- unsubscribeOn(Scheduler) - Method in class rx.Completable
-
Returns a Completable which makes sure when a subscriber cancels the subscription, the dispose is called on the specified scheduler
- unsubscribeOn(Scheduler) - Method in class rx.Observable
-
Modifies the source Observable so that subscribers will unsubscribe from it on a specified
Scheduler
. - unsubscribeOthers(OnSubscribeAmb.AmbSubscriber<T>) - Method in class rx.internal.operators.OnSubscribeAmb.Selection
- updateError(Throwable) - Method in class rx.internal.operators.OperatorSwitch.SwitchSubscriber
- upstream - Variable in class rx.observers.AsyncCompletableSubscriber
-
Holds onto a deferred subscription and allows asynchronous cancellation before the call to onSubscribe() by the upstream.
- using(Func0<R>, Func1<? super R, ? extends Completable>, Action1<? super R>) - Static method in class rx.Completable
-
Returns a Completable instance which manages a resource along with a custom Completable instance while the subscription is active.
- using(Func0<R>, Func1<? super R, ? extends Completable>, Action1<? super R>, boolean) - Static method in class rx.Completable
-
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.
- using(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>) - Static method in class rx.Observable
-
Constructs an Observable that creates a dependent resource object which is disposed of on unsubscription.
- using(Func0<Resource>, Func1<? super Resource, ? extends Observable<? extends T>>, Action1<? super Resource>, boolean) - Static method in class rx.Observable
-
Constructs an Observable that creates a dependent resource object which is disposed of just before termination if you have set
disposeEagerly
totrue
and unsubscription does not occur before termination. - using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>) - Static method in class rx.Single
-
Constructs an Single that creates a dependent resource object which is disposed of on unsubscription.
- using(Func0<Resource>, Func1<? super Resource, ? extends Single<? extends T>>, Action1<? super Resource>, boolean) - Static method in class rx.Single
-
Constructs an Single that creates a dependent resource object which is disposed of just before termination if you have set
disposeEagerly
totrue
and unsubscription does not occur before termination. - UtilityFunctions - Class in rx.internal.util
-
Utility functions for internal use that we don't want part of the public API.
- UtilityFunctions() - Constructor for class rx.internal.util.UtilityFunctions
-
Utility class.
- UtilityFunctions.AlwaysFalse - Enum in rx.internal.util
- UtilityFunctions.AlwaysTrue - Enum in rx.internal.util
V
- validate(long) - Static method in class rx.internal.operators.BackpressureUtils
-
Validates the requested amount and returns true if it is positive.
- validationInterval - Variable in class rx.internal.util.ObjectPool
- value - Variable in exception rx.exceptions.OnErrorThrowable.OnNextValue
- value - Variable in exception rx.exceptions.OnErrorThrowable
- value - Variable in class rx.internal.operators.BlockingOperatorLatest.LatestObserverIterator
- value - Variable in class rx.internal.operators.BlockingOperatorMostRecent.MostRecentObserver
- value - Variable in class rx.internal.operators.DeferredScalarSubscriber
-
The holder of the single value.
- value - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapInnerScalarProducer
- value - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.OnSubscribeScalarFlattenIterable
- value - Variable in class rx.internal.operators.OnSubscribeReduce.ReduceSubscriber
- value - Variable in class rx.internal.operators.OperatorDebounceWithTime.DebounceState
-
Guarded by this.
- value - Variable in class rx.internal.operators.OperatorMapNotification.MapNotificationSubscriber
- value - Variable in class rx.internal.operators.OperatorOnBackpressureLatest.LatestEmitter
- value - Variable in class rx.internal.operators.OperatorReplay.Node
-
The contained value.
- value - Variable in class rx.internal.operators.OperatorSampleWithTime.SamplerSubscriber
-
The shared value between the observer and the timed action.
- value - Variable in class rx.internal.operators.OperatorSingle.ParentSubscriber
- value - Variable in class rx.internal.producers.SingleDelayedProducer
-
The value to emit.
- value - Variable in class rx.internal.producers.SingleProducer
-
The value to be emitted.
- value - Variable in class rx.internal.util.atomic.LinkedQueueNode
- value - Variable in class rx.internal.util.ScalarSynchronousObservable.JustOnSubscribe
- value - Variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncOnSubscribe
- value - Variable in class rx.internal.util.ScalarSynchronousObservable.ScalarAsyncProducer
- value - Variable in class rx.internal.util.ScalarSynchronousObservable.WeakSingleProducer
- value - Variable in class rx.internal.util.ScalarSynchronousSingle.DirectScheduledEmission
- value - Variable in class rx.internal.util.ScalarSynchronousSingle.NormalScheduledEmission
- value - Variable in class rx.internal.util.ScalarSynchronousSingle.ScalarSynchronousSingleAction
- value - Variable in class rx.internal.util.ScalarSynchronousSingle
- value - Variable in class rx.Notification
- value - Variable in class rx.schedulers.TimeInterval
- value - Variable in class rx.schedulers.Timestamped
- value - Variable in class rx.subjects.ReplaySubject.ReplaySizeAndTimeBoundBuffer.TimedNode
- value - Variable in class rx.subjects.ReplaySubject.ReplaySizeBoundBuffer.Node
- value() - Method in class rx.singles.BlockingSingle
-
Returns the item emitted by this
BlockingSingle
. - valueCount - Variable in class rx.observers.TestSubscriber
-
Written after an onNext value has been added to the
TestSubscriber.values
list. - valueOf(String) - Static method in enum rx.AsyncEmitter.BackpressureMode
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.operators.EmptyObservableHolder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.operators.NeverObservableHolder
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.operators.OnSubscribeDetach.TerminatedProducer
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.util.ExceptionsUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.util.UtilityFunctions.AlwaysFalse
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.internal.util.UtilityFunctions.AlwaysTrue
-
Returns the enum constant of this type with the specified name.
- valueOf(String) - Static method in enum rx.Notification.Kind
-
Returns the enum constant of this type with the specified name.
- values - Variable in class rx.observers.TestSubscriber
- values() - Static method in enum rx.AsyncEmitter.BackpressureMode
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.operators.EmptyObservableHolder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.operators.NeverObservableHolder
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.operators.OnSubscribeDetach.TerminatedProducer
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.schedulers.GenericScheduledExecutorServiceFactory
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.util.ExceptionsUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.util.InternalObservableUtils
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Method in class rx.internal.util.OpenHashSet
-
Returns the raw array of values of this set, watch out for null entires.
- values() - Static method in enum rx.internal.util.UtilityFunctions.AlwaysFalse
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.internal.util.UtilityFunctions.AlwaysTrue
-
Returns an array containing the constants of this enum type, in the order they are declared.
- values() - Static method in enum rx.Notification.Kind
-
Returns an array containing the constants of this enum type, in the order they are declared.
- valueSelector - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- valueSelector - Variable in class rx.internal.operators.OperatorGroupBy
- valueSelector - Variable in class rx.internal.operators.OperatorToMap
- valueSelector - Variable in class rx.internal.operators.OperatorToMultimap
W
- waiting - Variable in class rx.internal.operators.BlockingOperatorNext.NextObserver
- waitingForConnect - Variable in class rx.internal.operators.OperatorMulticast
- WeakSingleProducer(Subscriber<? super T>, T) - Constructor for class rx.internal.util.ScalarSynchronousObservable.WeakSingleProducer
- when(Func1<Observable<Observable<Completable>>, Completable>) - Method in class rx.Scheduler
-
Allows the use of operators for controlling the timing around when actions scheduled on workers are actually done.
- window - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- window - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- window(int) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(int, int) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, long, TimeUnit, int, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, TimeUnit) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, TimeUnit, int) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, TimeUnit, int, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(long, TimeUnit, Scheduler) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(Func0<? extends Observable<? extends TClosing>>) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(Observable<? extends TOpening>, Func1<? super TOpening, ? extends Observable<? extends TClosing>>) - Method in class rx.Observable
-
Returns an Observable that emits windows of items it collects from the source Observable.
- window(Observable<U>) - Method in class rx.Observable
-
Returns an Observable that emits non-overlapping windows of items it collects from the source Observable where the boundary of each window is determined by the items emitted from a specified boundary-governing Observable.
- windowClosingSelector - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable
- WindowExact(Subscriber<? super Observable<T>>, int) - Constructor for class rx.internal.operators.OperatorWindowWithSize.WindowExact
- WindowObservableFunc(Observable<T>, RefCountSubscription) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc
- windowOpenings - Variable in class rx.internal.operators.OperatorWindowWithStartEndObservable
- WindowOverlap(Subscriber<? super Observable<T>>, int, int) - Constructor for class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- WindowOverlapProducer() - Constructor for class rx.internal.operators.OperatorWindowWithSize.WindowOverlap.WindowOverlapProducer
- windows - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- WindowSkip(Subscriber<? super Observable<T>>, int, int) - Constructor for class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- WindowSkipProducer() - Constructor for class rx.internal.operators.OperatorWindowWithSize.WindowSkip.WindowSkipProducer
- WindowSubscriber(Subscriber<? super T>, Subscription) - Constructor for class rx.internal.operators.OnSubscribeGroupJoin.WindowObservableFunc.WindowSubscriber
- wip - Variable in class rx.internal.operators.CompletableOnSubscribeConcat.CompletableConcatSubscriber
- wip - Variable in class rx.internal.operators.CompletableOnSubscribeMerge.CompletableMergeSubscriber
- wip - Variable in class rx.internal.operators.OnSubscribeConcatMap.ConcatMapSubscriber
- wip - Variable in class rx.internal.operators.OnSubscribeFlattenIterable.FlattenIterableSubscriber
- wip - Variable in class rx.internal.operators.OnSubscribeFromAsync.BufferAsyncEmitter
- wip - Variable in class rx.internal.operators.OnSubscribeFromAsync.LatestAsyncEmitter
- wip - Variable in class rx.internal.operators.OperatorEagerConcatMap.EagerOuterSubscriber
- wip - Variable in class rx.internal.operators.OperatorGroupBy.GroupBySubscriber
- wip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowExact
- wip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowOverlap
- wip - Variable in class rx.internal.operators.OperatorWindowWithSize.WindowSkip
- wip - Variable in class rx.internal.producers.QueuedProducer
- wip - Variable in class rx.internal.producers.QueuedValueProducer
- wip - Variable in class rx.internal.schedulers.ExecutorScheduler.ExecutorSchedulerWorker
- wip - Variable in class rx.internal.schedulers.TrampolineScheduler.InnerCurrentThreadScheduler
- withException(Observable<? extends T>) - Static method in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- withFunction(Single<? extends T>, Func1<Throwable, ? extends Single<? extends T>>) - Static method in class rx.internal.operators.SingleOperatorOnErrorResumeNext
- withLatestFrom(Iterable<Observable<?>>, FuncN<R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<?>[], FuncN<R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<? extends U>, Func2<? super T, ? super U, ? extends R>) - Method in class rx.Observable
-
Merges the specified Observable into this Observable sequence by using the
resultSelector
function only when the source Observable (this instance) emits an item. - withLatestFrom(Observable<T1>, Observable<T2>, Func3<? super T, ? super T1, ? super T2, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Func6<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Func7<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Func8<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Observable<T1>, Observable<T2>, Func9<? super T, ? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Func4<? super T, ? super T1, ? super T2, ? super T3, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- withLatestFrom(Observable<T1>, Observable<T2>, Observable<T3>, Observable<T4>, Func5<? super T, ? super T1, ? super T2, ? super T3, ? super T4, R>) - Method in class rx.Observable
-
Combines the value emission from this Observable with the latest emissions from the other Observables via a function to produce the output item.
- WithLatestMainSubscriber(Subscriber<? super R>, FuncN<R>, int) - Constructor for class rx.internal.operators.OperatorWithLatestFromMany.WithLatestMainSubscriber
- WithLatestOtherSubscriber(OperatorWithLatestFromMany.WithLatestMainSubscriber<?, ?>, int) - Constructor for class rx.internal.operators.OperatorWithLatestFromMany.WithLatestOtherSubscriber
- withOther(Observable<? extends T>) - Static method in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- withOther(Single<? extends T>, Single<? extends T>) - Static method in class rx.internal.operators.SingleOperatorOnErrorResumeNext
- withSingle(Func1<Throwable, ? extends T>) - Static method in class rx.internal.operators.OperatorOnErrorResumeNextViaFunction
- worker - Variable in class rx.internal.operators.OperatorWindowWithTime.ExactSubscriber
- worker - Variable in class rx.internal.operators.OperatorWindowWithTime.InexactSubscriber
- Worker() - Constructor for class rx.Scheduler.Worker
- workerObserver - Variable in class rx.internal.schedulers.SchedulerWhen
- wrap(Subscriber<? super T>) - Static method in class rx.observers.Subscribers
-
Returns a new
Subscriber
that passes all events tosubscriber
, has backpressure controlled bysubscriber
and uses the subscription list ofsubscriber
whenSubscriber.add(rx.Subscription)
is called. - WrappedPrintStream(PrintStream) - Constructor for class rx.exceptions.CompositeException.WrappedPrintStream
- WrappedPrintWriter(PrintWriter) - Constructor for class rx.exceptions.CompositeException.WrappedPrintWriter
- writeToQueue(E[], E, long, long) - Method in class rx.internal.util.unsafe.SpscUnboundedArrayQueue
- writeToQueue(AtomicReferenceArray<Object>, T, long, int) - Method in class rx.internal.util.atomic.SpscLinkedArrayQueue
- writeToQueue(AtomicReferenceArray<Object>, T, long, int) - Method in class rx.internal.util.atomic.SpscUnboundedAtomicArrayQueue
X
- xchgProducerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.atomic.BaseLinkedAtomicQueue
- xchgProducerNode(LinkedQueueNode<E>) - Method in class rx.internal.util.unsafe.MpscLinkedQueue
Z
- zip(Iterable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an Iterable of other Observables.
- zip(Iterable<? extends Single<?>>, FuncN<? extends R>) - Static method in class rx.Single
-
Returns a Single that emits the result of specified combiner function applied to combination of items emitted, in sequence, by an Iterable of other Singles.
- zip(Observable<?>[], FuncN<? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of items emitted, in sequence, by an array of other Observables.
- zip(Observable<? extends Observable<?>>, FuncN<? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of n items emitted, in sequence, by the n Observables emitted by a specified Observable.
- zip(Observable<? extends T1>, Observable<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of two items emitted, in sequence, by two other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of three items emitted, in sequence, by three other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of four items emitted, in sequence, by four other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of five items emitted, in sequence, by five other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of six items emitted, in sequence, by six other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of seven items emitted, in sequence, by seven other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of eight items emitted, in sequence, by eight other Observables.
- zip(Observable<? extends T1>, Observable<? extends T2>, Observable<? extends T3>, Observable<? extends T4>, Observable<? extends T5>, Observable<? extends T6>, Observable<? extends T7>, Observable<? extends T8>, Observable<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Observable
-
Returns an Observable that emits the results of a specified combiner function applied to combinations of nine items emitted, in sequence, by nine other Observables.
- zip(Single<? extends T>[], FuncN<? extends R>) - Static method in class rx.internal.operators.SingleOperatorZip
- zip(Single<? extends T1>, Single<? extends T2>, Func2<? super T1, ? super T2, ? extends R>) - Static method in class rx.Single
-
Returns a Single that emits the results of a specified combiner function applied to two items emitted by two other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Func3<? super T1, ? super T2, ? super T3, ? extends R>) - Static method in class rx.Single
-
Returns a Single that emits the results of a specified combiner function applied to three items emitted by three other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Func4<? super T1, ? super T2, ? super T3, ? super T4, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to four items emitted by four other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Func5<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to five items emitted by five other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Func6<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to six items emitted by six other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Func7<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to seven items emitted by seven other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Single<? extends T8>, Func8<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to eight items emitted by eight other Singles.
- zip(Single<? extends T1>, Single<? extends T2>, Single<? extends T3>, Single<? extends T4>, Single<? extends T5>, Single<? extends T6>, Single<? extends T7>, Single<? extends T8>, Single<? extends T9>, Func9<? super T1, ? super T2, ? super T3, ? super T4, ? super T5, ? super T6, ? super T7, ? super T8, ? super T9, ? extends R>) - Static method in class rx.Single
-
Returns an Observable that emits the results of a specified combiner function applied to nine items emitted by nine other Singles.
- Zip(Subscriber<? super R>, FuncN<? extends R>) - Constructor for class rx.internal.operators.OperatorZip.Zip
- zipFunction - Variable in class rx.internal.operators.OperatorZip.Zip
- zipFunction - Variable in class rx.internal.operators.OperatorZip
- zipFunction - Variable in class rx.internal.operators.OperatorZipIterable
- zipper - Variable in class rx.internal.operators.OperatorZip.ZipProducer
- zipper - Variable in class rx.internal.operators.OperatorZip.ZipSubscriber
- ZipProducer(OperatorZip.Zip<R>) - Constructor for class rx.internal.operators.OperatorZip.ZipProducer
- ZipSubscriber(Subscriber<? super R>, OperatorZip.Zip<R>, OperatorZip.ZipProducer<R>) - Constructor for class rx.internal.operators.OperatorZip.ZipSubscriber
- zipWith(Iterable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source Observable and a specified Iterable sequence.
- zipWith(Observable<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.Observable
-
Returns an Observable that emits items that are the result of applying a specified function to pairs of values, one each from the source Observable and another specified Observable.
- zipWith(Single<? extends T2>, Func2<? super T, ? super T2, ? extends R>) - Method in class rx.Single
-
Returns a Single that emits the result of applying a specified function to the pair of items emitted by the source Single and another specified Single.
_
- _next - Variable in class rx.internal.util.IndexedRingBuffer.IndexSection
- _onError(Throwable) - Method in class rx.observers.SafeSubscriber
-
The logic for
onError
without theisFinished
check so it can be called from withinonCompleted
.
All Classes All Packages