Packages

object Observable extends ObservableDeprecatedBuilders with Serializable

Observable builders.

Source
Observable.scala
Linear Supertypes
Serializable, ObservableDeprecatedBuilders, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Observable
  2. Serializable
  3. ObservableDeprecatedBuilders
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Type Members

  1. class CatsInstances extends Bracket[Observable, Throwable] with Alternative[Observable] with CoflatMap[Observable] with FunctorFilter[Observable] with TaskLift[Observable]

    Cats instances for Observable.

  2. implicit final class DeprecatedExtensions[+A] extends AnyVal with ObservableDeprecatedMethods[A]

    Exposes extension methods for deprecated Observable methods.

  3. type Operator[-I, +O] = (Subscriber[O]) => Subscriber[I]

    An Operator is a function for transforming observers, that can be used for lifting observables.

    An Operator is a function for transforming observers, that can be used for lifting observables.

    See Observable.liftByOperator.

  4. type Transformer[-A, +B] = (Observable[A]) => Observable[B]

    A Transformer is a function used for transforming observables.

    A Transformer is a function used for transforming observables.

    See Observable.transform

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. def apply[A](elems: A*): Observable[A]

    Given a sequence of elements, builds an observable from it.

  5. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  6. implicit val catsInstances: CatsInstances

    Implicit type class instances for Observable.

  7. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native() @HotSpotIntrinsicCandidate()
  8. def coeval[A](value: Coeval[A]): Observable[A]

    Transforms a non-strict Coeval value into an Observable that emits a single element.

  9. def combineLatest2[A1, A2](oa1: Observable[A1], oa2: Observable[A2]): Observable[(A1, A2)]

    Creates a combined observable from 2 source observables.

    Creates a combined observable from 2 source observables.

    This operator behaves in a similar way to zip2, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

    Visual Example

    stream1: 1 - - 2 - - 3 - 4 - -
    stream2: 1 - - 2 - 3 - - - - 4
    
    result: (1, 1), (2, 2), (2, 3), (3, 3), (4, 3), (4, 4)
    

  10. def combineLatest3[A1, A2, A3](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3]): Observable[(A1, A2, A3)]

    Creates a combined observable from 3 source observables.

    Creates a combined observable from 3 source observables.

    This operator behaves in a similar way to zip3, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  11. def combineLatest4[A1, A2, A3, A4](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4]): Observable[(A1, A2, A3, A4)]

    Creates a combined observable from 4 source observables.

    Creates a combined observable from 4 source observables.

    This operator behaves in a similar way to zip4, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  12. def combineLatest5[A1, A2, A3, A4, A5](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5]): Observable[(A1, A2, A3, A4, A5)]

    Creates a combined observable from 5 source observables.

    Creates a combined observable from 5 source observables.

    This operator behaves in a similar way to zip5, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  13. def combineLatest6[A1, A2, A3, A4, A5, A6](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5], oa6: Observable[A6]): Observable[(A1, A2, A3, A4, A5, A6)]

    Creates a combined observable from 6 source observables.

    Creates a combined observable from 6 source observables.

    This operator behaves in a similar way to zip6, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  14. def combineLatestList[A](sources: Observable[A]*): Observable[Seq[A]]

    Given an observable sequence, it combines them together returning a new observable that generates sequences.

  15. def combineLatestMap2[A1, A2, R](oa1: Observable[A1], oa2: Observable[A2])(f: (A1, A2) => R): Observable[R]

    Creates a combined observable from 2 source observables.

    Creates a combined observable from 2 source observables.

    This operator behaves in a similar way to zipMap2, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

    Visual Example

    stream1: 1 - - 2 - - 3 - 4 - -
    stream2: 1 - - 2 - 3 - - - - 4
    
    result: (1, 1), (2, 2), (2, 3), (3, 3), (4, 3), (4, 4)
    

  16. def combineLatestMap3[A1, A2, A3, R](a1: Observable[A1], a2: Observable[A2], a3: Observable[A3])(f: (A1, A2, A3) => R): Observable[R]

    Creates a combined observable from 3 source observables.

    Creates a combined observable from 3 source observables.

    This operator behaves in a similar way to zipMap3, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  17. def combineLatestMap4[A1, A2, A3, A4, R](a1: Observable[A1], a2: Observable[A2], a3: Observable[A3], a4: Observable[A4])(f: (A1, A2, A3, A4) => R): Observable[R]

    Creates a combined observable from 4 source observables.

    Creates a combined observable from 4 source observables.

    This operator behaves in a similar way to zipMap4, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  18. def combineLatestMap5[A1, A2, A3, A4, A5, R](a1: Observable[A1], a2: Observable[A2], a3: Observable[A3], a4: Observable[A4], a5: Observable[A5])(f: (A1, A2, A3, A4, A5) => R): Observable[R]

    Creates a combined observable from 5 source observables.

    Creates a combined observable from 5 source observables.

    This operator behaves in a similar way to zipMap5, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  19. def combineLatestMap6[A1, A2, A3, A4, A5, A6, R](a1: Observable[A1], a2: Observable[A2], a3: Observable[A3], a4: Observable[A4], a5: Observable[A5], a6: Observable[A6])(f: (A1, A2, A3, A4, A5, A6) => R): Observable[R]

    Creates a combined observable from 6 source observables.

    Creates a combined observable from 6 source observables.

    This operator behaves in a similar way to zipMap6, but while zip emits items only when all of the zipped source observables have emitted a previously unzipped item, combine emits an item whenever any of the source Observables emits an item (so long as each of the source Observables has emitted at least one item).

  20. def cons[A](head: A, tail: Observable[A]): Observable[A]

    Builds a new observable from a strict head and a lazily evaluated tail.

  21. def create[A](overflowStrategy: Synchronous[A], producerType: ProducerSide = MultiProducer)(f: (Sync[A]) => Cancelable): Observable[A]

    Creates an observable from a function that receives a concurrent and safe Subscriber.Sync.

    Creates an observable from a function that receives a concurrent and safe Subscriber.Sync.

    This builder represents the safe way of building observables from data-sources that cannot be back-pressured.

    overflowStrategy

    is the overflow strategy that specifies the type of the underlying buffer (unbounded, that overflows the head, etc). This parameter can only specify a "synchronous" strategy, so no back-pressuring allowed.

    producerType

    (UNSAFE) is the producer type and can be MultiProducer or SingleProducer, specified as an optimization option; if you don't know what you're doing, stick to MultiProducer, which says that multiple producers can push events at the same time, which is the default

  22. def defer[A](fa: => Observable[A]): Observable[A]

    Returns a new observable that creates a sequence from the given factory on each subscription.

  23. def delay[A](a: => A): Observable[A]

    Alias for eval.

  24. def empty[A]: Observable[A]

    Creates an observable that doesn't emit anything, but immediately calls onComplete instead.

  25. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  26. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  27. def eval[A](a: => A): Observable[A]

    Given a non-strict value, converts it into an Observable that upon subscription, evaluates the expression and emits a single element.

  28. def evalDelayed[A](delay: FiniteDuration, a: => A): Observable[A]

    Lifts a non-strict value into an observable that emits a single element, but upon subscription delay its evaluation by the specified timespan

  29. def evalOnce[A](f: => A): Observable[A]

    Given a non-strict value, converts it into an Observable that emits a single element and that memoizes the value for subsequent invocations.

  30. def firstStartedOf[A](source: Observable[A]*): Observable[A]

    Given a list of source Observables, emits all of the items from the first of these Observables to emit an item or to complete, and cancel the rest.

    Given a list of source Observables, emits all of the items from the first of these Observables to emit an item or to complete, and cancel the rest.

    Visual Example

    stream1: - - 1 1 1 - 1 - 1 - -
    stream2: - - - - - 2 2 2 2 2 2
    
    result: - - 1 1 1 - 1 - 1 - -
    

  31. def from[F[_], A](fa: F[A])(implicit F: ObservableLike[F]): Observable[A]

    Converts to Observable from any F[_] that has an ObservableLike instance.

  32. def fromAsyncStateAction[S, A](f: (S) => Task[(A, S)])(seed: => S): Observable[A]

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function.

  33. def fromAsyncStateActionF[F[_], S, A](f: (S) => F[(A, S)])(seed: => S)(implicit F: TaskLike[F]): Observable[A]

    Version of fromAsyncStateAction that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of fromAsyncStateAction that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
    See also

    fromAsyncStateAction for a version specialized for Task

  34. def fromCharsReader(in: Task[Reader], chunkSize: Int = 4096): Observable[Array[Char]]

    Safely converts a java.io.Reader into an observable that will emit Array[Char] elements.

    Safely converts a java.io.Reader into an observable that will emit Array[Char] elements.

    Compared with fromCharsReaderUnsafe, this version:

    • is referentially transparent, the input being a "generator" powered by monix.eval.Task
    • automatically forks execution on subscription to ensure that the current thread isn't blocked by the ensuing blocking I/O
    • ensures that the input stream is closed on completion, failure or cancellation
    in

    the Task[Reader] generator to convert into an observable

    chunkSize

    the maximum length of the emitted arrays of chars, must be positive

  35. def fromCharsReaderF[F[_]](in: F[Reader], chunkSize: Int = 4096)(implicit F: TaskLike[F]): Observable[Array[Char]]

    Version of fromCharsReader that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of fromCharsReader that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  36. def fromCharsReaderUnsafe(in: Reader, chunkSize: Int = 4096): Observable[Array[Char]]

    Converts a java.io.Reader into an observable that will emit Array[Char] elements.

    Converts a java.io.Reader into an observable that will emit Array[Char] elements.

    UNSAFE WARNING: this is an unsafe function, because reading from a reader is a destructive process, also violating referential transparency. Therefore only a single subscriber is supported, the result being a single-subscriber observable. If multiple subscribers are attempted, all subscribers, except for the first one, will be terminated with a APIContractViolationException.

    UNSAFE PROTOCOL: the created Observable does not close the given Reader. Usually it's the producer of a resource that needs to deallocate the resource.

    This operation will start processing on the current thread (on subscribe()), so in order to not block, it might be better to also do an executeAsync, or you may want to use the AlwaysAsyncExecution model, which can be configured per Scheduler, see Scheduler.withExecutionModel, or per Observable, see Observable.executeWithModel.

    in

    the Reader to convert into an observable

    chunkSize

    the maximum length of the emitted arrays of chars, must be positive

    Annotations
    @UnsafeProtocol() @UnsafeBecauseImpure()
    See also

    fromCharsReader for the safe version

  37. def fromEither[E, A](f: (E) => Throwable)(a: Either[E, A]): Observable[A]

    Builds a Observable instance out of a Scala Either.

  38. def fromEither[E <: Throwable, A](a: Either[E, A]): Observable[A]

    Builds an Observable instance out of a Scala Either.

  39. def fromFuture[A](factory: => Future[A]): Observable[A]

    Converts a Scala Future provided into an Observable.

    Converts a Scala Future provided into an Observable.

    If the created instance is a CancelableFuture, then it will be used for the returned Cancelable on subscribe.

  40. def fromInputStream(in: Task[InputStream], chunkSize: Int = 4096): Observable[Array[Byte]]

    Safely converts a java.io.InputStream into an observable that will emit Array[Byte] elements.

    Safely converts a java.io.InputStream into an observable that will emit Array[Byte] elements.

    Compared with fromInputStreamUnsafe, this version:

    • is referentially transparent, the input being a "generator" powered by monix.eval.Task
    • automatically forks execution on subscription to ensure that the current thread isn't blocked by the ensuing blocking I/O
    • ensures that the input stream is closed on completion, failure or cancellation
    in

    the Task[InputStream] generator to convert into an observable

    chunkSize

    the maximum length of the emitted arrays of bytes, must be positive

  41. def fromInputStreamF[F[_]](in: F[InputStream], chunkSize: Int = 4096)(implicit F: TaskLike[F]): Observable[Array[Byte]]

    Version of fromInputStream that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of fromInputStream that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  42. def fromInputStreamUnsafe(in: InputStream, chunkSize: Int = 4096): Observable[Array[Byte]]

    Converts a java.io.InputStream into an observable that will emit Array[Byte] elements.

    Converts a java.io.InputStream into an observable that will emit Array[Byte] elements.

    UNSAFE WARNING: this is an unsafe function, because reading from an input stream is a destructive process, also violating referential transparency. Therefore only a single subscriber is supported, the result being a single-subscriber observable. If multiple subscribers are attempted, all subscribers, except for the first one, will be terminated with a APIContractViolationException.

    UNSAFE PROTOCOL: the created Observable does not close the given InputStream. Usually it's the producer of a resource that needs to deallocate the resource.

    This operation will start processing on the current thread (on subscribe()), so in order to not block, it might be better to also do an executeAsync, or you may want to use the AlwaysAsyncExecution model, which can be configured per Scheduler, see Scheduler.withExecutionModel, or per Observable, see Observable.executeWithModel.

    in

    the InputStream to convert into an observable

    chunkSize

    the maximum length of the emitted arrays of bytes, must be positive

    Annotations
    @UnsafeProtocol() @UnsafeBecauseImpure()
    See also

    fromInputStream for the safe version

  43. def fromIterable[A](iterable: Iterable[A]): Observable[A]

    Converts any Iterable into an Observable.

  44. def fromIterator[A](resource: Resource[Task, Iterator[A]]): Observable[A]

    Wraps a scala.Iterator into an Observable in the context of a cats.effect.Resource, which allows for specifying a finalizer.

    Wraps a scala.Iterator into an Observable in the context of a cats.effect.Resource, which allows for specifying a finalizer.

    See also

    fromIterable

    fromIterator(task) for a version that uses Task for suspending side effects

    fromIteratorUnsafe for the unsafe version that can wrap an iterator directly

  45. def fromIterator[A](task: Task[Iterator[A]]): Observable[A]

    Wraps a scala.Iterator into an Observable.

    Wraps a scala.Iterator into an Observable.

    This function uses Task in order to suspend the creation of the Iterator, because reading from an Iterator is a destructive process. The Task is being used as a "factory", in pace of scala.Iterable.

    Example:

    import monix.eval.Task
    
    Observable.fromIterator(Task(Iterator.from(1)))
    See also

    fromIterable

    fromIterator(Resource) for a version that uses cats.effect.Resource

    fromIteratorUnsafe for the unsafe version that can wrap an iterator directly

  46. def fromIteratorBuffered[A](resource: Resource[Task, Iterator[A]], bufferSize: Int): Observable[Seq[A]]

    Wraps a scala.Iterator into an Observable in the context of a cats.effect.Resource, which allows for specifying a finalizer.

    Wraps a scala.Iterator into an Observable in the context of a cats.effect.Resource, which allows for specifying a finalizer.

    See also

    fromIterable

    fromIteratorBuffered(task) for a version that uses Task for suspending side effects

    fromIteratorBufferedUnsafe for the unsafe version that can wrap an iterator directly

  47. def fromIteratorBuffered[A](task: Task[Iterator[A]], bufferSize: Int): Observable[Seq[A]]

    Wraps a scala.Iterator into an Observable that emits events in chunkSize batches.

    Wraps a scala.Iterator into an Observable that emits events in chunkSize batches.

    This function uses Task in order to suspend the creation of the Iterator, because reading from an Iterator is a destructive process. The Task is being used as a "factory", in pace of scala.Iterable.

    Example:

    import monix.eval.Task
    
    Observable.fromIteratorBuffered(Task(Iterator.from(1)), 2)
    See also

    fromIterable

    fromIteratorBuffered(Resource) for a version that uses cats.effect.Resource

    fromIteratorBufferedUnsafe for the unsafe version that can wrap an iterator directly

  48. def fromIteratorBufferedUnsafe[A](iterator: Iterator[A], bufferSize: Int): Observable[Seq[A]]

    Converts any Iterator into an observable that emits events in bufferSize batches.

    Converts any Iterator into an observable that emits events in bufferSize batches.

    UNSAFE WARNING: reading from an Iterator is a destructive process. Therefore only a single subscriber is supported, the result being a single-subscriber observable. If multiple subscribers are attempted, all subscribers, except for the first one, will be terminated with a APIContractViolationException.

    iterator

    to transform into an observable

    Annotations
    @UnsafeProtocol() @UnsafeBecauseImpure()
    See also

    fromIteratorBuffered(task) or fromIteratorBuffered(resource) for safe alternatives

  49. def fromIteratorF[F[_], A](iteratorF: F[Iterator[A]])(implicit F: TaskLike[F]): Observable[A]

    Version of fromIterator that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of fromIterator that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  50. def fromIteratorUnsafe[A](iterator: Iterator[A]): Observable[A]

    Converts any Iterator into an observable.

    Converts any Iterator into an observable.

    UNSAFE WARNING: reading from an Iterator is a destructive process. Therefore only a single subscriber is supported, the result being a single-subscriber observable. If multiple subscribers are attempted, all subscribers, except for the first one, will be terminated with a APIContractViolationException.

    iterator

    to transform into an observable

    Annotations
    @UnsafeProtocol() @UnsafeBecauseImpure()
    See also

    fromIterator(task) or fromIterator(resource) for safe alternatives

  51. def fromLinesReader(in: Task[BufferedReader]): Observable[String]

    Safely converts a java.io.BufferedReader into an observable that will emit String elements corresponding to text lines from the input.

    Safely converts a java.io.BufferedReader into an observable that will emit String elements corresponding to text lines from the input.

    According to the specification of BufferedReader, a line is considered to be terminated by any one of a line feed (\n), a carriage return (\r), or a carriage return followed immediately by a linefeed.

    Compared with fromLinesReaderUnsafe, this version:

    • is referentially transparent, the input being a "generator" powered by monix.eval.Task
    • automatically forks execution on subscription to ensure that the current thread isn't blocked by the ensuing blocking I/O
    • ensures that the input stream is closed on completion, failure or cancellation
    in

    is the Task[BufferedReader] generator to convert into an observable

  52. def fromLinesReaderF[F[_]](in: F[BufferedReader])(implicit F: TaskLike[F]): Observable[String]

    Version of fromLinesReader that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of fromLinesReader that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  53. def fromLinesReaderUnsafe(in: BufferedReader): Observable[String]

    Converts a java.io.BufferedReader into an observable that will emit String text lines from the input.

    Converts a java.io.BufferedReader into an observable that will emit String text lines from the input.

    According to the specification of BufferedReader, a line is considered to be terminated by any one of a line feed (\n), a carriage return (\r), or a carriage return followed immediately by a linefeed.

    UNSAFE WARNING: this is an unsafe function, because reading from a reader is a destructive process, also violating referential transparency. Therefore only a single subscriber is supported, the result being a single-subscriber observable. If multiple subscribers are attempted, all subscribers, except for the first one, will be terminated with a APIContractViolationException.

    UNSAFE PROTOCOL: the created Observable does not close the given Reader. Usually it's the producer of a resource that needs to deallocate the resource.

    in

    is the Reader to convert into an observable

    Annotations
    @UnsafeProtocol() @UnsafeBecauseImpure()
    See also

    fromLinesReader for the safe version

  54. def fromReactivePublisher[A](publisher: Publisher[A], requestCount: Int): Observable[A]

    Given a org.reactivestreams.Publisher, converts it into a Monix / Rx Observable.

    Given a org.reactivestreams.Publisher, converts it into a Monix / Rx Observable.

    See the Reactive Streams protocol that Monix implements.

    publisher

    is the org.reactivestreams.Publisher reference to wrap into an Observable

    requestCount

    a strictly positive number, representing the size of the buffer used and the number of elements requested on each cycle when communicating demand, compliant with the reactive streams specification. If Int.MaxValue is given, then no back-pressuring logic will be applied (e.g. an unbounded buffer is used and the source has a license to stream as many events as it wants).

    See also

    Observable.toReactive for converting an Observable to a reactive publisher.

  55. def fromReactivePublisher[A](publisher: Publisher[A]): Observable[A]

    Given a org.reactivestreams.Publisher, converts it into a Monix / Rx Observable.

    Given a org.reactivestreams.Publisher, converts it into a Monix / Rx Observable.

    See the Reactive Streams protocol that Monix implements.

    publisher

    is the org.reactivestreams.Publisher reference to wrap into an Observable

    See also

    Observable.toReactive for converting an Observable to a reactive publisher.

  56. def fromResource[F[_], A](resource: Resource[F, A])(implicit F: TaskLike[F]): Observable[A]

    Transforms any cats.effect.Resource into an Observable.

    Transforms any cats.effect.Resource into an Observable.

    See the documentation for Resource.

    import cats.effect.Resource
    import monix.eval.Task
    import java.io._
    
    def openFileAsResource(file: File): Resource[Task, FileInputStream] =
      Resource.make(Task(new FileInputStream(file)))(h => Task(h.close()))
    
    def openFileAsStream(file: File): Observable[FileInputStream] =
      Observable.fromResource(openFileAsResource(file))

    This example would be equivalent with usage of Observable.resource:

    def openFileAsResource2(file: File): Observable[FileInputStream] = {
      Observable.resource(Task(new FileInputStream(file)))(h => Task(h.close()))
    }

    This means that flatMap is safe to use:

    def readBytes(file: File): Observable[Array[Byte]] =
      openFileAsStream(file).flatMap { in =>
        Observable.fromInputStreamUnsafe(in)
      }
  57. def fromStateAction[S, A](f: (S) => (A, S))(seed: => S): Observable[A]

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function.

  58. def fromTask[A](task: Task[A]): Observable[A]

    Converts any Task into an Observable.

    Converts any Task into an Observable.

    import monix.eval.Task
    
    val task = Task.eval("Hello!")
    
    Observable.fromTask(task)
  59. def fromTaskLike[F[_], A](fa: F[A])(implicit F: TaskLike[F]): Observable[A]

    Converts generic F[_] effects to Observable.

    Converts generic F[_] effects to Observable.

    Currently supported data types:

    Sample:

    import cats.implicits._
    import cats.effect.IO
    import cats.effect.Timer
    import scala.concurrent.duration._
    import monix.execution.Scheduler.global
    import monix.catnap.SchedulerEffect
    
    // Needed for IO.sleep
    implicit val timer: Timer[IO] = SchedulerEffect.timerLiftIO[IO](global)
    val task = IO.sleep(5.seconds) *> IO(println("Hello!"))
    
    Observable.fromTaskLike(task)
  60. def fromTry[A](a: Try[A]): Observable[A]

    Converts a Scala Try into an Observable.

    Converts a Scala Try into an Observable.

    import scala.util.Try
    
    val value = Try(1)
    Observable.fromTry(value)
  61. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  62. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  63. def interleave2[A](oa1: Observable[A], oa2: Observable[A]): Observable[A]

    Creates a new observable from this observable and another given observable by interleaving their items into a strictly alternating sequence.

    Creates a new observable from this observable and another given observable by interleaving their items into a strictly alternating sequence.

    So the first item emitted by the new observable will be the item emitted by self, the second item will be emitted by the other observable, and so forth; when either self or other calls onCompletes, the items will then be directly coming from the observable that has not completed; when onError is called by either self or other, the new observable will call onError and halt.

    See merge for a more relaxed alternative that doesn't emit items in strict alternating sequence.

  64. def interval(delay: FiniteDuration): Observable[Long]

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval.

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval. Starts from 0 with no delay, after which it emits incremented numbers spaced by the delay of time. The given delay of time acts as a fixed delay between successive events.

    delay

    the delay between 2 successive events

  65. def intervalAtFixedRate(initialDelay: FiniteDuration, period: FiniteDuration): Observable[Long]

    Creates an Observable that emits auto-incremented natural numbers (longs) at a fixed rate, as given by the specified period.

    Creates an Observable that emits auto-incremented natural numbers (longs) at a fixed rate, as given by the specified period. The time it takes to process an onNext event gets subtracted from the specified period and thus the created observable tries to emit events spaced by the given time interval, regardless of how long the processing of onNext takes.

    This version of the intervalAtFixedRate allows specifying an initialDelay before events start being emitted.

    initialDelay

    is the initial delay before emitting the first event

    period

    the period between 2 successive onNext events

  66. def intervalAtFixedRate(period: FiniteDuration): Observable[Long]

    Creates an Observable that emits auto-incremented natural numbers (longs) at a fixed rate, as given by the specified period.

    Creates an Observable that emits auto-incremented natural numbers (longs) at a fixed rate, as given by the specified period. The time it takes to process an onNext event gets subtracted from the specified period and thus the created observable tries to emit events spaced by the given time interval, regardless of how long the processing of onNext takes.

    period

    the period between 2 successive onNext events

  67. def intervalWithFixedDelay(delay: FiniteDuration): Observable[Long]

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval.

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval. Starts from 0 with no delay, after which it emits incremented numbers spaced by the delay of time. The given delay of time acts as a fixed delay between successive events.

    delay

    the delay between 2 successive events

  68. def intervalWithFixedDelay(initialDelay: FiniteDuration, delay: FiniteDuration): Observable[Long]

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval.

    Creates an Observable that emits auto-incremented natural numbers (longs) spaced by a given time interval. Starts from 0 with initialDelay, after which it emits incremented numbers spaced by the delay of time. The given delay of time acts as a fixed delay between successive events.

    This version of the intervalWithFixedDelay allows specifying an initialDelay before events start being emitted.

    initialDelay

    is the delay to wait before emitting the first event

    delay

    the time to wait between 2 successive events

  69. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  70. def liftFrom[F[_]](implicit F: ObservableLike[F]): ~>[F, Observable]

    Returns a F ~> Coeval (FunctionK) for transforming any supported data-type into Observable.

  71. def mergePrioritizedList[A](sources: (Int, Observable[A])*): Observable[A]

    Given a sequence of priority/observable pairs, combines them into a new observable that eagerly emits source items downstream as soon as demand is signaled, choosing the item from the highest priority (greater numbers mean higher priority) source when items from multiple sources are available.

    Given a sequence of priority/observable pairs, combines them into a new observable that eagerly emits source items downstream as soon as demand is signaled, choosing the item from the highest priority (greater numbers mean higher priority) source when items from multiple sources are available. If items are available from multiple sources with the same highest priority, one of them is chosen arbitrarily.

    Source items are buffered only to the extent necessary to accommodate backpressure from downstream, and thus if only a single item is available when demand is signaled, it will be emitted regardless of priority.

    Backpressure is propagated from downstream to the source observables, so that items from a given source will always be emitted downstream in the same order as received from the source, and at most a single item from a given source will be in flight at a time.

  72. def multicast[A](multicast: MulticastStrategy[A], overflow: Synchronous[A])(implicit s: Scheduler): (Sync[A], Observable[A])

    Creates an input channel and an output observable pair for building a multicast data-source.

    Creates an input channel and an output observable pair for building a multicast data-source.

    Useful for building multicast observables from data-sources that cannot be back-pressured.

    Prefer Observable.create when possible.

    multicast

    is the multicast strategy to use (e.g. publish, behavior, reply, async)

    overflow

    is the overflow strategy for the buffer that gets placed in front (since this will be a hot data-source that cannot be back-pressured)

  73. def multicast[A](multicast: MulticastStrategy[A])(implicit s: Scheduler): (Sync[A], Observable[A])

    Creates an input channel and an output observable pair for building a multicast data-source.

    Creates an input channel and an output observable pair for building a multicast data-source.

    Useful for building multicast observables from data-sources that cannot be back-pressured.

    Prefer Observable.create when possible.

    multicast

    is the multicast strategy to use (e.g. publish, behavior, reply, async)

  74. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  75. def never[A]: Observable[A]

    Creates an Observable that doesn't emit anything and that never completes.

  76. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  77. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native() @HotSpotIntrinsicCandidate()
  78. def now[A](elem: A): Observable[A]

    Returns an Observable that on execution emits the given strict value.

  79. implicit val observableNonEmptyParallel: Aux[Observable, observables.CombineObservable.Type]

    cats.NonEmptyParallel instance for Observable.

  80. def paginate[S, A](seed: => S)(f: (S) => (A, Option[S])): Observable[A]

    Similar to unfold, but allows to take emission one step further.

    Similar to unfold, but allows to take emission one step further.

    Example:
    1. Observable.paginate(0)(i => if (i < 10) (i, Some(i + 1)) else (i, None)).toListL
      
      result: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
  81. def paginateEval[S, A](seed: => S)(f: (S) => Task[(A, Option[S])]): Observable[A]

    Similar to unfoldEval, but allows to take emission one step further.

    Similar to unfoldEval, but allows to take emission one step further.

    Example:
    1. Observable.paginateEval(0)(i => if (i < 10) Task.now((i, Some(i + 1))) else Task.now((i,None))).toListL
      
      result: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9, 10]
  82. def pure[A](elem: A): Observable[A]

    Lifts an element into the Observable context.

    Lifts an element into the Observable context.

    Alias for now.

  83. def raiseError[A](ex: Throwable): Observable[A]

    Creates an Observable that emits an error.

  84. def range(from: Long, until: Long, step: Long = 1L): Observable[Long]

    Creates an Observable that emits items in the given range.

    Creates an Observable that emits items in the given range.

    from

    the range start

    until

    the range end

    step

    increment step, either positive or negative

  85. def repeat[A](elems: A*): Observable[A]

    Creates an Observable that continuously emits the given item repeatedly.

  86. def repeatEval[A](task: => A): Observable[A]

    Repeats the execution of the given task, emitting the results indefinitely.

  87. def repeatEvalF[F[_], A](fa: F[A])(implicit F: TaskLike[F]): Observable[A]

    Repeats the evaluation of given effectful value, emitting the results indefinitely.

  88. def resource[A](acquire: Task[A])(release: (A) => Task[Unit]): Observable[A]

    Creates a Observable that depends on resource allocated by a monadic value, ensuring the resource is released.

    Creates a Observable that depends on resource allocated by a monadic value, ensuring the resource is released.

    Typical use-cases are working with files or network sockets

    Example

    import monix.eval.Task
    import java.io.PrintWriter
    
    val printer =
      Observable.resource {
        Task(new PrintWriter("./lines.txt"))
      } { writer =>
        Task(writer.close())
      }
    
    // Safely use the resource, because the release is
    // scheduled to happen afterwards
    val writeLines = printer.flatMap { writer =>
      Observable
        .fromIterator(Task(Iterator.from(1)))
        .mapEval(i => Task { writer.println(s"Line #\$i") })
    }
    
    // Write 100 numbered lines to the file, closing the writer
    // when finished (after `runAsync`):
    writeLines.take(100).completedL
    acquire

    resource to acquire at the start of the stream

    release

    function that releases the acquired resource

  89. def resourceCase[A](acquire: Task[A])(release: (A, ExitCase[Throwable]) => Task[Unit]): Observable[A]

    Creates a stream that depends on resource allocated by a monadic value, ensuring the resource is released.

    Creates a stream that depends on resource allocated by a monadic value, ensuring the resource is released.

    Typical use-cases are working with files or network sockets

    Example

    import cats.effect.ExitCase
    import monix.eval.Task
    import java.io.PrintWriter
    
    val printer =
      Observable.resourceCase {
        Task(new PrintWriter("./lines.txt"))
      } {
        case (writer, ExitCase.Canceled | ExitCase.Completed) =>
          Task(writer.close())
        case (writer, ExitCase.Error(e)) =>
          Task { println(e.getMessage); writer.close() }
      }
    
    // Safely use the resource, because the release is
    // scheduled to happen afterwards
    val writeLines = printer.flatMap { writer =>
      Observable
        .fromIterator(Task(Iterator.from(1)))
        .mapEval(i => Task { writer.println(s"Line #\$i") })
    }
    
    // Write 100 numbered lines to the file, closing the writer
    // when finished (after `runAsync`):
    writeLines.take(100).completedL
    acquire

    an effect that acquires an expensive resource

    release

    function that releases the acquired resource

  90. def resourceCaseF[F[_], A](acquire: F[A])(release: (A, ExitCase[Throwable]) => F[Unit])(implicit F: TaskLike[F]): Observable[A]

    Version of resourceCase that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of resourceCase that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  91. def resourceF[F[_], A](acquire: F[A])(release: (A) => F[Unit])(implicit F: TaskLike[F]): Observable[A]

    Version of resource that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of resource that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
  92. def suspend[A](fa: => Observable[A]): Observable[A]

    Alias for defer.

  93. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  94. def tailRecM[A, B](a: A)(f: (A) => Observable[Either[A, B]]): Observable[B]

    Keeps calling f and concatenating the resulting observables for each scala.util.Left event emitted by the source, concatenating the resulting observables and pushing every scala.util.Right[B] events downstream.

    Keeps calling f and concatenating the resulting observables for each scala.util.Left event emitted by the source, concatenating the resulting observables and pushing every scala.util.Right[B] events downstream.

    Based on Phil Freeman's Stack Safety for Free.

    It helps to wrap your head around it if you think of it as being equivalent to this inefficient and unsafe implementation (for Observable):

    // Don't do this kind of recursion, because `flatMap` can throw
    // stack overflow errors:
    def tailRecM[A, B](a: A)(f: (A) => Observable[Either[A, B]]): Observable[B] =
      f(a).flatMap {
        case Right(b) => Observable.pure(b)
        case Left(nextA) => tailRecM(nextA)(f)
     }
  95. def timerRepeated[A](initialDelay: FiniteDuration, period: FiniteDuration, unit: A): Observable[A]

    Create an Observable that repeatedly emits the given item, until the underlying Observer cancels.

  96. def toReactive[A](source: Observable[A])(implicit s: Scheduler): Publisher[A]

    Wraps this Observable into a org.reactivestreams.Publisher.

    Wraps this Observable into a org.reactivestreams.Publisher. See the Reactive Streams protocol that Monix implements.

  97. def toString(): String
    Definition Classes
    AnyRef → Any
  98. def unfold[S, A](seed: => S)(f: (S) => Option[(A, S)]): Observable[A]

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function until None is returned.

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function until None is returned.

    Example:
    1. Observable.unfold(0)(i => if (i < 10) Some((i, i + 1)) else None).toListL
      
      result: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9]
    See also

    paginate for a way to return one more value when generator returns None

  99. def unfoldEval[S, A](seed: => S)(f: (S) => Task[Option[(A, S)]]): Observable[A]

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function until None is returned.

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an observable that keeps generating elements produced by our generator function until None is returned.

    Example:
    1. Observable.unfoldEval(0)(i => if (i < 10) Task.now(Some((i, i + 1))) else Task.now(None)).toListL
      
      result: [0, 1, 2, 3, 4, 5, 6, 7, 8, 9]
    See also

    paginateEval for a way to return one more value when generator returns None

  100. def unfoldEvalF[F[_], S, A](seed: => S)(f: (S) => F[Option[(A, S)]])(implicit F: TaskLike[F]): Observable[A]

    Version of unfoldEval that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    Version of unfoldEval that can work with generic F[_] tasks, anything that's supported via monix.eval.TaskLike conversions.

    So you can work among others with:

    • cats.effect.IO
    • monix.eval.Coeval
    • scala.concurrent.Future
    • ...
    See also

    unfoldEval for a version specialized for Task

  101. val unit: Observable[Unit]

    Reusable value for an Observable[Unit] that emits a single event, the implementation for cats.effect.Applicative.unit.

  102. def unsafeCreate[A](f: (Subscriber[A]) => Cancelable): Observable[A]

    Given a subscribe function, lifts it into an Observable.

    Given a subscribe function, lifts it into an Observable.

    This function is unsafe to use because users have to know and apply the Monix communication contract, related to thread-safety, communicating demand (back-pressure) and error handling.

    Only use if you know what you're doing. Otherwise prefer create.

  103. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  104. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  105. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  106. def zip2[A1, A2](oa1: Observable[A1], oa2: Observable[A2]): Observable[(A1, A2)]

    Creates a new observable from two observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from two observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    Visual Example

    stream1: 1 - - 2 - - 3 - 4 - -
    stream2: 1 - - 2 - 3 - - - - 4
    
    result: (1, 1), (2, 2), (3, 3), (4, 4)
    

    See combineLatestMap2 for a more relaxed alternative that doesn't combine items in strict sequence.

  107. def zip3[A1, A2, A3](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3]): Observable[(A1, A2, A3)]

    Creates a new observable from three observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from three observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap3 for a more relaxed alternative that doesn't combine items in strict sequence.

  108. def zip4[A1, A2, A3, A4](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4]): Observable[(A1, A2, A3, A4)]

    Creates a new observable from four observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from four observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap4 for a more relaxed alternative that doesn't combine items in strict sequence.

  109. def zip5[A1, A2, A3, A4, A5](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5]): Observable[(A1, A2, A3, A4, A5)]

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap5 for a more relaxed alternative that doesn't combine items in strict sequence.

  110. def zip6[A1, A2, A3, A4, A5, A6](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5], oa6: Observable[A6]): Observable[(A1, A2, A3, A4, A5, A6)]

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap5 for a more relaxed alternative that doesn't combine items in strict sequence.

  111. def zipList[A](sources: Observable[A]*): Observable[Seq[A]]

    Given an observable sequence, it zips them together returning a new observable that generates sequences.

  112. def zipMap2[A1, A2, R](oa1: Observable[A1], oa2: Observable[A2])(f: (A1, A2) => R): Observable[R]

    Creates a new observable from two observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from two observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    Visual Example

    stream1: 1 - - 2 - - 3 - 4 - -
    stream2: 1 - - 2 - 3 - - - - 4
    
    result: (1, 1), (2, 2), (3, 3), (4, 4)
    

    See combineLatestMap2 for a more relaxed alternative that doesn't combine items in strict sequence.

    f

    is the mapping function applied over the generated pairs

  113. def zipMap3[A1, A2, A3, R](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3])(f: (A1, A2, A3) => R): Observable[R]

    Creates a new observable from three observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from three observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap3 for a more relaxed alternative that doesn't combine items in strict sequence.

    f

    is the mapping function applied over the generated pairs

  114. def zipMap4[A1, A2, A3, A4, R](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4])(f: (A1, A2, A3, A4) => R): Observable[R]

    Creates a new observable from four observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from four observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap4 for a more relaxed alternative that doesn't combine items in strict sequence.

    f

    is the mapping function applied over the generated pairs

  115. def zipMap5[A1, A2, A3, A4, A5, R](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5])(f: (A1, A2, A3, A4, A5) => R): Observable[R]

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap5 for a more relaxed alternative that doesn't combine items in strict sequence.

    f

    is the mapping function applied over the generated pairs

  116. def zipMap6[A1, A2, A3, A4, A5, A6, R](oa1: Observable[A1], oa2: Observable[A2], oa3: Observable[A3], oa4: Observable[A4], oa5: Observable[A5], oa6: Observable[A6])(f: (A1, A2, A3, A4, A5, A6) => R): Observable[R]

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    Creates a new observable from five observable sequences by combining their items in pairs in a strict sequence.

    So the first item emitted by the new observable will be the result of the function applied to the first items emitted by each of the source observables; the second item emitted by the new observable will be the result of the function applied to the second items emitted by each of those observables; and so forth.

    See combineLatestMap5 for a more relaxed alternative that doesn't combine items in strict sequence.

    f

    is the mapping function applied over the generated pairs

Deprecated Value Members

  1. def concat[A](sources: Observable[A]*): Observable[A]

    DEPRECATED — please switch to the concat method.

    DEPRECATED — please switch to the concat method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).concat

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).concat

  2. def concatDelayError[A](sources: Observable[A]*): Observable[A]

    DEPRECATED — please switch to the concatDelayErrors method.

    DEPRECATED — please switch to the concatDelayErrors method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).concatDelayErrors

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).concatDelayErrors

  3. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable]) @Deprecated
    Deprecated
  4. def flatten[A](sources: Observable[A]*): Observable[A]

    DEPRECATED — please switch to the flatten method.

    DEPRECATED — please switch to the flatten method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).flatten

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).flatten

  5. def flattenDelayError[A](sources: Observable[A]*): Observable[A]

    DEPRECATED — please switch to the flattenDelayErrors method.

    DEPRECATED — please switch to the flattenDelayErrors method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).flattenDelayErrors

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).flattenDelayErrors

  6. def fork[A](fa: Observable[A], scheduler: Scheduler): Observable[A]

    DEPRECATED — please use .executeOn.

    DEPRECATED — please use .executeOn.

    The reason for the deprecation is the repurposing of the word "fork" in Task.

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Please use Observable!.executeOn

  7. def fork[A](fa: Observable[A]): Observable[A]

    DEPRECATED — please use .executeAsync.

    DEPRECATED — please use .executeAsync.

    The reason for the deprecation is the repurposing of the word "fork" in Task.

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Please use Observable!.executeAsync

  8. def fromEval[A](fa: Eval[A]): Observable[A]

    DEPRECATED — switch to Observable.from.

    DEPRECATED — switch to Observable.from.

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable.from

  9. def fromIO[A](fa: IO[A]): Observable[A]

    DEPRECATED — switch to Observable.from.

    DEPRECATED — switch to Observable.from.

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable.from

  10. def merge[A](sources: Observable[A]*)(implicit os: OverflowStrategy[A] = OverflowStrategy.Default): Observable[A]

    DEPRECATED — please switch to the merge method.

    DEPRECATED — please switch to the merge method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).merge

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).merge

  11. def mergeDelayError[A](sources: Observable[A]*)(implicit os: OverflowStrategy[A] = OverflowStrategy.Default): Observable[A]

    DEPRECATED — please switch to the merge method.

    DEPRECATED — please switch to the merge method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).merge

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).merge

  12. def switch[A](sources: Observable[A]*): Observable[A]

    DEPRECATED — please switch to the switch method.

    DEPRECATED — please switch to the switch method.

    This deprecation was made because there's no point in having this function described both as a method and as a companion object function. In general in API design we either have both for all functions, or we have to choose.

    Switch to: Observable(list).switch

    Definition Classes
    ObservableDeprecatedBuilders
    Annotations
    @deprecated
    Deprecated

    (Since version 3.0.0) Switch to Observable(list).switch

Inherited from Serializable

Inherited from ObservableDeprecatedBuilders

Inherited from AnyRef

Inherited from Any

Ungrouped