monifu.reactive.channels

BehaviorChannel

final class BehaviorChannel[T] extends ObservableChannel[T, T]

A BehaviorChannel is a Channel that uses an underlying BehaviorSubject.

Linear Supertypes
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. BehaviorChannel
  2. ObservableChannel
  3. LiftOperators2
  4. Channel
  5. Observable
  6. AnyRef
  7. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

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 >: T](other: ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  5. def +:[U >: T](elem: U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  6. def :+[U >: T](elem: U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  7. def :=(update: T): Unit

  8. final def ==(arg0: AnyRef): Boolean

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

    Definition Classes
    Any
  10. def ambWith[U >: T](other: Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  11. def apply(): T

  12. def asFuture(implicit s: Scheduler): Future[Option[T]]

    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
  13. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  14. def asyncBoundary[U >: T](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  15. def asyncBoundary(overflowStrategy: OverflowStrategy): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  16. def behavior[U >: T](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
  17. def buffer(timespan: FiniteDuration, maxSize: Int): ObservableChannel[T, Seq[T]]

    Definition Classes
    LiftOperators2
  18. def buffer(timespan: FiniteDuration): ObservableChannel[T, Seq[T]]

    Definition Classes
    LiftOperators2
  19. def buffer(count: Int, skip: Int): ObservableChannel[T, Seq[T]]

    Definition Classes
    LiftOperators2
  20. def buffer(count: Int): ObservableChannel[T, Seq[T]]

    Definition Classes
    LiftOperators2
  21. def bufferIntrospective(maxSize: Int): Observable[List[T]]

    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
  22. def cache(maxCapacity: Int): Observable[T]

    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
  23. def cache: Observable[T]

    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
  24. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  25. def collect[U](pf: PartialFunction[T, U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  26. def combineLatest[U](other: Observable[U]): ObservableChannel[T, (T, U)]

    Definition Classes
    LiftOperators2
  27. def combineLatestDelayError[U](other: Observable[U]): ObservableChannel[T, (T, U)]

    Definition Classes
    LiftOperators2
  28. def complete: ObservableChannel[T, Nothing]

    Definition Classes
    LiftOperators2
  29. def concat[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  30. def concatDelayError[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  31. def concatMap[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  32. def concatMapDelayError[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  33. def count: ObservableChannel[T, Long]

    Definition Classes
    LiftOperators2
  34. def debounce[U](selector: (T) ⇒ Observable[Any], f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  35. def debounce(selector: (T) ⇒ Observable[Any]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  36. def debounce[U](timeout: FiniteDuration, f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  37. def debounce(timeout: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  38. def debounceRepeated(period: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  39. def defaultIfEmpty[U >: T](default: U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  40. def delay[U](selector: (T) ⇒ Observable[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  41. def delay(duration: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  42. def delaySubscription(timespan: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  43. def delaySubscription[U](trigger: Observable[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  44. def distinct[U](fn: (T) ⇒ U): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  45. def distinct: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  46. def distinctUntilChanged[U](fn: (T) ⇒ U): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  47. def distinctUntilChanged: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  48. def doOnCanceled(cb: ⇒ Unit): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  49. def doOnComplete(cb: ⇒ Unit): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  50. def doOnError(cb: (Throwable) ⇒ Unit): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  51. def doOnStart(cb: (T) ⇒ Unit): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  52. def doWork(cb: (T) ⇒ Unit): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  53. def drop(n: Int): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  54. def dropByTimespan(timespan: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  55. def dropWhile(p: (T) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  56. def dropWhileWithIndex(p: (T, Int) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  57. def dump(prefix: String, out: PrintStream = System.out): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  58. def echoOnce(timeout: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  59. def echoRepeated(timeout: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  60. def endWith[U >: T](elems: U*): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  61. def endWithError(error: Throwable): ObservableChannel[T, T]

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

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

    Definition Classes
    AnyRef → Any
  64. def error: ObservableChannel[T, Throwable]

    Definition Classes
    LiftOperators2
  65. def exists(p: (T) ⇒ Boolean): ObservableChannel[T, Boolean]

    Definition Classes
    LiftOperators2
  66. def filter(p: (T) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  67. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  68. def find(p: (T) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  69. def firstOrElse[U >: T](default: ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  70. def flatMap[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  71. def flatMapDelayError[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  72. def flatMapLatest[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  73. def flatScan[R](initial: R)(op: (R, T) ⇒ Observable[R]): ObservableChannel[T, R]

    Definition Classes
    LiftOperators2
  74. def flatScanDelayError[R](initial: R)(op: (R, T) ⇒ Observable[R]): ObservableChannel[T, R]

    Definition Classes
    LiftOperators2
  75. def flatten[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  76. def flattenDelayError[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  77. def flattenLatest[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  78. def foldLeft[R](initial: R)(op: (R, T) ⇒ R): ObservableChannel[T, R]

    Definition Classes
    LiftOperators2
  79. def forAll(p: (T) ⇒ Boolean): ObservableChannel[T, Boolean]

    Definition Classes
    LiftOperators2
  80. def foreach(cb: (T) ⇒ 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
  81. final def getClass(): Class[_]

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

    Definition Classes
    LiftOperators2
  83. def groupBy[K](keySelector: (T) ⇒ K): ObservableChannel[T, GroupedObservable[K, T]]

    Definition Classes
    LiftOperators2
  84. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  85. def head: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  86. def headOrElse[B >: T](default: ⇒ B): ObservableChannel[T, B]

    Definition Classes
    LiftOperators2
  87. def ignoreElements: ObservableChannel[T, Nothing]

    Definition Classes
    LiftOperators2
  88. def isEmpty: ObservableChannel[T, Boolean]

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

    Definition Classes
    Any
  90. def last: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  91. def lift[U](f: (Observable[T]) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  92. def liftToSelf[U](f: (Observable[T]) ⇒ Observable[U]): ObservableChannel[T, U]

    Attributes
    protected
    Definition Classes
    ObservableChannelLiftOperators2
  93. def map[U](f: (T) ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  94. def materialize: ObservableChannel[T, Notification[T]]

    Definition Classes
    LiftOperators2
  95. def max[U >: T](implicit ev: Ordering[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  96. def maxBy[U](f: (T) ⇒ U)(implicit ev: Ordering[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  97. def merge[U](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U)(implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  98. def merge[U](overflowStrategy: OverflowStrategy)(implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  99. def merge[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  100. def mergeDelayErrors[U](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U)(implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  101. def mergeDelayErrors[U](overflowStrategy: OverflowStrategy)(implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  102. def mergeDelayErrors[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  103. def mergeMap[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  104. def mergeMapDelayErrors[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  105. def min[U >: T](implicit ev: Ordering[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  106. def minBy[U](f: (T) ⇒ U)(implicit ev: Ordering[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  107. def multicast[U >: T, 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
  108. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  109. def nonEmpty: ObservableChannel[T, Boolean]

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

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

    Definition Classes
    AnyRef
  112. def onErrorFallbackTo[U >: T](that: ⇒ Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  113. def onErrorRecoverWith[U >: T](pf: PartialFunction[Throwable, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  114. def onErrorRetry(maxRetries: Long): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  115. def onErrorRetryIf(p: (Throwable) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  116. def onErrorRetryUnlimited: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  117. def onSubscribe(subscriber: Subscriber[T]): 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
    BehaviorChannelObservable
    See also

    subscribe.

  118. def onSubscribe(observer: Observer[T])(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
  119. def publish(implicit s: Scheduler): ConnectableObservable[T]

    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
  120. def publishLast(implicit s: Scheduler): ConnectableObservable[T]

    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
  121. def pushComplete(): Unit

    End the stream.

    End the stream.

    Definition Classes
    BehaviorChannelChannel
  122. def pushError(ex: Throwable): Unit

    Ends the stream with an error.

    Ends the stream with an error.

    Definition Classes
    BehaviorChannelChannel
  123. def pushNext(elems: T*): Unit

    Push the given events down the stream.

    Push the given events down the stream.

    Definition Classes
    BehaviorChannelChannel
  124. def reduce[U >: T](op: (U, U) ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  125. def repeat: ObservableChannel[T, T]

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

    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
  127. def replay(implicit s: Scheduler): ConnectableObservable[T]

    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
  128. def sample[U](sampler: Observable[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  129. def sample(initialDelay: FiniteDuration, delay: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  130. def sample(delay: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  131. def sampleRepeated[U](sampler: Observable[U]): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  132. def sampleRepeated(initialDelay: FiniteDuration, delay: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  133. def sampleRepeated(delay: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  134. def scan[R](initial: R)(op: (R, T) ⇒ R): ObservableChannel[T, R]

    Definition Classes
    LiftOperators2
  135. implicit val scheduler: Scheduler

  136. def share(implicit s: Scheduler): Observable[T]

    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
  137. def startWith[U >: T](elems: U*): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  138. def subscribe(nextFn: (T) ⇒ 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
  139. 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
  140. def subscribe(nextFn: (T) ⇒ 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
  141. def subscribe(nextFn: (T) ⇒ 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
  142. def subscribe(observer: Observer[T])(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
  143. def subscribe(subscriber: Subscriber[T]): BooleanCancelable

    Subscribes to the stream.

    Subscribes to the stream.

    returns

    a subscription that can be used to cancel the streaming.

    Definition Classes
    Observable
  144. def subscribeOn(s: Scheduler): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  145. def sum[U >: T](implicit ev: Numeric[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  146. def switch[U](implicit ev: <:<[T, Observable[U]]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  147. def switchMap[U](f: (T) ⇒ Observable[U]): ObservableChannel[T, U]

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

    Definition Classes
    AnyRef
  149. def tail: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  150. def take(timespan: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  151. def take(n: Long): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  152. def takeRight(n: Int): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  153. def takeWhile(p: (T) ⇒ Boolean): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  154. def takeWhileNotCanceled(c: BooleanCancelable): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  155. def throttleFirst(interval: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  156. def throttleLast(period: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  157. def throttleWithTimeout(timeout: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  158. def timeout[U >: T](timeout: FiniteDuration, backup: Observable[U]): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  159. def timeout(timeout: FiniteDuration): ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  160. def toReactive[U >: T](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
  161. def toString(): String

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

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  165. def whileBusyBuffer[U >: T](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  166. def whileBusyBuffer[U >: T](overflowStrategy: Synchronous): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  167. def whileBusyDropEvents[U >: T](onOverflow: (Long) ⇒ U): ObservableChannel[T, U]

    Definition Classes
    LiftOperators2
  168. def whileBusyDropEvents: ObservableChannel[T, T]

    Definition Classes
    LiftOperators2
  169. def window(timespan: FiniteDuration, maxCount: Int): ObservableChannel[T, Observable[T]]

    Definition Classes
    LiftOperators2
  170. def window(timespan: FiniteDuration): ObservableChannel[T, Observable[T]]

    Definition Classes
    LiftOperators2
  171. def window(count: Int, skip: Int): ObservableChannel[T, Observable[T]]

    Definition Classes
    LiftOperators2
  172. def window(count: Int): ObservableChannel[T, Observable[T]]

    Definition Classes
    LiftOperators2
  173. def zip[U](other: Observable[U]): ObservableChannel[T, (T, U)]

    Definition Classes
    LiftOperators2
  174. def zipWithIndex: ObservableChannel[T, (T, Long)]

    Definition Classes
    LiftOperators2

Inherited from ObservableChannel[T, T]

Inherited from LiftOperators2[T, T, ObservableChannel]

Inherited from Channel[T]

Inherited from Observable[T]

Inherited from AnyRef

Inherited from Any

Ungrouped