Package rx

Class Single<T>

java.lang.Object
rx.Single<T>
Type Parameters:
T - the type of the item emitted by the Single
Direct Known Subclasses:
ScalarSynchronousSingle

@Beta public class Single<T> extends Object
The Single class implements the Reactive Pattern for a single value response. See Observable for the implementation of the Reactive Pattern for a stream or vector of values.

Single behaves the same as Observable except that it can only emit either a single successful value, or an error (there is no "onComplete" notification as there is for Observable)

Like an Observable, a Single is lazy, can be either "hot" or "cold", synchronous or asynchronous.

The documentation for this class makes use of marble diagrams. The following legend explains these diagrams:

For more information see the ReactiveX documentation.

Since:
(If this class graduates from "Experimental" replace this parenthetical with the release number)
  • Nested Class Summary

    Nested Classes
    Modifier and Type
    Class
    Description
    static interface 
    Invoked when Single.execute is called.
    static interface 
  • Field Summary

    Fields
    Modifier and Type
    Field
    Description
    (package private) final Observable.OnSubscribe<T>
     
  • Constructor Summary

    Constructors
    Modifier
    Constructor
    Description
    private
     
    protected
    Creates a Single with a Function to execute when it is subscribed to (executed).
  • Method Summary

    Modifier and Type
    Method
    Description
    private static <T> Observable<T>
    <R> Single<R>
    compose(Single.Transformer<? super T,? extends R> transformer)
    Transform a Single by applying a particular Transformer function to it.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2)
    Returns an Observable that emits the items emitted by two Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3)
    Returns an Observable that emits the items emitted by three Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4)
    Returns an Observable that emits the items emitted by four Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5)
    Returns an Observable that emits the items emitted by five Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6)
    Returns an Observable that emits the items emitted by six Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7)
    Returns an Observable that emits the items emitted by seven Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8)
    Returns an Observable that emits the items emitted by eight Singles, one after the other.
    static <T> Observable<T>
    concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8, Single<? extends T> t9)
    Returns an Observable that emits the items emitted by nine Singles, one after the other.
    final Observable<T>
    concatWith(Single<? extends T> t1)
    Returns an Observable that emits the item emitted by the source Single, then the item emitted by the specified Single.
    static <T> Single<T>
    Returns a Single that will execute the specified function when a SingleSubscriber executes it or a Subscriber subscribes to it.
    static <T> Single<T>
    defer(Callable<Single<T>> singleFactory)
    Returns a Single that calls a Single factory to create a Single for each new Observer that subscribes.
    final Single<T>
    delay(long delay, TimeUnit unit)
    Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
    final Single<T>
    delay(long delay, TimeUnit unit, Scheduler scheduler)
    Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay.
    final Single<T>
    Returns a Single that delays the subscription to this Single until the Observable completes.
    final Single<T>
    Registers an Action0 to be called when this Single invokes either SingleSubscriber.onSuccess(Object) onSuccess} or onError.
    final Single<T>
    Modifies the source Single so that it invokes an action if it calls onError.
    final Single<T>
    Modifies the source Single so that it invokes the given action when it is subscribed from its subscribers.
    final Single<T>
    doOnSuccess(Action1<? super T> onSuccess)
    Modifies the source Single so that it invokes an action when it calls onSuccess.
    final Single<T>
    Modifies the source Single so that it invokes the given action when it is unsubscribed from its subscribers.
    static <T> Single<T>
    error(Throwable exception)
    Returns a Single that invokes a subscriber's onError method when the subscriber subscribes to it.
    final <R> Single<R>
    flatMap(Func1<? super T,? extends Single<? extends R>> func)
    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.
    final <R> Observable<R>
    flatMapObservable(Func1<? super T,? extends Observable<? extends R>> func)
    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.
    static <T> Single<T>
    from(Future<? extends T> future)
    Converts a Future into a Single.
    static <T> Single<T>
    from(Future<? extends T> future, long timeout, TimeUnit unit)
    Converts a Future into a Single, with a timeout on the Future.
    static <T> Single<T>
    from(Future<? extends T> future, Scheduler scheduler)
    Converts a Future, operating on a specified Scheduler, into a Single.
    static <T> Single<T>
    fromCallable(Callable<? extends T> func)
    Returns a Single that invokes passed function and emits its result for each new Observer that subscribes.
    (package private) static <T> Single<? extends T>[]
    iterableToArray(Iterable<? extends Single<? extends T>> singlesIterable)
    FOR INTERNAL USE ONLY.
    static <T> Single<T>
    just(T value)
    Returns a Single that emits a specified item.
    final <R> Single<R>
    lift(Observable.Operator<? extends R,? super T> lift)
    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.
    final <R> Single<R>
    map(Func1<? super T,? extends R> func)
    Returns a Single that applies a specified function to the item emitted by the source Single and emits the result of this function application.
    static <T> Single<T>
    merge(Single<? extends Single<? extends T>> source)
    Flattens a Single that emits a Single into a single Single that emits the item emitted by the nested Single, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2)
    Flattens two Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3)
    Flattens three Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4)
    Flattens four Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5)
    Flattens five Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6)
    Flattens six Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7)
    Flattens seven Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8)
    Flattens eight Singles into a single Observable, without any transformation.
    static <T> Observable<T>
    merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8, Single<? extends T> t9)
    Flattens nine Singles into a single Observable, without any transformation.
    final Observable<T>
    mergeWith(Single<? extends T> t1)
    Flattens this and another Single into a single Observable, without any transformation.
    private Single<Observable<T>>
    INTERNAL: Used with lift and operators.
    final Single<T>
    observeOn(Scheduler scheduler)
    Modifies a Single to emit its item (or notify of its error) on a specified Scheduler, asynchronously.
    final Single<T>
    onErrorResumeNext(Func1<Throwable,? extends Single<? extends T>> resumeFunctionInCaseOfError)
    Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.
    final Single<T>
    onErrorResumeNext(Single<? extends T> resumeSingleInCaseOfError)
    Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.
    final Single<T>
    onErrorReturn(Func1<Throwable,? extends T> resumeFunction)
    Instructs a Single to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.
    final Single<T>
    Returns a Single that mirrors the source Single, resubscribing to it if it calls onError (infinite retry count).
    final Single<T>
    retry(long count)
    Returns an Single that mirrors the source Single, resubscribing to it if it calls onError up to a specified number of retries.
    final Single<T>
    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.
    final Single<T>
    retryWhen(Func1<Observable<? extends Throwable>,? extends Observable<?>> notificationHandler)
    Returns a Single that emits the same values as the source Single with the exception of an onError.
    Subscribes to a Single but ignore its emission or notification.
    subscribe(Action1<? super T> onSuccess)
    Subscribes to a Single and provides a callback to handle the item it emits.
    subscribe(Action1<? super T> onSuccess, Action1<Throwable> onError)
    Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it issues.
    subscribe(Observer<? super T> observer)
    Subscribes an Observer to this single and returns a Subscription that allows unsubscription.
    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> subscriber)
    Subscribes to a Single and provides a Subscriber that implements functions to handle the item the Single emits or any error notification it issues.
    final Single<T>
    Asynchronously subscribes subscribers to this Single on the specified Scheduler.
    final Single<T>
    Returns a Single that emits the item emitted by the source Single until a Completable terminates.
    final <E> Single<T>
    takeUntil(Observable<? extends E> other)
    Returns a Single that emits the item emitted by the source Single until an Observable emits an item.
    final <E> Single<T>
    takeUntil(Single<? extends E> other)
    Returns a Single that emits the item emitted by the source Single until a second Single emits an item.
    final Single<T>
    timeout(long timeout, TimeUnit timeUnit)
    Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
    final Single<T>
    timeout(long timeout, TimeUnit timeUnit, Scheduler scheduler)
    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.
    final Single<T>
    timeout(long timeout, TimeUnit timeUnit, Single<? extends T> other)
    Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item.
    final Single<T>
    timeout(long timeout, TimeUnit timeUnit, Single<? extends T> other, Scheduler scheduler)
    Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, using a specified Scheduler.
    Converts a Single into a BlockingSingle (a Single with blocking operators).
    Returns a Completable that discards result of the Single (similar to Observable.ignoreElements()) and calls onCompleted when this source Single calls onSuccess.
    final Observable<T>
    Converts this Single into an Observable.
    unsafeSubscribe(Subscriber<? super T> subscriber)
    Subscribes to a Single and invokes the Single.OnSubscribe function without any contract protection, error handling, unsubscribe, or execution hooks.
    static <T, Resource>
    Single<T>
    using(Func0<Resource> resourceFactory, Func1<? super Resource,? extends Single<? extends T>> singleFactory, Action1<? super Resource> disposeAction)
    Constructs an Single that creates a dependent resource object which is disposed of on unsubscription.
    static <T, Resource>
    Single<T>
    using(Func0<Resource> resourceFactory, Func1<? super Resource,? extends Single<? extends T>> singleFactory, Action1<? super Resource> disposeAction, boolean disposeEagerly)
    Constructs an Single that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and unsubscription does not occur before termination.
    static <R> Single<R>
    zip(Iterable<? extends Single<?>> singles, FuncN<? extends R> zipFunction)
    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.
    static <T1, T2, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Func2<? super T1,? super T2,? extends R> zipFunction)
    Returns a Single that emits the results of a specified combiner function applied to two items emitted by two other Singles.
    static <T1, T2, T3, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Func3<? super T1,? super T2,? super T3,? extends R> zipFunction)
    Returns a Single that emits the results of a specified combiner function applied to three items emitted by three other Singles.
    static <T1, T2, T3, T4, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Func4<? super T1,? super T2,? super T3,? super T4,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to four items emitted by four other Singles.
    static <T1, T2, T3, T4, T5, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Func5<? super T1,? super T2,? super T3,? super T4,? super T5,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to five items emitted by five other Singles.
    static <T1, T2, T3, T4, T5, T6, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Func6<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to six items emitted by six other Singles.
    static <T1, T2, T3, T4, T5, T6, T7, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Func7<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to seven items emitted by seven other Singles.
    static <T1, T2, T3, T4, T5, T6, T7, T8, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Single<? extends T8> s8, Func8<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to eight items emitted by eight other Singles.
    static <T1, T2, T3, T4, T5, T6, T7, T8, T9, R>
    Single<R>
    zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Single<? extends T8> s8, Single<? extends T9> s9, Func9<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? super T9,? extends R> zipFunction)
    Returns an Observable that emits the results of a specified combiner function applied to nine items emitted by nine other Singles.
    final <T2, R> Single<R>
    zipWith(Single<? extends T2> other, Func2<? super T,? super T2,? extends R> zipFunction)
    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.

    Methods inherited from class java.lang.Object

    clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
  • Field Details

  • Constructor Details

    • Single

      protected Single(Single.OnSubscribe<T> f)
      Creates a Single with a Function to execute when it is subscribed to (executed).

      Note: Use create(OnSubscribe) to create a Single, instead of this constructor, unless you specifically have a need for inheritance.

      Parameters:
      f - OnExecute to be executed when execute(SingleSubscriber) or subscribe(Subscriber) is called
    • Single

      private Single(Observable.OnSubscribe<T> f)
  • Method Details

    • create

      public static <T> Single<T> create(Single.OnSubscribe<T> f)
      Returns a Single that will execute the specified function when a SingleSubscriber executes it or a Subscriber subscribes to it.

      Write the function you pass to create so that it behaves as a Single: It should invoke the SingleSubscriber onSuccess and/or onError methods appropriately.

      A well-formed Single must invoke either the SingleSubscriber's onSuccess method exactly once or its onError method exactly once.

      Scheduler:
      create does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of the item that this Single emits
      Parameters:
      f - a function that accepts an SingleSubscriber<T>, and invokes its onSuccess or onError methods as appropriate
      Returns:
      a Single that, when a Subscriber subscribes to it, will execute the specified function
      See Also:
    • lift

      @Experimental public final <R> Single<R> lift(Observable.Operator<? extends R,? super T> lift)
      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.

      In other words, this allows chaining TaskExecutors together on a Single for acting on the values within the Single.

      task.map(...).filter(...).lift(new OperatorA()).lift(new OperatorB(...)).subscribe()

      If the operator you are creating is designed to act on the item emitted by a source Single, use lift. If your operator is designed to transform the source Single as a whole (for instance, by applying a particular set of existing RxJava operators to it) use compose(rx.Single.Transformer<? super T, ? extends R>).

      Scheduler:
      lift does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the downstream's value type (output)
      Parameters:
      lift - the Operator that implements the Single-operating function to be applied to the source Single
      Returns:
      a Single that is the result of applying the lifted Operator to the source Single
      See Also:
    • compose

      public <R> Single<R> compose(Single.Transformer<? super T,? extends R> transformer)
      Transform a Single by applying a particular Transformer function to it.

      This method operates on the Single itself whereas lift(rx.Observable.Operator<? extends R, ? super T>) operates on the Single's Subscribers or Observers.

      If the operator you are creating is designed to act on the individual item emitted by a Single, use lift(rx.Observable.Operator<? extends R, ? super T>). If your operator is designed to transform the source Single as a whole (for instance, by applying a particular set of existing RxJava operators to it) use compose.

      Scheduler:
      compose does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the value type of the single returned by the transformer function
      Parameters:
      transformer - implements the function that transforms the source Single
      Returns:
      the source Single, transformed by the transformer function
      See Also:
    • asObservable

      private static <T> Observable<T> asObservable(Single<T> t)
    • nest

      private Single<Observable<T>> nest()
      INTERNAL: Used with lift and operators. Converts the source Single<T> into an Single<Observable<T>> that emits an Observable that emits the same emission as the source Single.

      Scheduler:
      nest does not operate by default on a particular Scheduler.
      Returns:
      a Single that emits an Observable that emits the same item as the source Single
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2)
      Returns an Observable that emits the items emitted by two Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - an Single to be concatenated
      t2 - an Single to be concatenated
      Returns:
      an Observable that emits items emitted by the two source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3)
      Returns an Observable that emits the items emitted by three Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the three source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4)
      Returns an Observable that emits the items emitted by four Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the four source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5)
      Returns an Observable that emits the items emitted by five Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      t5 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the five source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6)
      Returns an Observable that emits the items emitted by six Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      t5 - a Single to be concatenated
      t6 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the six source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7)
      Returns an Observable that emits the items emitted by seven Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      t5 - a Single to be concatenated
      t6 - a Single to be concatenated
      t7 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the seven source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8)
      Returns an Observable that emits the items emitted by eight Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      t5 - a Single to be concatenated
      t6 - a Single to be concatenated
      t7 - a Single to be concatenated
      t8 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the eight source Singles, one after the other.
      See Also:
    • concat

      public static <T> Observable<T> concat(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8, Single<? extends T> t9)
      Returns an Observable that emits the items emitted by nine Singles, one after the other.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be concatenated
      t2 - a Single to be concatenated
      t3 - a Single to be concatenated
      t4 - a Single to be concatenated
      t5 - a Single to be concatenated
      t6 - a Single to be concatenated
      t7 - a Single to be concatenated
      t8 - a Single to be concatenated
      t9 - a Single to be concatenated
      Returns:
      an Observable that emits items emitted by the nine source Singles, one after the other.
      See Also:
    • error

      public static <T> Single<T> error(Throwable exception)
      Returns a Single that invokes a subscriber's onError method when the subscriber subscribes to it.

      Scheduler:
      error does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of the item (ostensibly) emitted by the Single
      Parameters:
      exception - the particular Throwable to pass to onError
      Returns:
      a Single that invokes the subscriber's onError method when the subscriber subscribes to it
      See Also:
    • from

      public static <T> Single<T> from(Future<? extends T> future)
      Converts a Future into a Single.

      You can convert any object that supports the Future interface into a Single that emits the return value of the Future.get() method of that object, by passing the object into the from method.

      Important note: This Single is blocking; you cannot unsubscribe from it.

      Scheduler:
      from does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of object that the Future returns, and also the type of item to be emitted by the resulting Single
      Parameters:
      future - the source Future
      Returns:
      a Single that emits the item from the source Future
      See Also:
    • from

      public static <T> Single<T> from(Future<? extends T> future, long timeout, TimeUnit unit)
      Converts a Future into a Single, with a timeout on the Future.

      You can convert any object that supports the Future interface into a Single that emits the return value of the Future.get() method of that object, by passing the object into the from method.

      Important note: This Single is blocking; you cannot unsubscribe from it.

      Scheduler:
      from does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of object that the Future returns, and also the type of item to be emitted by the resulting Single
      Parameters:
      future - the source Future
      timeout - the maximum time to wait before calling get
      unit - the TimeUnit of the timeout argument
      Returns:
      a Single that emits the item from the source Future
      See Also:
    • from

      public static <T> Single<T> from(Future<? extends T> future, Scheduler scheduler)
      Converts a Future, operating on a specified Scheduler, into a Single.

      You can convert any object that supports the Future interface into a Single that emits the return value of the Future.get() method of that object, by passing the object into the from method.

      Scheduler:
      you specify which Scheduler this operator will use
      Type Parameters:
      T - the type of object that the Future returns, and also the type of item to be emitted by the resulting Single
      Parameters:
      future - the source Future
      scheduler - the Scheduler to wait for the Future on. Use a Scheduler such as Schedulers.io() that can block and wait on the Future
      Returns:
      a Single that emits the item from the source Future
      See Also:
    • fromCallable

      @Beta public static <T> Single<T> fromCallable(Callable<? extends T> func)
      Returns a Single that invokes passed function and emits its result for each new Observer that subscribes.

      Allows you to defer execution of passed function until Observer subscribes to the Single. It makes passed function "lazy". Result of the function invocation will be emitted by the Single.

      Scheduler:
      fromCallable does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of the item emitted by the Single.
      Parameters:
      func - function which execution should be deferred, it will be invoked when Observer will subscribe to the Single.
      Returns:
      a Single whose Observers' subscriptions trigger an invocation of the given function.
    • just

      public static <T> Single<T> just(T value)
      Returns a Single that emits a specified item.

      To convert any object into a Single that emits that object, pass that object into the just method.

      Scheduler:
      just does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of that item
      Parameters:
      value - the item to emit
      Returns:
      a Single that emits value
      See Also:
    • merge

      public static <T> Single<T> merge(Single<? extends Single<? extends T>> source)
      Flattens a Single that emits a Single into a single Single that emits the item emitted by the nested Single, without any transformation.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the value type of the sources and the output
      Parameters:
      source - a Single that emits a Single
      Returns:
      a Single that emits the item that is the result of flattening the Single emitted by source
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2)
      Flattens two Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3)
      Flattens three Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4)
      Flattens four Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5)
      Flattens five Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      t5 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6)
      Flattens six Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      t5 - a Single to be merged
      t6 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7)
      Flattens seven Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      t5 - a Single to be merged
      t6 - a Single to be merged
      t7 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8)
      Flattens eight Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      t5 - a Single to be merged
      t6 - a Single to be merged
      t7 - a Single to be merged
      t8 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • merge

      public static <T> Observable<T> merge(Single<? extends T> t1, Single<? extends T> t2, Single<? extends T> t3, Single<? extends T> t4, Single<? extends T> t5, Single<? extends T> t6, Single<? extends T> t7, Single<? extends T> t8, Single<? extends T> t9)
      Flattens nine Singles into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the merge method.

      Scheduler:
      merge does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the common value type
      Parameters:
      t1 - a Single to be merged
      t2 - a Single to be merged
      t3 - a Single to be merged
      t4 - a Single to be merged
      t5 - a Single to be merged
      t6 - a Single to be merged
      t7 - a Single to be merged
      t8 - a Single to be merged
      t9 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • zip

      public static <T1, T2, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Func2<? super T1,? super T2,? extends R> zipFunction)
      Returns a Single that emits the results of a specified combiner function applied to two items emitted by two other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Func3<? super T1,? super T2,? super T3,? extends R> zipFunction)
      Returns a Single that emits the results of a specified combiner function applied to three items emitted by three other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Func4<? super T1,? super T2,? super T3,? super T4,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to four items emitted by four other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, T5, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Func5<? super T1,? super T2,? super T3,? super T4,? super T5,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to five items emitted by five other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      T5 - the fifth source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      s5 - a fifth source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, T5, T6, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Func6<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to six items emitted by six other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      T5 - the fifth source Single's value type
      T6 - the sixth source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      s5 - a fifth source Single
      s6 - a sixth source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, T5, T6, T7, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Func7<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to seven items emitted by seven other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      T5 - the fifth source Single's value type
      T6 - the sixth source Single's value type
      T7 - the seventh source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      s5 - a fifth source Single
      s6 - a sixth source Single
      s7 - a seventh source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, T5, T6, T7, T8, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Single<? extends T8> s8, Func8<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to eight items emitted by eight other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      T5 - the fifth source Single's value type
      T6 - the sixth source Single's value type
      T7 - the seventh source Single's value type
      T8 - the eigth source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      s5 - a fifth source Single
      s6 - a sixth source Single
      s7 - a seventh source Single
      s8 - an eighth source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <T1, T2, T3, T4, T5, T6, T7, T8, T9, R> Single<R> zip(Single<? extends T1> s1, Single<? extends T2> s2, Single<? extends T3> s3, Single<? extends T4> s4, Single<? extends T5> s5, Single<? extends T6> s6, Single<? extends T7> s7, Single<? extends T8> s8, Single<? extends T9> s9, Func9<? super T1,? super T2,? super T3,? super T4,? super T5,? super T6,? super T7,? super T8,? super T9,? extends R> zipFunction)
      Returns an Observable that emits the results of a specified combiner function applied to nine items emitted by nine other Singles.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      T1 - the first source Single's value type
      T2 - the second source Single's value type
      T3 - the third source Single's value type
      T4 - the fourth source Single's value type
      T5 - the fifth source Single's value type
      T6 - the sixth source Single's value type
      T7 - the seventh source Single's value type
      T8 - the eigth source Single's value type
      T9 - the ninth source Single's value type
      R - the result value type
      Parameters:
      s1 - the first source Single
      s2 - a second source Single
      s3 - a third source Single
      s4 - a fourth source Single
      s5 - a fifth source Single
      s6 - a sixth source Single
      s7 - a seventh source Single
      s8 - an eighth source Single
      s9 - a ninth source Single
      zipFunction - a function that, when applied to the item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • zip

      public static <R> Single<R> zip(Iterable<? extends Single<?>> singles, FuncN<? extends R> zipFunction)
      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 applies this function in strict sequence.

      Scheduler:
      zip does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the result value type
      Parameters:
      singles - an Iterable of source Singles. Should not be empty because Single either emits result or error. NoSuchElementException will be emit as error if Iterable will be empty.
      zipFunction - a function that, when applied to an item emitted by each of the source Singles, results in an item that will be emitted by the resulting Single
      Returns:
      a Single that emits the zipped results
      See Also:
    • concatWith

      public final Observable<T> concatWith(Single<? extends T> t1)
      Returns an Observable that emits the item emitted by the source Single, then the item emitted by the specified Single.

      Scheduler:
      concat does not operate by default on a particular Scheduler.
      Parameters:
      t1 - a Single to be concatenated after the current
      Returns:
      an Observable that emits the item emitted by the source Single, followed by the item emitted by t1
      See Also:
    • flatMap

      public final <R> Single<R> flatMap(Func1<? super T,? extends Single<? extends R>> func)
      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.

      Scheduler:
      flatMap does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the result value type
      Parameters:
      func - a function that, when applied to the item emitted by the source Single, returns a Single
      Returns:
      the Single returned from func when applied to the item emitted by the source Single
      See Also:
    • flatMapObservable

      public final <R> Observable<R> flatMapObservable(Func1<? super T,? extends Observable<? extends R>> func)
      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.

      Scheduler:
      flatMapObservable does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the result value type
      Parameters:
      func - a function that, when applied to the item emitted by the source Single, returns an Observable
      Returns:
      the Observable returned from func when applied to the item emitted by the source Single
      See Also:
    • map

      public final <R> Single<R> map(Func1<? super T,? extends R> func)
      Returns a Single that applies a specified function to the item emitted by the source Single and emits the result of this function application.

      Scheduler:
      map does not operate by default on a particular Scheduler.
      Type Parameters:
      R - the result value type
      Parameters:
      func - a function to apply to the item emitted by the Single
      Returns:
      a Single that emits the item from the source Single, transformed by the specified function
      See Also:
    • mergeWith

      public final Observable<T> mergeWith(Single<? extends T> t1)
      Flattens this and another Single into a single Observable, without any transformation.

      You can combine items emitted by multiple Singles so that they appear as a single Observable, by using the mergeWith method.

      Scheduler:
      mergeWith does not operate by default on a particular Scheduler.
      Parameters:
      t1 - a Single to be merged
      Returns:
      an Observable that emits all of the items emitted by the source Singles
      See Also:
    • observeOn

      public final Single<T> observeOn(Scheduler scheduler)
      Modifies a Single to emit its item (or notify of its error) on a specified Scheduler, asynchronously.

      Scheduler:
      you specify which Scheduler this operator will use
      Parameters:
      scheduler - the Scheduler to notify subscribers on
      Returns:
      the source Single modified so that its subscribers are notified on the specified Scheduler
      See Also:
    • onErrorReturn

      public final Single<T> onErrorReturn(Func1<Throwable,? extends T> resumeFunction)
      Instructs a Single to emit an item (returned by a specified function) rather than invoking onError if it encounters an error.

      By default, when a Single encounters an error that prevents it from emitting the expected item to its subscriber, the Single invokes its subscriber's Observer.onError(java.lang.Throwable) method, and then quits without invoking any more of its subscriber's methods. The onErrorReturn method changes this behavior. If you pass a function (resumeFunction) to a Single's onErrorReturn method, if the original Single encounters an error, instead of invoking its subscriber's Observer.onError(java.lang.Throwable) method, it will instead emit the return value of resumeFunction.

      You can use this to prevent errors from propagating or to supply fallback data should errors be encountered.

      Scheduler:
      onErrorReturn does not operate by default on a particular Scheduler.
      Parameters:
      resumeFunction - a function that returns an item that the new Single will emit if the source Single encounters an error
      Returns:
      the original Single with appropriately modified behavior
      See Also:
    • onErrorResumeNext

      @Experimental public final Single<T> onErrorResumeNext(Single<? extends T> resumeSingleInCaseOfError)
      Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.

      By default, when a Single encounters an error that prevents it from emitting the expected item to its Observer, the Single invokes its Observer's onError method, and then quits without invoking any more of its Observer's methods. The onErrorResumeNext method changes this behavior. If you pass another Single (resumeSingleInCaseOfError) to an Single's onErrorResumeNext method, if the original Single encounters an error, instead of invoking its Observer's onError method, it will instead relinquish control to resumeSingleInCaseOfError which will invoke the Observer's onNext method if it is able to do so. In such a case, because no Single necessarily invokes onError, the Observer may never know that an error happened.

      You can use this to prevent errors from propagating or to supply fallback data should errors be encountered.

      Scheduler:
      onErrorResumeNext does not operate by default on a particular Scheduler.
      Parameters:
      resumeSingleInCaseOfError - a Single that will take control if source Single encounters an error.
      Returns:
      the original Single, with appropriately modified behavior.
      Since:
      (if this graduates from Experimental/Beta to supported, replace this parenthetical with the release number)
      See Also:
    • onErrorResumeNext

      @Experimental public final Single<T> onErrorResumeNext(Func1<Throwable,? extends Single<? extends T>> resumeFunctionInCaseOfError)
      Instructs a Single to pass control to another Single rather than invoking Observer.onError(Throwable) if it encounters an error.

      By default, when a Single encounters an error that prevents it from emitting the expected item to its Observer, the Single invokes its Observer's onError method, and then quits without invoking any more of its Observer's methods. The onErrorResumeNext method changes this behavior. If you pass a function that will return another Single (resumeFunctionInCaseOfError) to an Single's onErrorResumeNext method, if the original Single encounters an error, instead of invoking its Observer's onError method, it will instead relinquish control to resumeSingleInCaseOfError which will invoke the Observer's onNext method if it is able to do so. In such a case, because no Single necessarily invokes onError, the Observer may never know that an error happened.

      You can use this to prevent errors from propagating or to supply fallback data should errors be encountered.

      Scheduler:
      onErrorResumeNext does not operate by default on a particular Scheduler.
      Parameters:
      resumeFunctionInCaseOfError - a function that returns a Single that will take control if source Single encounters an error.
      Returns:
      the original Single, with appropriately modified behavior.
      Since:
      (if this graduates from Experimental/Beta to supported, replace this parenthetical with the release number)
      See Also:
    • subscribe

      public final Subscription subscribe()
      Subscribes to a Single but ignore its emission or notification.
      Scheduler:
      subscribe does not operate by default on a particular Scheduler.
      Returns:
      a Subscription reference can request the Single stop work.
      Throws:
      OnErrorNotImplementedException - if the Single tries to call Observer.onError(java.lang.Throwable)
      See Also:
    • subscribe

      public final Subscription subscribe(Action1<? super T> onSuccess)
      Subscribes to a Single and provides a callback to handle the item it emits.
      Scheduler:
      subscribe does not operate by default on a particular Scheduler.
      Parameters:
      onSuccess - the Action1<T> you have designed to accept the emission from the Single
      Returns:
      a Subscription reference can request the Single stop work.
      Throws:
      IllegalArgumentException - if onNext is null
      OnErrorNotImplementedException - if the Single tries to call Observer.onError(java.lang.Throwable)
      See Also:
    • subscribe

      public final Subscription subscribe(Action1<? super T> onSuccess, Action1<Throwable> onError)
      Subscribes to a Single and provides callbacks to handle the item it emits or any error notification it issues.
      Scheduler:
      subscribe does not operate by default on a particular Scheduler.
      Parameters:
      onSuccess - the Action1<T> you have designed to accept the emission from the Single
      onError - the Action1<Throwable> you have designed to accept any error notification from the Single
      Returns:
      a Subscription reference can request the Single stop work.
      Throws:
      IllegalArgumentException - if onNext is null, or if onError is null
      See Also:
    • unsafeSubscribe

      public final Subscription unsafeSubscribe(Subscriber<? super T> subscriber)
      Subscribes to a Single and invokes the Single.OnSubscribe function without any contract protection, error handling, unsubscribe, or execution hooks.

      Use this only for implementing an Observable.Operator that requires nested subscriptions. For other purposes, use subscribe(Subscriber) which ensures the Rx contract and other functionality.

      Scheduler:
      unsafeSubscribe does not operate by default on a particular Scheduler.
      Parameters:
      subscriber - the Subscriber that will handle the emission or notification from the Single
      Returns:
      the subscription that allows unsubscribing
    • subscribe

      public final Subscription subscribe(Observer<? super T> observer)
      Subscribes an Observer to this single and returns a Subscription that allows unsubscription.
      Parameters:
      observer - the Observer to subscribe
      Returns:
      the Subscription that allows unsubscription
    • subscribe

      public final Subscription subscribe(Subscriber<? super T> subscriber)
      Subscribes to a Single and provides a Subscriber that implements functions to handle the item the Single emits or any error notification it issues.

      A typical implementation of subscribe does the following:

      1. It stores a reference to the Subscriber in a collection object, such as a List<T> object.
      2. It returns a reference to the Subscription interface. This enables Subscribers to unsubscribe, that is, to stop receiving the item or notification before the Single completes.

      A Single<T> instance is responsible for accepting all subscriptions and notifying all Subscribers. Unless the documentation for a particular Single<T> implementation indicates otherwise, Subscribers should make no assumptions about the order in which multiple Subscribers will receive their notifications.

      For more information see the ReactiveX documentation.

      Scheduler:
      subscribe does not operate by default on a particular Scheduler.
      Parameters:
      subscriber - the Subscriber that will handle the emission or notification from the Single
      Returns:
      a Subscription reference can request the Single stop work.
      Throws:
      IllegalStateException - if subscribe is unable to obtain an OnSubscribe<> function
      IllegalArgumentException - if the Subscriber provided as the argument to subscribe is null
      OnErrorNotImplementedException - if the Subscriber's onError method is null
      RuntimeException - if the Subscriber's onError method itself threw a Throwable
      See Also:
    • subscribe

      public final Subscription subscribe(SingleSubscriber<? super T> te)
      Subscribes to a Single and provides a SingleSubscriber that implements functions to handle the item the Single emits or any error notification it issues.

      A typical implementation of subscribe does the following:

      1. It stores a reference to the Subscriber in a collection object, such as a List<T> object.
      2. It returns a reference to the Subscription interface. This enables Subscribers to unsubscribe, that is, to stop receiving the item or notification before the Single completes.

      A Single<T> instance is responsible for accepting all subscriptions and notifying all Subscribers. Unless the documentation for a particular Single<T> implementation indicates otherwise, Subscribers should make no assumptions about the order in which multiple Subscribers will receive their notifications.

      For more information see the ReactiveX documentation.

      Scheduler:
      subscribe does not operate by default on a particular Scheduler.
      Parameters:
      te - the SingleSubscriber that will handle the emission or notification from the Single
      Returns:
      a Subscription reference can request the Single stop work.
      Throws:
      IllegalStateException - if subscribe is unable to obtain an OnSubscribe<> function
      IllegalArgumentException - if the SingleSubscriber provided as the argument to subscribe is null
      OnErrorNotImplementedException - if the SingleSubscriber's onError method is null
      RuntimeException - if the SingleSubscriber's onError method itself threw a Throwable
      See Also:
    • subscribeOn

      public final Single<T> subscribeOn(Scheduler scheduler)
      Asynchronously subscribes subscribers to this Single on the specified Scheduler.

      Scheduler:
      you specify which Scheduler this operator will use
      Parameters:
      scheduler - the Scheduler to perform subscription actions on
      Returns:
      the source Single modified so that its subscriptions happen on the specified Scheduler
      See Also:
    • takeUntil

      public final Single<T> takeUntil(Completable other)
      Returns a Single that emits the item emitted by the source Single until a Completable terminates. Upon termination of other, this will emit a CancellationException rather than go to SingleSubscriber.onSuccess(Object).

      Scheduler:
      takeUntil does not operate by default on a particular Scheduler.
      Parameters:
      other - the Completable whose termination will cause takeUntil to emit the item from the source Single
      Returns:
      a Single that emits the item emitted by the source Single until such time as other terminates.
      See Also:
    • takeUntil

      public final <E> Single<T> takeUntil(Observable<? extends E> other)
      Returns a Single that emits the item emitted by the source Single until an Observable emits an item. Upon emission of an item from other, this will emit a CancellationException rather than go to SingleSubscriber.onSuccess(Object).

      Scheduler:
      takeUntil does not operate by default on a particular Scheduler.
      Type Parameters:
      E - the type of items emitted by other
      Parameters:
      other - the Observable whose first emitted item will cause takeUntil to emit the item from the source Single
      Returns:
      a Single that emits the item emitted by the source Single until such time as other emits its first item
      See Also:
    • takeUntil

      public final <E> Single<T> takeUntil(Single<? extends E> other)
      Returns a Single that emits the item emitted by the source Single until a second Single emits an item. Upon emission of an item from other, this will emit a CancellationException rather than go to SingleSubscriber.onSuccess(Object).

      Scheduler:
      takeUntil does not operate by default on a particular Scheduler.
      Type Parameters:
      E - the type of item emitted by other
      Parameters:
      other - the Single whose emitted item will cause takeUntil to emit the item from the source Single
      Returns:
      a Single that emits the item emitted by the source Single until such time as other emits its item
      See Also:
    • toObservable

      public final Observable<T> toObservable()
      Converts this Single into an Observable.

      Returns:
      an Observable that emits a single item T.
    • toCompletable

      @Experimental public final Completable toCompletable()
      Returns a Completable that discards result of the Single (similar to Observable.ignoreElements()) and calls onCompleted when this source Single calls onSuccess. Error terminal event is propagated.

      Scheduler:
      toCompletable does not operate by default on a particular Scheduler.
      Returns:
      a Completable that calls onCompleted on it's subscriber when the source Single calls onSuccess.
      Since:
      (if this graduates from Experimental/Beta to supported, replace this parenthetical with the release number).
      See Also:
    • timeout

      public final Single<T> timeout(long timeout, TimeUnit timeUnit)
      Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item. If it is not emitted within the specified timeout duration, the resulting Single terminates and notifies subscribers of a TimeoutException.

      Scheduler:
      This version of timeout operates by default on the computation Scheduler.
      Parameters:
      timeout - maximum duration before the Single times out
      timeUnit - the unit of time that applies to the timeout argument.
      Returns:
      the source Single modified to notify subscribers of a TimeoutException in case of a timeout
      See Also:
    • timeout

      public final Single<T> timeout(long timeout, TimeUnit timeUnit, Scheduler scheduler)
      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. If the item is not emitted within the specified timeout duration, the resulting Single terminates and notifies subscribers of a TimeoutException.

      Scheduler:
      you specify which Scheduler this operator will use
      Parameters:
      timeout - maximum duration before the Single times out
      timeUnit - the unit of time that applies to the timeout argument
      scheduler - the Scheduler to run the timeout timers on
      Returns:
      the source Single modified to notify subscribers of a TimeoutException in case of a timeout
      See Also:
    • timeout

      public final Single<T> timeout(long timeout, TimeUnit timeUnit, Single<? extends T> other)
      Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item. If it is not emitted within the specified timeout duration, the resulting Single instead mirrors a fallback Single.

      Scheduler:
      This version of timeout operates by default on the computation Scheduler.
      Parameters:
      timeout - maximum time before a timeout occurs
      timeUnit - the unit of time that applies to the timeout argument
      other - the fallback Single to use in case of a timeout
      Returns:
      the source Single modified to switch to the fallback Single in case of a timeout
      See Also:
    • timeout

      public final Single<T> timeout(long timeout, TimeUnit timeUnit, Single<? extends T> other, Scheduler scheduler)
      Returns a Single that mirrors the source Single but applies a timeout policy for its emitted item, using a specified Scheduler. If the item isn't emitted within the specified timeout duration, the resulting Single instead mirrors a fallback Single.

      Scheduler:
      you specify which Scheduler this operator will use
      Parameters:
      timeout - maximum duration before a timeout occurs
      timeUnit - the unit of time that applies to the timeout argument
      other - the Single to use as the fallback in case of a timeout
      scheduler - the Scheduler to run the timeout timers on
      Returns:
      the source Single modified so that it will switch to the fallback Single in case of a timeout
      See Also:
    • toBlocking

      @Experimental public final BlockingSingle<T> toBlocking()
      Converts a Single into a BlockingSingle (a Single with blocking operators).
      Scheduler:
      toBlocking does not operate by default on a particular Scheduler.
      Returns:
      a BlockingSingle version of this Single.
      See Also:
    • zipWith

      public final <T2, R> Single<R> zipWith(Single<? extends T2> other, Func2<? super T,? super T2,? extends R> zipFunction)
      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.

      Scheduler:
      zipWith does not operate by default on a particular Scheduler.
      Type Parameters:
      T2 - the type of items emitted by the other Single
      R - the type of items emitted by the resulting Single
      Parameters:
      other - the other Observable
      zipFunction - a function that combines the pairs of items from the two Observables to generate the items to be emitted by the resulting Single
      Returns:
      an Observable that pairs up values from the source Observable and the other Observable and emits the results of zipFunction applied to these pairs
      See Also:
    • doOnError

      @Experimental public final Single<T> doOnError(Action1<Throwable> onError)
      Modifies the source Single so that it invokes an action if it calls onError.

      In case the onError action throws, the downstream will receive a composite exception containing the original exception and the exception thrown by onError.

      Scheduler:
      doOnError does not operate by default on a particular Scheduler.
      Parameters:
      onError - the action to invoke if the source Single calls onError
      Returns:
      the source Single with the side-effecting behavior applied
      See Also:
    • doOnSuccess

      @Experimental public final Single<T> doOnSuccess(Action1<? super T> onSuccess)
      Modifies the source Single so that it invokes an action when it calls onSuccess.

      Scheduler:
      doOnSuccess does not operate by default on a particular Scheduler.
      Parameters:
      onSuccess - the action to invoke when the source Single calls onSuccess
      Returns:
      the source Single with the side-effecting behavior applied
      See Also:
    • doOnSubscribe

      @Experimental public final Single<T> doOnSubscribe(Action0 subscribe)
      Modifies the source Single so that it invokes the given action when it is subscribed from its subscribers. Each subscription will result in an invocation of the given action except when the source Single is reference counted, in which case the source Single will invoke the given action for the first subscription.

      Scheduler:
      doOnSubscribe does not operate by default on a particular Scheduler.
      Parameters:
      subscribe - the action that gets called when an observer subscribes to this Single
      Returns:
      the source Single modified so as to call this Action when appropriate
      See Also:
    • delay

      @Experimental public final Single<T> delay(long delay, TimeUnit unit, Scheduler scheduler)
      Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay. Error notifications from the source Single are not delayed.

      Scheduler:
      you specify which Scheduler this operator will use
      Parameters:
      delay - the delay to shift the source by
      unit - the time unit of delay
      scheduler - the Scheduler to use for delaying
      Returns:
      the source Single shifted in time by the specified delay
      See Also:
    • delay

      @Experimental public final Single<T> delay(long delay, TimeUnit unit)
      Returns an Single that emits the items emitted by the source Single shifted forward in time by a specified delay. Error notifications from the source Observable are not delayed.

      Scheduler:
      This version of delay operates by default on the computation Scheduler.
      Parameters:
      delay - the delay to shift the source by
      unit - the TimeUnit in which period is defined
      Returns:
      the source Single shifted in time by the specified delay
      See Also:
    • defer

      @Experimental public static <T> Single<T> defer(Callable<Single<T>> singleFactory)
      Returns a Single that calls a Single factory to create a Single for each new Observer that subscribes. That is, for each subscriber, the actual Single that subscriber observes is determined by the factory function.

      The defer Observer allows you to defer or delay emitting value from a Single until such time as an Observer subscribes to the Single. This allows an Observer to easily obtain updates or a refreshed version of the sequence.

      Scheduler:
      defer does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the type of the items emitted by the Single.
      Parameters:
      singleFactory - the Single factory function to invoke for each Observer that subscribes to the resulting Single.
      Returns:
      a Single whose Observers' subscriptions trigger an invocation of the given Single factory function.
      See Also:
    • doOnUnsubscribe

      @Experimental public final Single<T> doOnUnsubscribe(Action0 action)
      Modifies the source Single so that it invokes the given action when it is unsubscribed from its subscribers.

      Scheduler:
      doOnUnsubscribe does not operate by default on a particular Scheduler.
      Parameters:
      action - the action that gets called when this Single is unsubscribed.
      Returns:
      the source Single modified so as to call this Action when appropriate.
      See Also:
    • doAfterTerminate

      @Experimental public final Single<T> doAfterTerminate(Action0 action)
      Registers an Action0 to be called when this Single invokes either SingleSubscriber.onSuccess(Object) onSuccess} or onError.

      Scheduler:
      doAfterTerminate does not operate by default on a particular Scheduler.
      Parameters:
      action - an Action0 to be invoked when the source Single finishes.
      Returns:
      a Single that emits the same item or error as the source Single, then invokes the Action0
      See Also:
    • iterableToArray

      static <T> Single<? extends T>[] iterableToArray(Iterable<? extends Single<? extends T>> singlesIterable)
      FOR INTERNAL USE ONLY.

      Converts Iterable of Single to array of Single.

      Parameters:
      singlesIterable - non null iterable of Single.
      Returns:
      array of Single with same length as passed iterable.
    • retry

      public final Single<T> retry()
      Returns a Single that mirrors the source Single, resubscribing to it if it calls onError (infinite retry count). If the source Single calls SingleSubscriber.onError(java.lang.Throwable), this method will resubscribe to the source Single rather than propagating the onError call.
      Scheduler:
      retry operates by default on the trampoline Scheduler.
      Returns:
      the source Single modified with retry logic
      See Also:
    • retry

      public final Single<T> retry(long count)
      Returns an Single that mirrors the source Single, resubscribing to it if it calls onError up to a specified number of retries. If the source Single calls SingleSubscriber.onError(java.lang.Throwable), this method will resubscribe to the source Single for a maximum of count resubscriptions rather than propagating the onError call.
      Scheduler:
      retry operates by default on the trampoline Scheduler.
      Parameters:
      count - number of retry attempts before failing
      Returns:
      the source Single modified with retry logic
      See Also:
    • retry

      public final Single<T> retry(Func2<Integer,Throwable,Boolean> predicate)
      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.
      Backpressure Support:
      This operator honors backpressure.
      Scheduler:
      retry operates by default on the trampoline Scheduler.
      Parameters:
      predicate - the predicate that determines if a resubscription may happen in case of a specific exception and retry count
      Returns:
      the source Single modified with retry logic
      See Also:
    • retryWhen

      public final Single<T> retryWhen(Func1<Observable<? extends Throwable>,? extends Observable<?>> notificationHandler)
      Returns a Single that emits the same values as the source Single with the exception of an onError. An onError notification from the source will result in the emission of a Throwable item to the Observable provided as an argument to the notificationHandler function.

      Emissions from the handler Observable is treated as follows:

      • If the handler Observable emits an onCompleted the retryWhen will call onError with NoSuchElementException on the child subscription.
      • If the handler Observable emits an onError the retryWhen will call onError with the same Throwable instance on the child subscription.
      • Otherwise, the operator will resubscribe to the source Single.

      The notificationHandler function is called for each subscriber individually. This allows per-Subscriber state to be added to the error notification sequence.

      
       single.retryWhen(error -> {
           AtomicInteger counter = new AtomicInteger();
           return error.takeWhile(e -> counter.incrementAndGet() < 3).map(e -> "retry");
       }).subscribe(...);
       

      Note that you must compose over the input Observable provided in the function call because expects an emission of the exception to be matched by an event from the handler Observable.

      Scheduler:
      retryWhen operates by default on the trampoline Scheduler.
      Parameters:
      notificationHandler - receives an Observable of notifications with which a user can complete or error, aborting the retry
      Returns:
      the source Single modified with retry logic
      See Also:
    • using

      @Experimental public static <T, Resource> Single<T> using(Func0<Resource> resourceFactory, Func1<? super Resource,? extends Single<? extends T>> singleFactory, Action1<? super Resource> disposeAction)
      Constructs an Single that creates a dependent resource object which is disposed of on unsubscription.

      Scheduler:
      using does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the value type of the generated source
      Resource - the type of the per-subscriber resource
      Parameters:
      resourceFactory - the factory function to create a resource object that depends on the Single
      singleFactory - the factory function to create a Single
      disposeAction - the function that will dispose of the resource
      Returns:
      the Single whose lifetime controls the lifetime of the dependent resource object
      See Also:
    • using

      @Experimental public static <T, Resource> Single<T> using(Func0<Resource> resourceFactory, Func1<? super Resource,? extends Single<? extends T>> singleFactory, Action1<? super Resource> disposeAction, boolean disposeEagerly)
      Constructs an Single that creates a dependent resource object which is disposed of just before termination if you have set disposeEagerly to true and unsubscription does not occur before termination. Otherwise resource disposal will occur on unsubscription. Eager disposal is particularly appropriate for a synchronous Single that reuses resources. disposeAction will only be called once per subscription.

      Scheduler:
      using does not operate by default on a particular Scheduler.
      Type Parameters:
      T - the value type of the generated source
      Resource - the type of the per-subscriber resource
      Parameters:
      resourceFactory - the factory function to create a resource object that depends on the Single
      singleFactory - the factory function to create a Single
      disposeAction - the function that will dispose of the resource
      disposeEagerly - if true then disposal will happen either on unsubscription or just before emission of a terminal event (onComplete or onError).
      Returns:
      the Single whose lifetime controls the lifetime of the dependent resource object
      Since:
      (if this graduates from Experimental/Beta to supported, replace this parenthetical with the release number)
      See Also:
    • delaySubscription

      @Experimental public final Single<T> delaySubscription(Observable<?> other)
      Returns a Single that delays the subscription to this Single until the Observable completes. In case the onError of the supplied observer throws, the exception will be propagated to the downstream subscriber and will result in skipping the subscription of this Single.

      Scheduler:
      This method does not operate by default on a particular Scheduler.
      Parameters:
      other - the Observable that should trigger the subscription to this Single.
      Returns:
      a Single that delays the subscription to this Single until the Observable emits an element or completes normally.