monifu.reactive.channels

SubjectChannel

class SubjectChannel[I, +O] extends ObservableChannel[I, O]

Wraps any Subject into a Channel.

Linear Supertypes
Known Subclasses
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. SubjectChannel
  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 >: O](other: ⇒ Observable[U]): ObservableChannel[I, U]

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

    Definition Classes
    LiftOperators2
  6. def :+[U >: O](elem: U): ObservableChannel[I, 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 >: O](other: Observable[U]): ObservableChannel[I, U]

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

    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 >: O](overflowStrategy: Evicted, onOverflow: (Long) ⇒ U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  13. def asyncBoundary(overflowStrategy: OverflowStrategy): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  14. def behavior[U >: O](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): ObservableChannel[I, Seq[O]]

    Definition Classes
    LiftOperators2
  16. def buffer(timespan: FiniteDuration): ObservableChannel[I, Seq[O]]

    Definition Classes
    LiftOperators2
  17. def buffer(count: Int, skip: Int): ObservableChannel[I, Seq[O]]

    Definition Classes
    LiftOperators2
  18. def buffer(count: Int): ObservableChannel[I, Seq[O]]

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

    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[O]

    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[O]

    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[O, U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  24. def combineLatest[U](other: Observable[U]): ObservableChannel[I, (O, U)]

    Definition Classes
    LiftOperators2
  25. def combineLatestDelayError[U](other: Observable[U]): ObservableChannel[I, (O, U)]

    Definition Classes
    LiftOperators2
  26. def complete: ObservableChannel[I, Nothing]

    Definition Classes
    LiftOperators2
  27. def concat[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  28. def concatDelayError[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  29. def concatMap[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  30. def concatMapDelayError[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  31. def count: ObservableChannel[I, Long]

    Definition Classes
    LiftOperators2
  32. def debounce[U](selector: (O) ⇒ Observable[Any], f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  33. def debounce(selector: (O) ⇒ Observable[Any]): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  34. def debounce[U](timeout: FiniteDuration, f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  35. def debounce(timeout: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  36. def debounceRepeated(period: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  37. def defaultIfEmpty[U >: O](default: U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  38. def delay[U](selector: (O) ⇒ Observable[U]): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  39. def delay(duration: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  40. def delaySubscription(timespan: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  41. def delaySubscription[U](trigger: Observable[U]): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  42. def distinct[U](fn: (O) ⇒ U): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  43. def distinct: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  44. def distinctUntilChanged[U](fn: (O) ⇒ U): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  45. def distinctUntilChanged: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  46. def doOnCanceled(cb: ⇒ Unit): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  47. def doOnComplete(cb: ⇒ Unit): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  48. def doOnError(cb: (Throwable) ⇒ Unit): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  49. def doOnStart(cb: (O) ⇒ Unit): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  50. def doWork(cb: (O) ⇒ Unit): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  51. def drop(n: Int): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  52. def dropByTimespan(timespan: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  53. def dropWhile(p: (O) ⇒ Boolean): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  54. def dropWhileWithIndex(p: (O, Int) ⇒ Boolean): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  55. def dump(prefix: String, out: PrintStream = System.out): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  56. def echoOnce(timeout: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  57. def echoRepeated(timeout: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  58. def endWith[U >: O](elems: U*): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  59. def endWithError(error: Throwable): ObservableChannel[I, O]

    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: ObservableChannel[I, Throwable]

    Definition Classes
    LiftOperators2
  63. def exists(p: (O) ⇒ Boolean): ObservableChannel[I, Boolean]

    Definition Classes
    LiftOperators2
  64. def filter(p: (O) ⇒ Boolean): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  65. def finalize(): Unit

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

    Definition Classes
    LiftOperators2
  67. def firstOrElse[U >: O](default: ⇒ U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  68. def flatMap[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  69. def flatMapDelayError[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  70. def flatMapLatest[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  71. def flatScan[R](initial: R)(op: (R, O) ⇒ Observable[R]): ObservableChannel[I, R]

    Definition Classes
    LiftOperators2
  72. def flatScanDelayError[R](initial: R)(op: (R, O) ⇒ Observable[R]): ObservableChannel[I, R]

    Definition Classes
    LiftOperators2
  73. def flatten[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  74. def flattenDelayError[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  75. def flattenLatest[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  76. def foldLeft[R](initial: R)(op: (R, O) ⇒ R): ObservableChannel[I, R]

    Definition Classes
    LiftOperators2
  77. def forAll(p: (O) ⇒ Boolean): ObservableChannel[I, Boolean]

    Definition Classes
    LiftOperators2
  78. def foreach(cb: (O) ⇒ 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: (O) ⇒ K): ObservableChannel[I, GroupedObservable[K, O]]

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

    Definition Classes
    LiftOperators2
  82. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  83. def head: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  84. def headOrElse[B >: O](default: ⇒ B): ObservableChannel[I, B]

    Definition Classes
    LiftOperators2
  85. def ignoreElements: ObservableChannel[I, Nothing]

    Definition Classes
    LiftOperators2
  86. def isEmpty: ObservableChannel[I, Boolean]

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

    Definition Classes
    Any
  88. def last: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  89. def lift[U](f: (Observable[O]) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  90. def liftToSelf[U](f: (Observable[O]) ⇒ Observable[U]): ObservableChannel[I, U]

    Attributes
    protected
    Definition Classes
    ObservableChannelLiftOperators2
  91. def map[U](f: (O) ⇒ U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  92. def materialize: ObservableChannel[I, Notification[O]]

    Definition Classes
    LiftOperators2
  93. def max[U >: O](implicit ev: Ordering[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  94. def maxBy[U](f: (O) ⇒ U)(implicit ev: Ordering[U]): ObservableChannel[I, O]

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

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

    Definition Classes
    LiftOperators2
  97. def merge[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

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

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

    Definition Classes
    LiftOperators2
  100. def mergeDelayErrors[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  101. def mergeMap[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  102. def mergeMapDelayErrors[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  103. def min[U >: O](implicit ev: Ordering[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  104. def minBy[U](f: (O) ⇒ U)(implicit ev: Ordering[U]): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  105. def multicast[U >: O, 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: ObservableChannel[I, Boolean]

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

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

    Definition Classes
    AnyRef
  110. def onErrorFallbackTo[U >: O](that: ⇒ Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  111. def onErrorRecoverWith[U >: O](pf: PartialFunction[Throwable, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  112. def onErrorRetry(maxRetries: Long): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  113. def onErrorRetryIf(p: (Throwable) ⇒ Boolean): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  114. def onErrorRetryUnlimited: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  115. final def onSubscribe(subscriber: Subscriber[O]): 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
    SubjectChannelObservable
    See also

    subscribe.

  116. def onSubscribe(observer: Observer[O])(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
  117. def publish(implicit s: Scheduler): ConnectableObservable[O]

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

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

    End the stream.

    End the stream.

    Definition Classes
    SubjectChannelChannel
  120. final def pushError(ex: Throwable): Unit

    Ends the stream with an error.

    Ends the stream with an error.

    Definition Classes
    SubjectChannelChannel
  121. final def pushNext(elems: I*): Unit

    Push the given events down the stream.

    Push the given events down the stream.

    Definition Classes
    SubjectChannelChannel
  122. def reduce[U >: O](op: (U, U) ⇒ U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  123. def repeat: ObservableChannel[I, O]

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

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

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

    Definition Classes
    LiftOperators2
  127. def sample(initialDelay: FiniteDuration, delay: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  128. def sample(delay: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  129. def sampleRepeated[U](sampler: Observable[U]): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  130. def sampleRepeated(initialDelay: FiniteDuration, delay: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  131. def sampleRepeated(delay: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  132. def scan[R](initial: R)(op: (R, O) ⇒ R): ObservableChannel[I, R]

    Definition Classes
    LiftOperators2
  133. def share(implicit s: Scheduler): Observable[O]

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

    Definition Classes
    LiftOperators2
  135. def subscribe(nextFn: (O) ⇒ 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
  136. 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
  137. def subscribe(nextFn: (O) ⇒ 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
  138. def subscribe(nextFn: (O) ⇒ 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
  139. def subscribe(observer: Observer[O])(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
  140. def subscribe(subscriber: Subscriber[O]): 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 subscribeOn(s: Scheduler): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  142. def sum[U >: O](implicit ev: Numeric[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  143. def switch[U](implicit ev: <:<[O, Observable[U]]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  144. def switchMap[U](f: (O) ⇒ Observable[U]): ObservableChannel[I, U]

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

    Definition Classes
    AnyRef
  146. def tail: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  147. def take(timespan: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  148. def take(n: Long): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  149. def takeRight(n: Int): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  150. def takeWhile(p: (O) ⇒ Boolean): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  151. def takeWhileNotCanceled(c: BooleanCancelable): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  152. def throttleFirst(interval: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  153. def throttleLast(period: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  154. def throttleWithTimeout(timeout: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  155. def timeout[U >: O](timeout: FiniteDuration, backup: Observable[U]): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  156. def timeout(timeout: FiniteDuration): ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  157. def toReactive[U >: O](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
  158. def toString(): String

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

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

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

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

    Definition Classes
    LiftOperators2
  163. def whileBusyBuffer[U >: O](overflowStrategy: Synchronous): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  164. def whileBusyDropEvents[U >: O](onOverflow: (Long) ⇒ U): ObservableChannel[I, U]

    Definition Classes
    LiftOperators2
  165. def whileBusyDropEvents: ObservableChannel[I, O]

    Definition Classes
    LiftOperators2
  166. def window(timespan: FiniteDuration, maxCount: Int): ObservableChannel[I, Observable[O]]

    Definition Classes
    LiftOperators2
  167. def window(timespan: FiniteDuration): ObservableChannel[I, Observable[O]]

    Definition Classes
    LiftOperators2
  168. def window(count: Int, skip: Int): ObservableChannel[I, Observable[O]]

    Definition Classes
    LiftOperators2
  169. def window(count: Int): ObservableChannel[I, Observable[O]]

    Definition Classes
    LiftOperators2
  170. def zip[U](other: Observable[U]): ObservableChannel[I, (O, U)]

    Definition Classes
    LiftOperators2
  171. def zipWithIndex: ObservableChannel[I, (O, Long)]

    Definition Classes
    LiftOperators2

Inherited from ObservableChannel[I, O]

Inherited from LiftOperators2[I, O, ObservableChannel]

Inherited from Channel[I]

Inherited from Observable[O]

Inherited from AnyRef

Inherited from Any

Ungrouped