abstract class Stream[+F[_], +O] extends StreamOps[F, O]

A stream producing output of type O, which may evaluate F effects. If F is Nothing or fs2.Pure, the stream is pure.

Self Type
Stream[F, O]
Source
Stream.scala
Linear Supertypes
StreamOps[F, O], StreamPipe2Ops[F, O], StreamPipeOps[F, O], AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Stream
  2. StreamOps
  3. StreamPipe2Ops
  4. StreamPipeOps
  5. AnyRef
  6. Any
Implicitly
  1. by covaryPure
  2. by StreamPureOps
  3. by any2stringadd
  4. by StringFormat
  5. by Ensuring
  6. by ArrowAssoc
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new Stream()

Abstract Value Members

  1. abstract def get[F2[_], O2 >: O](implicit S: Sub1[F, F2], T: RealSupertype[O, O2]): StreamCore[F2, O2]

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. def +(other: String): String
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to any2stringadd[Stream[F, O]] performed by method any2stringadd in scala.Predef.
    Definition Classes
    any2stringadd
  4. def ++[G[_], Lub[_], B >: O](p2: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  5. def ->[B](y: B): (Stream[F, O], B)
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to ArrowAssoc[Stream[F, O]] performed by method ArrowAssoc in scala.Predef. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    ArrowAssoc
    Annotations
    @inline()
  6. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  7. def append[G[_], Lub[_], B >: O](p2: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  8. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  9. def attempt: Stream[F, Either[Throwable, O]]
    Definition Classes
    StreamOps
  10. def buffer(n: Int): Stream[F, O]

    Alias for self through pipe.buffer.

    Alias for self through pipe.buffer.

    Definition Classes
    StreamPipeOps
  11. def bufferAll: Stream[F, O]

    Alias for self through pipe.bufferAll.

    Alias for self through pipe.bufferAll.

    Definition Classes
    StreamPipeOps
  12. def bufferBy(f: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.bufferBy.

    Alias for self through pipe.bufferBy.

    Definition Classes
    StreamPipeOps
  13. def chunkLimit(n: Int): Stream[F, Chunk[O]]

    Alias for self through pipe.chunkLimit.

    Alias for self through pipe.chunkLimit.

    Definition Classes
    StreamPipeOps
  14. def chunkN(n: Int, allowFewer: Boolean = true): Stream[F, List[Chunk[O]]]

    Alias for self through pipe.chunkN.

    Alias for self through pipe.chunkN.

    Definition Classes
    StreamPipeOps
  15. def chunks: Stream[F, Chunk[O]]

    Alias for self through pipe.chunks.

    Alias for self through pipe.chunks.

    Definition Classes
    StreamPipeOps
  16. def clone(): AnyRef
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  17. def collect[O2](pf: PartialFunction[O, O2]): Stream[F, O2]

    Alias for self through pipe.collect.

    Alias for self through pipe.collect.

    Definition Classes
    StreamPipeOps
  18. def collectFirst[O2](pf: PartialFunction[O, O2]): Stream[F, O2]

    Alias for self through pipe.collectFirst.

    Alias for self through pipe.collectFirst.

    Definition Classes
    StreamPipeOps
  19. def cons[A2 >: O](c: Chunk[A2])(implicit T: RealSupertype[O, A2]): Stream[F, A2]

    Prepend a single chunk onto the front of this stream.

    Prepend a single chunk onto the front of this stream.

    Definition Classes
    StreamOps
  20. def cons1[A2 >: O](a: A2)(implicit T: RealSupertype[O, A2]): Stream[F, A2]

    Prepend a single value onto the front of this stream.

    Prepend a single value onto the front of this stream.

    Definition Classes
    StreamOps
  21. def covary[F2[_]](implicit S: Sub1[F, F2]): Stream[F2, O]
    Definition Classes
    StreamOps
  22. def delete(f: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.delete.

    Alias for self through pipe.delete.

    Definition Classes
    StreamPipeOps
  23. def drain: Stream[F, Nothing]
    Definition Classes
    StreamOps
  24. def drop(n: Int): Stream[F, O]

    Alias for self through pipe.drop.

    Alias for self through pipe.drop.

    Definition Classes
    StreamPipeOps
  25. def dropLast: Stream[F, O]

    Alias for self through pipe.dropLast.

    Alias for self through pipe.dropLast.

    Definition Classes
    StreamPipeOps
  26. def dropLastIf(p: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.dropLastIf.

    Alias for self through pipe.dropLastIf.

    Definition Classes
    StreamPipeOps
  27. def dropRight(n: Int): Stream[F, O]

    Alias for self through pipe.dropRight.

    Alias for self through pipe.dropRight.

    Definition Classes
    StreamPipeOps
  28. def dropWhile(p: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.dropWhile

    Alias for self through pipe.dropWhile

    Definition Classes
    StreamPipeOps
  29. def either[F2[_], O2](s2: Stream[F2, O2])(implicit arg0: Async[F2], S: Sub1[F, F2]): Stream[F2, Either[O, O2]]

    Alias for (this through2v s2)(pipe2.either).

    Alias for (this through2v s2)(pipe2.either).

    Definition Classes
    StreamPipe2Ops
  30. def ensuring(cond: (Stream[F, O]) ⇒ Boolean, msg: ⇒ Any): Stream[F, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Ensuring[Stream[F, O]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  31. def ensuring(cond: (Stream[F, O]) ⇒ Boolean): Stream[F, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Ensuring[Stream[F, O]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  32. def ensuring(cond: Boolean, msg: ⇒ Any): Stream[F, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Ensuring[Stream[F, O]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  33. def ensuring(cond: Boolean): Stream[F, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Ensuring[Stream[F, O]] performed by method Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  34. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  35. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  36. def evalMap[G[_], Lub[_], B](f: (O) ⇒ G[B])(implicit L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  37. def exists(f: (O) ⇒ Boolean): Stream[F, Boolean]

    Alias for self through pipe.exists.

    Alias for self through pipe.exists.

    Definition Classes
    StreamPipeOps
  38. final def fetchAsync[F2[_], O2 >: O](implicit F2: Async[F2], S: Sub1[F, F2], T: RealSupertype[O, O2]): Stream[F2, Future[F2, Stream[F2, O2]]]
  39. def filter(f: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.filter.

    Alias for self through pipe.filter.

    Definition Classes
    StreamPipeOps
  40. def finalize(): Unit
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  41. def find(f: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.find.

    Alias for self through pipe.find.

    Definition Classes
    StreamPipeOps
  42. def flatMap[G[_], Lub[_], B](f: (O) ⇒ Stream[G, B])(implicit L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  43. def fold[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, O2]

    Alias for self through pipe.fold(z)(f).

    Alias for self through pipe.fold(z)(f).

    Definition Classes
    StreamPipeOps
  44. def fold1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Alias for self through pipe.fold1(f).

    Alias for self through pipe.fold1(f).

    Definition Classes
    StreamPipeOps
  45. def forall(f: (O) ⇒ Boolean): Stream[F, Boolean]

    Alias for self through pipe.forall.

    Alias for self through pipe.forall.

    Definition Classes
    StreamPipeOps
  46. def formatted(fmtstr: String): String
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to StringFormat[Stream[F, O]] performed by method StringFormat in scala.Predef.
    Definition Classes
    StringFormat
    Annotations
    @inline()
  47. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
  48. def hashCode(): Int
    Definition Classes
    AnyRef → Any
  49. def interleave[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  50. def interleaveAll[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  51. def interruptWhen[F2[_]](haltWhenTrue: Signal[F2, Boolean])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]

    Alias for (haltWhenTrue.discrete through2 this)(pipe2.interrupt).

    Alias for (haltWhenTrue.discrete through2 this)(pipe2.interrupt).

    Definition Classes
    StreamPipe2Ops
  52. def interruptWhen[F2[_]](haltWhenTrue: Stream[F2, Boolean])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]

    Alias for (haltWhenTrue through2 this)(pipe2.interrupt).

    Alias for (haltWhenTrue through2 this)(pipe2.interrupt).

    Definition Classes
    StreamPipe2Ops
  53. def intersperse[O2 >: O](separator: O2): Stream[F, O2]

    Alias for self through pipe.intersperse.

    Alias for self through pipe.intersperse.

    Definition Classes
    StreamPipeOps
  54. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  55. def last: Stream[F, Option[O]]

    Alias for self through pipe.last.

    Alias for self through pipe.last.

    Definition Classes
    StreamPipeOps
  56. def lastOr[O2 >: O](li: ⇒ O2): Stream[F, O2]

    Alias for self through pipe.lastOr.

    Alias for self through pipe.lastOr.

    Definition Classes
    StreamPipeOps
  57. final def map[O2](f: (O) ⇒ O2): Stream[F, O2]
    Definition Classes
    Stream → StreamOps
  58. def mapAccumulate[S, O2](init: S)(f: (S, O) ⇒ (S, O2)): Stream[F, (S, O2)]

    Alias for self through pipe.mapAccumulate

    Alias for self through pipe.mapAccumulate

    Definition Classes
    StreamPipeOps
  59. final def mapChunks[O2](f: (Chunk[O]) ⇒ Chunk[O2]): Stream[F, O2]

    Alias for self through pipe.mapChunks(f).

    Alias for self through pipe.mapChunks(f).

    Definition Classes
    Stream → StreamPipeOps
  60. def mask: Stream[F, O]
    Definition Classes
    StreamOps
  61. def merge[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  62. def mergeDrainL[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  63. def mergeDrainR[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]
    Definition Classes
    StreamPipe2Ops
  64. def mergeHaltBoth[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  65. def mergeHaltL[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  66. def mergeHaltR[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]
    Definition Classes
    StreamPipe2Ops
  67. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  68. def noneTerminate: Stream[F, Option[O]]
    Definition Classes
    StreamOps
  69. final def notify(): Unit
    Definition Classes
    AnyRef
  70. final def notifyAll(): Unit
    Definition Classes
    AnyRef
  71. def onComplete[G[_], Lub[_], B >: O](regardless: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  72. def onError[G[_], Lub[_], B >: O](f: (Throwable) ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[F, G, Lub]): Stream[Lub, B]
    Definition Classes
    StreamOps
  73. def onFinalize[F2[_]](f: F2[Unit])(implicit S: Sub1[F, F2], F2: Monad[F2]): Stream[F2, O]
    Definition Classes
    StreamOps
  74. def open: Pull[F, Nothing, Handle[F, O]]
    Definition Classes
    StreamOps
  75. def output: Pull[F, O, Unit]
    Definition Classes
    StreamOps
  76. def pullv[F2[_], B](using: (Handle[F, O]) ⇒ Pull[F2, B, Any])(implicit S: Sub1[F, F2]): Stream[F2, B]

    Like pull, but the function may add additional effects.

    Like pull, but the function may add additional effects.

    Definition Classes
    StreamOps
  77. def pure(implicit S: Sub1[F, Pure]): Stream[Pure, O]

    Converts a Stream[Nothing,A] in to a Stream[Pure,A].

    Converts a Stream[Nothing,A] in to a Stream[Pure,A].

    Definition Classes
    StreamOps
  78. def reduce[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Alias for self through pipe.reduce(z)(f).

    Alias for self through pipe.reduce(z)(f).

    Definition Classes
    StreamPipeOps
  79. def repeat: Stream[F, O]

    Repeat this stream an infinite number of times.

    Repeat this stream an infinite number of times. s.repeat == s ++ s ++ s ++ ...

    Definition Classes
    StreamOps
  80. final def runFoldFree[O2](z: O2)(f: (O2, O) ⇒ O2): Free[F, O2]
    Definition Classes
    Stream → StreamOps
  81. final def runFoldTraceFree[O2](t: Trace)(z: O2)(f: (O2, O) ⇒ O2): Free[F, O2]
    Definition Classes
    Stream → StreamOps
  82. def runFree: Free[F, Unit]
    Definition Classes
    StreamOps
  83. def runLogFree: Free[F, Vector[O]]
    Definition Classes
    StreamOps
  84. def runTraceFree(t: Trace): Free[F, Unit]
    Definition Classes
    StreamOps
  85. def scan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, O2]

    Alias for self through pipe.scan(z)(f).

    Alias for self through pipe.scan(z)(f).

    Definition Classes
    StreamPipeOps
  86. def scan1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Alias for self through pipe.scan1(f).

    Alias for self through pipe.scan1(f).

    Definition Classes
    StreamPipeOps
  87. def shiftRight[O2 >: O](head: O2*): Stream[F, O2]

    Alias for self through pipe.shiftRight.

    Alias for self through pipe.shiftRight.

    Definition Classes
    StreamPipeOps
  88. def sliding(n: Int): Stream[F, Vector[O]]

    Alias for self through pipe.sliding.

    Alias for self through pipe.sliding.

    Definition Classes
    StreamPipeOps
  89. def split(f: (O) ⇒ Boolean): Stream[F, Vector[O]]

    Alias for self through pipe.split.

    Alias for self through pipe.split.

    Definition Classes
    StreamPipeOps
  90. final def step: Pull[F, Nothing, Step[Chunk[O], Handle[F, O]]]
  91. final def stepAsync[F2[_], O2 >: O](implicit S: Sub1[F, F2], F2: Async[F2], T: RealSupertype[O, O2]): Pull[F2, Nothing, Future[F2, Pull[F2, Nothing, Step[Chunk[O2], Handle[F2, O2]]]]]
  92. def sum[O2 >: O](implicit arg0: Numeric[O2]): Stream[F, O2]

    Alias for self through pipe.sum(f).

    Alias for self through pipe.sum(f).

    Definition Classes
    StreamPipeOps
  93. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  94. def tail: Stream[F, O]

    Alias for self through pipe.tail.

    Alias for self through pipe.tail.

    Definition Classes
    StreamPipeOps
  95. def take(n: Long): Stream[F, O]

    Alias for self through pipe.take(n).

    Alias for self through pipe.take(n).

    Definition Classes
    StreamPipeOps
  96. def takeRight(n: Long): Stream[F, O]

    Alias for self through pipe.takeRight.

    Alias for self through pipe.takeRight.

    Definition Classes
    StreamPipeOps
  97. def takeThrough(p: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.takeThrough.

    Alias for self through pipe.takeThrough.

    Definition Classes
    StreamPipeOps
  98. def takeWhile(p: (O) ⇒ Boolean): Stream[F, O]

    Alias for self through pipe.takeWhile.

    Alias for self through pipe.takeWhile.

    Definition Classes
    StreamPipeOps
  99. def through2v[F2[_], B, C](s2: Stream[F2, B])(f: Pipe2[F2, O, B, C])(implicit S: Sub1[F, F2]): Stream[F2, C]

    Like through2, but the specified Pipe2's effect may be a supertype of F.

    Like through2, but the specified Pipe2's effect may be a supertype of F.

    Definition Classes
    StreamOps
  100. def throughv[F2[_], B](f: Pipe[F2, O, B])(implicit S: Sub1[F, F2]): Stream[F2, B]

    Like through, but the specified Pipe's effect may be a supertype of F.

    Like through, but the specified Pipe's effect may be a supertype of F.

    Definition Classes
    StreamOps
  101. def toList: List[O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream.StreamPureOps[O] performed by method StreamPureOps in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    StreamPureOps
  102. def toString(): String
    Definition Classes
    Stream → AnyRef → Any
  103. def toVector: Vector[O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream.StreamPureOps[O] performed by method StreamPureOps in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    StreamPureOps
  104. def tov[F2[_]](f: Sink[F2, O])(implicit S: Sub1[F, F2]): Stream[F2, Unit]

    Like to, but the specified Sink's effect may be a supertype of F.

    Like to, but the specified Sink's effect may be a supertype of F.

    Definition Classes
    StreamOps
  105. def translate[G[_]](u: ~>[F, G]): Stream[G, O]
    Definition Classes
    StreamOps
  106. def unchunk: Stream[F, O]

    Alias for self through pipe.unchunk.

    Alias for self through pipe.unchunk.

    Definition Classes
    StreamPipeOps
  107. def uncons: Stream[F, Option[Step[Chunk[O], Stream[F, O]]]]
  108. def uncons1: Stream[F, Option[Step[O, Stream[F, O]]]]
  109. def vectorChunkN(n: Int, allowFewer: Boolean = true): Stream[F, Vector[O]]

    Alias for self through pipe.vectorChunkN.

    Alias for self through pipe.vectorChunkN.

    Definition Classes
    StreamPipeOps
  110. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  111. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  112. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  113. def zip[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2]): Stream[F2, (O, O2)]
    Definition Classes
    StreamPipe2Ops
  114. def zipWith[F2[_], O2, O3](s2: Stream[F2, O2])(f: (O, O2) ⇒ O3)(implicit S: Sub1[F, F2]): Stream[F2, O3]
    Definition Classes
    StreamPipe2Ops
  115. def zipWithIndex: Stream[F, (O, Int)]

    Alias for self through pipe.zipWithIndex.

    Alias for self through pipe.zipWithIndex.

    Definition Classes
    StreamPipeOps
  116. def zipWithNext: Stream[F, (O, Option[O])]

    Alias for self through pipe.zipWithNext.

    Alias for self through pipe.zipWithNext.

    Definition Classes
    StreamPipeOps
  117. def zipWithPrevious: Stream[F, (Option[O], O)]

    Alias for self through pipe.zipWithPrevious.

    Alias for self through pipe.zipWithPrevious.

    Definition Classes
    StreamPipeOps
  118. def zipWithPreviousAndNext: Stream[F, (Option[O], O, Option[O])]

    Alias for self through pipe.zipWithPreviousAndNext.

    Alias for self through pipe.zipWithPreviousAndNext.

    Definition Classes
    StreamPipeOps
  119. def zipWithScan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, (O, O2)]

    Alias for self through pipe.zipWithScan.

    Alias for self through pipe.zipWithScan.

    Definition Classes
    StreamPipeOps
  120. def zipWithScan1[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, (O, O2)]

    Alias for self through pipe.zipWithScan1.

    Alias for self through pipe.zipWithScan1.

    Definition Classes
    StreamPipeOps
  121. def [B](y: B): (Stream[F, O], B)
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to ArrowAssoc[Stream[F, O]] performed by method ArrowAssoc in scala.Predef. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    ArrowAssoc

Shadowed Implicit Value Members

  1. def ++[G[_], Lub[_], B >: O](p2: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).++(p2)(R, L)
    Definition Classes
    StreamOps
  2. def append[G[_], Lub[_], B >: O](p2: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).append(p2)(R, L)
    Definition Classes
    StreamOps
  3. def attempt: Stream[Nothing, Either[Throwable, O]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).attempt
    Definition Classes
    StreamOps
  4. def buffer(n: Int): Stream[Nothing, O]

    Alias for self through pipe.buffer.

    Alias for self through pipe.buffer.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).buffer(n)
    Definition Classes
    StreamPipeOps
  5. def bufferAll: Stream[Nothing, O]

    Alias for self through pipe.bufferAll.

    Alias for self through pipe.bufferAll.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).bufferAll
    Definition Classes
    StreamPipeOps
  6. def bufferBy(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.bufferBy.

    Alias for self through pipe.bufferBy.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).bufferBy(f)
    Definition Classes
    StreamPipeOps
  7. def chunkLimit(n: Int): Stream[Nothing, Chunk[O]]

    Alias for self through pipe.chunkLimit.

    Alias for self through pipe.chunkLimit.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).chunkLimit(n)
    Definition Classes
    StreamPipeOps
  8. def chunkN(n: Int, allowFewer: Boolean = true): Stream[Nothing, List[Chunk[O]]]

    Alias for self through pipe.chunkN.

    Alias for self through pipe.chunkN.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).chunkN(n, allowFewer)
    Definition Classes
    StreamPipeOps
  9. def chunks: Stream[Nothing, Chunk[O]]

    Alias for self through pipe.chunks.

    Alias for self through pipe.chunks.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).chunks
    Definition Classes
    StreamPipeOps
  10. def collect[O2](pf: PartialFunction[O, O2]): Stream[Nothing, O2]

    Alias for self through pipe.collect.

    Alias for self through pipe.collect.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).collect(pf)
    Definition Classes
    StreamPipeOps
  11. def collectFirst[O2](pf: PartialFunction[O, O2]): Stream[Nothing, O2]

    Alias for self through pipe.collectFirst.

    Alias for self through pipe.collectFirst.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).collectFirst(pf)
    Definition Classes
    StreamPipeOps
  12. def cons[A2 >: O](c: Chunk[A2])(implicit T: RealSupertype[O, A2]): Stream[Nothing, A2]

    Prepend a single chunk onto the front of this stream.

    Prepend a single chunk onto the front of this stream.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).cons(c)(T)
    Definition Classes
    StreamOps
  13. def cons1[A2 >: O](a: A2)(implicit T: RealSupertype[O, A2]): Stream[Nothing, A2]

    Prepend a single value onto the front of this stream.

    Prepend a single value onto the front of this stream.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).cons1(a)(T)
    Definition Classes
    StreamOps
  14. def covary[F2[_]](implicit S: Sub1[Nothing, F2]): Stream[F2, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).covary(S)
    Definition Classes
    StreamOps
  15. def delete(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.delete.

    Alias for self through pipe.delete.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).delete(f)
    Definition Classes
    StreamPipeOps
  16. def drain: Stream[Nothing, Nothing]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).drain
    Definition Classes
    StreamOps
  17. def drop(n: Int): Stream[Nothing, O]

    Alias for self through pipe.drop.

    Alias for self through pipe.drop.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).drop(n)
    Definition Classes
    StreamPipeOps
  18. def dropLast: Stream[Nothing, O]

    Alias for self through pipe.dropLast.

    Alias for self through pipe.dropLast.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).dropLast
    Definition Classes
    StreamPipeOps
  19. def dropLastIf(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.dropLastIf.

    Alias for self through pipe.dropLastIf.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).dropLastIf(p)
    Definition Classes
    StreamPipeOps
  20. def dropRight(n: Int): Stream[Nothing, O]

    Alias for self through pipe.dropRight.

    Alias for self through pipe.dropRight.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).dropRight(n)
    Definition Classes
    StreamPipeOps
  21. def dropWhile(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.dropWhile

    Alias for self through pipe.dropWhile

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).dropWhile(p)
    Definition Classes
    StreamPipeOps
  22. def either[F2[_], O2](s2: Stream[F2, O2])(implicit arg0: Async[F2], S: Sub1[Nothing, F2]): Stream[F2, Either[O, O2]]

    Alias for (this through2v s2)(pipe2.either).

    Alias for (this through2v s2)(pipe2.either).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).either(s2)(arg0, S)
    Definition Classes
    StreamPipe2Ops
  23. def evalMap[G[_], Lub[_], B](f: (O) ⇒ G[B])(implicit L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).evalMap(f)(L)
    Definition Classes
    StreamOps
  24. def exists(f: (O) ⇒ Boolean): Stream[Nothing, Boolean]

    Alias for self through pipe.exists.

    Alias for self through pipe.exists.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).exists(f)
    Definition Classes
    StreamPipeOps
  25. final def fetchAsync[F2[_], O2 >: O](implicit F2: Async[F2], S: Sub1[Nothing, F2], T: RealSupertype[O, O2]): Stream[F2, Future[F2, Stream[F2, O2]]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).fetchAsync(F2, S, T)
  26. def filter(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.filter.

    Alias for self through pipe.filter.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).filter(f)
    Definition Classes
    StreamPipeOps
  27. def find(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.find.

    Alias for self through pipe.find.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).find(f)
    Definition Classes
    StreamPipeOps
  28. def flatMap[G[_], Lub[_], B](f: (O) ⇒ Stream[G, B])(implicit L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).flatMap(f)(L)
    Definition Classes
    StreamOps
  29. def fold[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.fold(z)(f).

    Alias for self through pipe.fold(z)(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).fold(z)(f)
    Definition Classes
    StreamPipeOps
  30. def fold1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.fold1(f).

    Alias for self through pipe.fold1(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).fold1(f)
    Definition Classes
    StreamPipeOps
  31. def forall(f: (O) ⇒ Boolean): Stream[Nothing, Boolean]

    Alias for self through pipe.forall.

    Alias for self through pipe.forall.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).forall(f)
    Definition Classes
    StreamPipeOps
  32. def get[F2[_], O2 >: O](implicit S: Sub1[Nothing, F2], T: RealSupertype[O, O2]): StreamCore[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).get(S, T)
  33. def interleave[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).interleave(s2)(R, S)
    Definition Classes
    StreamPipe2Ops
  34. def interleaveAll[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).interleaveAll(s2)(R, S)
    Definition Classes
    StreamPipe2Ops
  35. def interruptWhen[F2[_]](haltWhenTrue: Signal[F2, Boolean])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Alias for (haltWhenTrue.discrete through2 this)(pipe2.interrupt).

    Alias for (haltWhenTrue.discrete through2 this)(pipe2.interrupt).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).interruptWhen(haltWhenTrue)(S, F2)
    Definition Classes
    StreamPipe2Ops
  36. def interruptWhen[F2[_]](haltWhenTrue: Stream[F2, Boolean])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Alias for (haltWhenTrue through2 this)(pipe2.interrupt).

    Alias for (haltWhenTrue through2 this)(pipe2.interrupt).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).interruptWhen(haltWhenTrue)(S, F2)
    Definition Classes
    StreamPipe2Ops
  37. def intersperse[O2 >: O](separator: O2): Stream[Nothing, O2]

    Alias for self through pipe.intersperse.

    Alias for self through pipe.intersperse.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).intersperse(separator)
    Definition Classes
    StreamPipeOps
  38. def last: Stream[Nothing, Option[O]]

    Alias for self through pipe.last.

    Alias for self through pipe.last.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).last
    Definition Classes
    StreamPipeOps
  39. def lastOr[O2 >: O](li: ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.lastOr.

    Alias for self through pipe.lastOr.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).lastOr(li)
    Definition Classes
    StreamPipeOps
  40. final def map[O2](f: (O) ⇒ O2): Stream[Nothing, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).map(f)
    Definition Classes
    Stream → StreamOps
  41. def mapAccumulate[S, O2](init: S)(f: (S, O) ⇒ (S, O2)): Stream[Nothing, (S, O2)]

    Alias for self through pipe.mapAccumulate

    Alias for self through pipe.mapAccumulate

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mapAccumulate(init)(f)
    Definition Classes
    StreamPipeOps
  42. final def mapChunks[O2](f: (Chunk[O]) ⇒ Chunk[O2]): Stream[Nothing, O2]

    Alias for self through pipe.mapChunks(f).

    Alias for self through pipe.mapChunks(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mapChunks(f)
    Definition Classes
    Stream → StreamPipeOps
  43. def mask: Stream[Nothing, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mask
    Definition Classes
    StreamOps
  44. def merge[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).merge(s2)(R, S, F2)
    Definition Classes
    StreamPipe2Ops
  45. def mergeDrainL[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mergeDrainL(s2)(S, F2)
    Definition Classes
    StreamPipe2Ops
  46. def mergeDrainR[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mergeDrainR(s2)(S, F2)
    Definition Classes
    StreamPipe2Ops
  47. def mergeHaltBoth[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mergeHaltBoth(s2)(R, S, F2)
    Definition Classes
    StreamPipe2Ops
  48. def mergeHaltL[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mergeHaltL(s2)(R, S, F2)
    Definition Classes
    StreamPipe2Ops
  49. def mergeHaltR[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).mergeHaltR(s2)(R, S, F2)
    Definition Classes
    StreamPipe2Ops
  50. def noneTerminate: Stream[Nothing, Option[O]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).noneTerminate
    Definition Classes
    StreamOps
  51. def onComplete[G[_], Lub[_], B >: O](regardless: ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).onComplete(regardless)(R, L)
    Definition Classes
    StreamOps
  52. def onError[G[_], Lub[_], B >: O](f: (Throwable) ⇒ Stream[G, B])(implicit R: RealSupertype[O, B], L: Lub1[Nothing, G, Lub]): Stream[Lub, B]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).onError(f)(R, L)
    Definition Classes
    StreamOps
  53. def onFinalize[F2[_]](f: F2[Unit])(implicit S: Sub1[Nothing, F2], F2: Monad[F2]): Stream[F2, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).onFinalize(f)(S, F2)
    Definition Classes
    StreamOps
  54. def open: Pull[Nothing, Nothing, Handle[Nothing, O]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).open
    Definition Classes
    StreamOps
  55. def output: Pull[Nothing, O, Unit]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).output
    Definition Classes
    StreamOps
  56. def pullv[F2[_], B](using: (Handle[Nothing, O]) ⇒ Pull[F2, B, Any])(implicit S: Sub1[Nothing, F2]): Stream[F2, B]

    Like pull, but the function may add additional effects.

    Like pull, but the function may add additional effects.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).pullv(using)(S)
    Definition Classes
    StreamOps
  57. def pure(implicit S: Sub1[Nothing, Pure]): Stream[Pure, O]

    Converts a Stream[Nothing,A] in to a Stream[Pure,A].

    Converts a Stream[Nothing,A] in to a Stream[Pure,A].

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).pure(S)
    Definition Classes
    StreamOps
  58. def reduce[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.reduce(z)(f).

    Alias for self through pipe.reduce(z)(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).reduce(f)
    Definition Classes
    StreamPipeOps
  59. def repeat: Stream[Nothing, O]

    Repeat this stream an infinite number of times.

    Repeat this stream an infinite number of times. s.repeat == s ++ s ++ s ++ ...

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).repeat
    Definition Classes
    StreamOps
  60. final def runFoldFree[O2](z: O2)(f: (O2, O) ⇒ O2): Free[Nothing, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).runFoldFree(z)(f)
    Definition Classes
    Stream → StreamOps
  61. final def runFoldTraceFree[O2](t: Trace)(z: O2)(f: (O2, O) ⇒ O2): Free[Nothing, O2]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).runFoldTraceFree(t)(z)(f)
    Definition Classes
    Stream → StreamOps
  62. def runFree: Free[Nothing, Unit]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).runFree
    Definition Classes
    StreamOps
  63. def runLogFree: Free[Nothing, Vector[O]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).runLogFree
    Definition Classes
    StreamOps
  64. def runTraceFree(t: Trace): Free[Nothing, Unit]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).runTraceFree(t)
    Definition Classes
    StreamOps
  65. def scan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.scan(z)(f).

    Alias for self through pipe.scan(z)(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).scan(z)(f)
    Definition Classes
    StreamPipeOps
  66. def scan1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Alias for self through pipe.scan1(f).

    Alias for self through pipe.scan1(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).scan1(f)
    Definition Classes
    StreamPipeOps
  67. def shiftRight[O2 >: O](head: O2*): Stream[Nothing, O2]

    Alias for self through pipe.shiftRight.

    Alias for self through pipe.shiftRight.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).shiftRight(head)
    Definition Classes
    StreamPipeOps
  68. def sliding(n: Int): Stream[Nothing, Vector[O]]

    Alias for self through pipe.sliding.

    Alias for self through pipe.sliding.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).sliding(n)
    Definition Classes
    StreamPipeOps
  69. def split(f: (O) ⇒ Boolean): Stream[Nothing, Vector[O]]

    Alias for self through pipe.split.

    Alias for self through pipe.split.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).split(f)
    Definition Classes
    StreamPipeOps
  70. final def step: Pull[Nothing, Nothing, Step[Chunk[O], Handle[Nothing, O]]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).step
  71. final def stepAsync[F2[_], O2 >: O](implicit S: Sub1[Nothing, F2], F2: Async[F2], T: RealSupertype[O, O2]): Pull[F2, Nothing, Future[F2, Pull[F2, Nothing, Step[Chunk[O2], Handle[F2, O2]]]]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).stepAsync(S, F2, T)
  72. def sum[O2 >: O](implicit arg0: Numeric[O2]): Stream[Nothing, O2]

    Alias for self through pipe.sum(f).

    Alias for self through pipe.sum(f).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).sum(arg0)
    Definition Classes
    StreamPipeOps
  73. def tail: Stream[Nothing, O]

    Alias for self through pipe.tail.

    Alias for self through pipe.tail.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).tail
    Definition Classes
    StreamPipeOps
  74. def take(n: Long): Stream[Nothing, O]

    Alias for self through pipe.take(n).

    Alias for self through pipe.take(n).

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).take(n)
    Definition Classes
    StreamPipeOps
  75. def takeRight(n: Long): Stream[Nothing, O]

    Alias for self through pipe.takeRight.

    Alias for self through pipe.takeRight.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).takeRight(n)
    Definition Classes
    StreamPipeOps
  76. def takeThrough(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.takeThrough.

    Alias for self through pipe.takeThrough.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).takeThrough(p)
    Definition Classes
    StreamPipeOps
  77. def takeWhile(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Alias for self through pipe.takeWhile.

    Alias for self through pipe.takeWhile.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).takeWhile(p)
    Definition Classes
    StreamPipeOps
  78. def through2v[F2[_], B, C](s2: Stream[F2, B])(f: Pipe2[F2, O, B, C])(implicit S: Sub1[Nothing, F2]): Stream[F2, C]

    Like through2, but the specified Pipe2's effect may be a supertype of F.

    Like through2, but the specified Pipe2's effect may be a supertype of F.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).through2v(s2)(f)(S)
    Definition Classes
    StreamOps
  79. def throughv[F2[_], B](f: Pipe[F2, O, B])(implicit S: Sub1[Nothing, F2]): Stream[F2, B]

    Like through, but the specified Pipe's effect may be a supertype of F.

    Like through, but the specified Pipe's effect may be a supertype of F.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).throughv(f)(S)
    Definition Classes
    StreamOps
  80. def toString(): String
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).toString()
    Definition Classes
    Stream → AnyRef → Any
  81. def tov[F2[_]](f: Sink[F2, O])(implicit S: Sub1[Nothing, F2]): Stream[F2, Unit]

    Like to, but the specified Sink's effect may be a supertype of F.

    Like to, but the specified Sink's effect may be a supertype of F.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).tov(f)(S)
    Definition Classes
    StreamOps
  82. def translate[G[_]](u: ~>[Nothing, G]): Stream[G, O]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).translate(u)
    Definition Classes
    StreamOps
  83. def unchunk: Stream[Nothing, O]

    Alias for self through pipe.unchunk.

    Alias for self through pipe.unchunk.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).unchunk
    Definition Classes
    StreamPipeOps
  84. def uncons: Stream[Nothing, Option[Step[Chunk[O], Stream[Nothing, O]]]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).uncons
  85. def uncons1: Stream[Nothing, Option[Step[O, Stream[Nothing, O]]]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).uncons1
  86. def vectorChunkN(n: Int, allowFewer: Boolean = true): Stream[Nothing, Vector[O]]

    Alias for self through pipe.vectorChunkN.

    Alias for self through pipe.vectorChunkN.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).vectorChunkN(n, allowFewer)
    Definition Classes
    StreamPipeOps
  87. def zip[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2]): Stream[F2, (O, O2)]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zip(s2)(S)
    Definition Classes
    StreamPipe2Ops
  88. def zipWith[F2[_], O2, O3](s2: Stream[F2, O2])(f: (O, O2) ⇒ O3)(implicit S: Sub1[Nothing, F2]): Stream[F2, O3]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWith(s2)(f)(S)
    Definition Classes
    StreamPipe2Ops
  89. def zipWithIndex: Stream[Nothing, (O, Int)]

    Alias for self through pipe.zipWithIndex.

    Alias for self through pipe.zipWithIndex.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithIndex
    Definition Classes
    StreamPipeOps
  90. def zipWithNext: Stream[Nothing, (O, Option[O])]

    Alias for self through pipe.zipWithNext.

    Alias for self through pipe.zipWithNext.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithNext
    Definition Classes
    StreamPipeOps
  91. def zipWithPrevious: Stream[Nothing, (Option[O], O)]

    Alias for self through pipe.zipWithPrevious.

    Alias for self through pipe.zipWithPrevious.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithPrevious
    Definition Classes
    StreamPipeOps
  92. def zipWithPreviousAndNext: Stream[Nothing, (Option[O], O, Option[O])]

    Alias for self through pipe.zipWithPreviousAndNext.

    Alias for self through pipe.zipWithPreviousAndNext.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithPreviousAndNext
    Definition Classes
    StreamPipeOps
  93. def zipWithScan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, (O, O2)]

    Alias for self through pipe.zipWithScan.

    Alias for self through pipe.zipWithScan.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithScan(z)(f)
    Definition Classes
    StreamPipeOps
  94. def zipWithScan1[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, (O, O2)]

    Alias for self through pipe.zipWithScan1.

    Alias for self through pipe.zipWithScan1.

    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).zipWithScan1(z)(f)
    Definition Classes
    StreamPipeOps

Deprecated Value Members

  1. def terminated: Stream[Nothing, Option[O]]
    Implicit
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.StreamDerived. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (stream: Stream[Nothing, O]).terminated
    Definition Classes
    StreamOps
    Annotations
    @deprecated
    Deprecated

    (Since version 0.9) renamed to noneTerminate

  2. def terminated: Stream[F, Option[O]]
    Definition Classes
    StreamOps
    Annotations
    @deprecated
    Deprecated

    (Since version 0.9) renamed to noneTerminate

Inherited from StreamOps[F, O]

Inherited from StreamPipe2Ops[F, O]

Inherited from StreamPipeOps[F, O]

Inherited from AnyRef

Inherited from Any

Inherited by implicit conversion covaryPure from Stream[F, O] to Stream[Nothing, O]

Inherited by implicit conversion StreamPureOps from Stream[F, O] to Stream.StreamPureOps[O]

Inherited by implicit conversion any2stringadd from Stream[F, O] to any2stringadd[Stream[F, O]]

Inherited by implicit conversion StringFormat from Stream[F, O] to StringFormat[Stream[F, O]]

Inherited by implicit conversion Ensuring from Stream[F, O] to Ensuring[Stream[F, O]]

Inherited by implicit conversion ArrowAssoc from Stream[F, O] to ArrowAssoc[Stream[F, O]]

Ungrouped