monifu.reactive.observables

GroupedObservable

trait GroupedObservable[K, +V] extends Observable[V] with LiftOperators2[K, V, GroupedObservable]

A GroupedObservable is an observable type generated by Observable.groupBy. It has the following properties:

- comes accompanied with a key property after which the grouping was made

- supports a single subscriber, throwing IllegalStateException if you attempt multiple subscriptions

Self Type
GroupedObservable[K, V]
Linear Supertypes
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. GroupedObservable
  2. LiftOperators2
  3. Observable
  4. AnyRef
  5. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract def key: K

    Returns the key associated with this grouped observable.

  2. abstract def onSubscribe(subscriber: Subscriber[V]): Unit

    Characteristic function for an Observable instance, that creates the subscription and that eventually starts the streaming of events to the given Observer, being meant to be overridden in custom combinators or in classes implementing Observable.

    Characteristic function for an Observable instance, that creates the subscription and that eventually starts the streaming of events to the given Observer, being meant to be overridden in custom combinators or in classes implementing Observable.

    This function is "unsafe" to call because it does not protect the calls to the given Observer implementation in regards to unexpected exceptions that violate the contract, therefore the given instance must respect its contract and not throw any exceptions when the observable calls onNext, onComplete and onError. If it does, then the behavior is undefined.

    Definition Classes
    Observable
    See also

    subscribe.

Concrete Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. def ++[U >: V](other: ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  5. def +:[U >: V](elem: U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  6. def :+[U >: V](elem: U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  7. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  8. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  9. def ambWith[U >: V](other: Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  10. def asFuture(implicit s: Scheduler): Future[Option[V]]

    Returns the first generated result as a Future and then cancels the subscription.

    Returns the first generated result as a Future and then cancels the subscription.

    Definition Classes
    Observable
  11. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  12. def asyncBoundary[U >: V](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  13. def asyncBoundary(overflowStrategy: OverflowStrategy): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  14. def behavior[U >: V](initialValue: U)(implicit s: Scheduler): ConnectableObservable[U]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers). The underlying subject used is a BehaviorSubject.

    Definition Classes
    Observable
  15. def buffer(timespan: FiniteDuration, maxSize: Int): GroupedObservable[K, Seq[V]]

    Definition Classes
    LiftOperators2
  16. def buffer(timespan: FiniteDuration): GroupedObservable[K, Seq[V]]

    Definition Classes
    LiftOperators2
  17. def buffer(count: Int, skip: Int): GroupedObservable[K, Seq[V]]

    Definition Classes
    LiftOperators2
  18. def buffer(count: Int): GroupedObservable[K, Seq[V]]

    Definition Classes
    LiftOperators2
  19. def bufferIntrospective(maxSize: Int): Observable[List[V]]

    Buffers signals while busy, after which it emits the buffered events as a single bundle.

    Buffers signals while busy, after which it emits the buffered events as a single bundle.

    This operator starts applying back-pressure when the underlying buffer's size is exceeded.

    Definition Classes
    Observable
  20. def cache(maxCapacity: Int): Observable[V]

    Caches the emissions from the source Observable and replays them in order to any subsequent Subscribers.

    Caches the emissions from the source Observable and replays them in order to any subsequent Subscribers. This method has similar behavior to replay except that this auto-subscribes to the source Observable rather than returning a ConnectableObservable for which you must call connect to activate the subscription.

    When you call cache, it does not yet subscribe to the source Observable and so does not yet begin caching items. This only happens when the first Subscriber calls the resulting Observable's subscribe method.

    maxCapacity

    is the maximum buffer size after which old events start being dropped (according to what happens when using ReplaySubject.createWithSize)

    returns

    an Observable that, when first subscribed to, caches all of its items and notifications for the benefit of subsequent subscribers

    Definition Classes
    Observable
  21. def cache: Observable[V]

    Caches the emissions from the source Observable and replays them in order to any subsequent Subscribers.

    Caches the emissions from the source Observable and replays them in order to any subsequent Subscribers. This method has similar behavior to replay except that this auto-subscribes to the source Observable rather than returning a ConnectableObservable for which you must call connect to activate the subscription.

    When you call cache, it does not yet subscribe to the source Observable and so does not yet begin caching items. This only happens when the first Subscriber calls the resulting Observable's subscribe method.

    Note: You sacrifice the ability to cancel the origin when you use the cache operator so be careful not to use this on Observables that emit an infinite or very large number of items that will use up memory.

    returns

    an Observable that, when first subscribed to, caches all of its items and notifications for the benefit of subsequent subscribers

    Definition Classes
    Observable
  22. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  23. def collect[U](pf: PartialFunction[V, U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  24. def combineLatest[U](other: Observable[U]): GroupedObservable[K, (V, U)]

    Definition Classes
    LiftOperators2
  25. def combineLatestDelayError[U](other: Observable[U]): GroupedObservable[K, (V, U)]

    Definition Classes
    LiftOperators2
  26. def complete: GroupedObservable[K, Nothing]

    Definition Classes
    LiftOperators2
  27. def concat[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  28. def concatDelayError[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  29. def concatMap[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  30. def concatMapDelayError[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  31. def count: GroupedObservable[K, Long]

    Definition Classes
    LiftOperators2
  32. def debounce[U](selector: (V) ⇒ Observable[Any], f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  33. def debounce(selector: (V) ⇒ Observable[Any]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  34. def debounce[U](timeout: FiniteDuration, f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  35. def debounce(timeout: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  36. def debounceRepeated(period: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  37. def defaultIfEmpty[U >: V](default: U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  38. def delay[U](selector: (V) ⇒ Observable[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  39. def delay(duration: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  40. def delaySubscription(timespan: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  41. def delaySubscription[U](trigger: Observable[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  42. def distinct[U](fn: (V) ⇒ U): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  43. def distinct: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  44. def distinctUntilChanged[U](fn: (V) ⇒ U): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  45. def distinctUntilChanged: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  46. def doOnCanceled(cb: ⇒ Unit): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  47. def doOnComplete(cb: ⇒ Unit): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  48. def doOnError(cb: (Throwable) ⇒ Unit): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  49. def doOnStart(cb: (V) ⇒ Unit): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  50. def doWork(cb: (V) ⇒ Unit): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  51. def drop(n: Int): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  52. def dropByTimespan(timespan: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  53. def dropWhile(p: (V) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  54. def dropWhileWithIndex(p: (V, Int) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  55. def dump(prefix: String, out: PrintStream = System.out): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  56. def echoOnce(timeout: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  57. def echoRepeated(timeout: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  58. def endWith[U >: V](elems: U*): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  59. def endWithError(error: Throwable): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  60. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  61. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  62. def error: GroupedObservable[K, Throwable]

    Definition Classes
    LiftOperators2
  63. def exists(p: (V) ⇒ Boolean): GroupedObservable[K, Boolean]

    Definition Classes
    LiftOperators2
  64. def filter(p: (V) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  65. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  66. def find(p: (V) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  67. def firstOrElse[U >: V](default: ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  68. def flatMap[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  69. def flatMapDelayError[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  70. def flatMapLatest[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  71. def flatScan[R](initial: R)(op: (R, V) ⇒ Observable[R]): GroupedObservable[K, R]

    Definition Classes
    LiftOperators2
  72. def flatScanDelayError[R](initial: R)(op: (R, V) ⇒ Observable[R]): GroupedObservable[K, R]

    Definition Classes
    LiftOperators2
  73. def flatten[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  74. def flattenDelayError[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  75. def flattenLatest[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  76. def foldLeft[R](initial: R)(op: (R, V) ⇒ R): GroupedObservable[K, R]

    Definition Classes
    LiftOperators2
  77. def forAll(p: (V) ⇒ Boolean): GroupedObservable[K, Boolean]

    Definition Classes
    LiftOperators2
  78. def foreach(cb: (V) ⇒ Unit)(implicit s: Scheduler): Unit

    Subscribes to the source Observable and foreach element emitted by the source it executes the given callback.

    Subscribes to the source Observable and foreach element emitted by the source it executes the given callback.

    Definition Classes
    Observable
  79. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  80. def groupBy[K](keyBufferSize: Int, keySelector: (V) ⇒ K): GroupedObservable[K, GroupedObservable[K, V]]

    Definition Classes
    LiftOperators2
  81. def groupBy[K](keySelector: (V) ⇒ K): GroupedObservable[K, GroupedObservable[K, V]]

    Definition Classes
    LiftOperators2
  82. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  83. def head: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  84. def headOrElse[B >: V](default: ⇒ B): GroupedObservable[K, B]

    Definition Classes
    LiftOperators2
  85. def ignoreElements: GroupedObservable[K, Nothing]

    Definition Classes
    LiftOperators2
  86. def isEmpty: GroupedObservable[K, Boolean]

    Definition Classes
    LiftOperators2
  87. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  88. def last: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  89. def lift[U](f: (Observable[V]) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  90. def liftToSelf[U](f: (Observable[V]) ⇒ Observable[U]): GroupedObservable[K, U]

    Attributes
    protected
    Definition Classes
    GroupedObservableLiftOperators2
  91. def map[U](f: (V) ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  92. def materialize: GroupedObservable[K, Notification[V]]

    Definition Classes
    LiftOperators2
  93. def max[U >: V](implicit ev: Ordering[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  94. def maxBy[U](f: (V) ⇒ U)(implicit ev: Ordering[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  95. def merge[U](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U)(implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  96. def merge[U](overflowStrategy: OverflowStrategy)(implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  97. def merge[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  98. def mergeDelayErrors[U](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U)(implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  99. def mergeDelayErrors[U](overflowStrategy: OverflowStrategy)(implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  100. def mergeDelayErrors[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  101. def mergeMap[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  102. def mergeMapDelayErrors[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  103. def min[U >: V](implicit ev: Ordering[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  104. def minBy[U](f: (V) ⇒ U)(implicit ev: Ordering[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  105. def multicast[U >: V, R](subject: Subject[U, R])(implicit s: Scheduler): ConnectableObservable[R]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers).

    Definition Classes
    Observable
  106. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  107. def nonEmpty: GroupedObservable[K, Boolean]

    Definition Classes
    LiftOperators2
  108. final def notify(): Unit

    Definition Classes
    AnyRef
  109. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  110. def onErrorFallbackTo[U >: V](that: ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  111. def onErrorRecoverWith[U >: V](pf: PartialFunction[Throwable, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  112. def onErrorRetry(maxRetries: Long): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  113. def onErrorRetryIf(p: (Throwable) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  114. def onErrorRetryUnlimited: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  115. def onSubscribe(observer: Observer[V])(implicit s: Scheduler): Unit

    Subscribes to the stream.

    Subscribes to the stream.

    This function is "unsafe" to call because it does not protect the calls to the given Observer implementation in regards to unexpected exceptions that violate the contract, therefore the given instance must respect its contract and not throw any exceptions when the observable calls onNext, onComplete and onError. If it does, then the behavior is undefined.

    observer

    is an Observer that respects the Monifu Rx contract

    s

    is the Scheduler used for creating the subscription

    Definition Classes
    Observable
  116. def publish(implicit s: Scheduler): ConnectableObservable[V]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers). The underlying subject used is a PublishSubject.

    Definition Classes
    Observable
  117. def publishLast(implicit s: Scheduler): ConnectableObservable[V]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers). The underlying subject used is a AsyncSubject.

    Definition Classes
    Observable
  118. def reduce[U >: V](op: (U, U) ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  119. def repeat: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  120. def replay(bufferSize: Int)(implicit s: Scheduler): ConnectableObservable[V]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers). The underlying subject used is a ReplaySubject.

    bufferSize

    is the size of the buffer limiting the number of items that can be replayed (on overflow the head starts being dropped)

    Definition Classes
    Observable
  121. def replay(implicit s: Scheduler): ConnectableObservable[V]

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.

    Converts this observable into a multicast observable, useful for turning a cold observable into a hot one (i.e. whose source is shared by all observers). The underlying subject used is a ReplaySubject.

    Definition Classes
    Observable
  122. def sample[U](sampler: Observable[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  123. def sample(initialDelay: FiniteDuration, delay: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  124. def sample(delay: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  125. def sampleRepeated[U](sampler: Observable[U]): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  126. def sampleRepeated(initialDelay: FiniteDuration, delay: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  127. def sampleRepeated(delay: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  128. def scan[R](initial: R)(op: (R, V) ⇒ R): GroupedObservable[K, R]

    Definition Classes
    LiftOperators2
  129. def share(implicit s: Scheduler): Observable[V]

    Returns a new Observable that multi-casts (shares) the original Observable.

    Returns a new Observable that multi-casts (shares) the original Observable.

    Definition Classes
    Observable
  130. def startWith[U >: V](elems: U*): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  131. def subscribe(nextFn: (V) ⇒ Future[Ack])(implicit s: Scheduler): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  132. def subscribe()(implicit s: Scheduler): Cancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  133. def subscribe(nextFn: (V) ⇒ Future[Ack], errorFn: (Throwable) ⇒ Unit)(implicit s: Scheduler): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  134. def subscribe(nextFn: (V) ⇒ Future[Ack], errorFn: (Throwable) ⇒ Unit, completedFn: () ⇒ Unit)(implicit s: Scheduler): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  135. def subscribe(observer: Observer[V])(implicit s: Scheduler): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  136. def subscribe(subscriber: Subscriber[V]): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  137. def subscribeOn(s: Scheduler): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  138. def sum[U >: V](implicit ev: Numeric[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  139. def switch[U](implicit ev: <:<[V, Observable[U]]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  140. def switchMap[U](f: (V) ⇒ Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  141. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  142. def tail: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  143. def take(timespan: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  144. def take(n: Long): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  145. def takeRight(n: Int): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  146. def takeWhile(p: (V) ⇒ Boolean): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  147. def takeWhileNotCanceled(c: BooleanCancelable): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  148. def throttleFirst(interval: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  149. def throttleLast(period: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  150. def throttleWithTimeout(timeout: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  151. def timeout[U >: V](timeout: FiniteDuration, backup: Observable[U]): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  152. def timeout(timeout: FiniteDuration): GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  153. def toReactive[U >: V](implicit s: Scheduler): Publisher[U]

    Wraps this Observable into a org.reactivestreams.Publisher.

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

    Definition Classes
    Observable
  154. def toString(): String

    Definition Classes
    AnyRef → Any
  155. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  156. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  157. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  158. def whileBusyBuffer[U >: V](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  159. def whileBusyBuffer[U >: V](overflowStrategy: Synchronous): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  160. def whileBusyDropEvents[U >: V](onOverflow: (Long) ⇒ U): GroupedObservable[K, U]

    Definition Classes
    LiftOperators2
  161. def whileBusyDropEvents: GroupedObservable[K, V]

    Definition Classes
    LiftOperators2
  162. def window(timespan: FiniteDuration, maxCount: Int): GroupedObservable[K, Observable[V]]

    Definition Classes
    LiftOperators2
  163. def window(timespan: FiniteDuration): GroupedObservable[K, Observable[V]]

    Definition Classes
    LiftOperators2
  164. def window(count: Int, skip: Int): GroupedObservable[K, Observable[V]]

    Definition Classes
    LiftOperators2
  165. def window(count: Int): GroupedObservable[K, Observable[V]]

    Definition Classes
    LiftOperators2
  166. def zip[U](other: Observable[U]): GroupedObservable[K, (V, U)]

    Definition Classes
    LiftOperators2
  167. def zipWithIndex: GroupedObservable[K, (V, Long)]

    Definition Classes
    LiftOperators2

Inherited from LiftOperators2[K, V, GroupedObservable]

Inherited from Observable[V]

Inherited from AnyRef

Inherited from Any

Ungrouped