Class/Object

fs2

Stream

Related Docs: object Stream | package fs2

Permalink

final class Stream[+F[_], +O] extends AnyRef

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

Laws (using infix syntax):

append forms a monoid in conjunction with empty:

And push is consistent with using append to prepend a single chunk: -push(c)(s) == chunk(c) append s

fail propagates until being caught by onError:

Stream forms a monad with emit and flatMap:

The monad is the list-style sequencing monad:

Self Type
Stream[F, O]
Source
Stream.scala
Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Stream
  2. AnyRef
  3. 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

Value Members

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

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. def +(other: String): String

    Permalink
    Implicit information
    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[_], O2 >: O](s2: ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[F, G, Lub]): Stream[Lub, O2]

    Permalink
  5. def ->[B](y: B): (Stream[F, O], B)

    Permalink
    Implicit information
    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) and at the same time O is a subclass of Option[Nothing] (O <: Option[Nothing]).
    Definition Classes
    ArrowAssoc
    Annotations
    @inline()
  6. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  7. def append[G[_], Lub[_], O2 >: O](s2: ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[F, G, Lub]): Stream[Lub, O2]

    Permalink
  8. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  9. def attempt: Stream[F, Attempt[O]]

    Permalink
  10. def buffer(n: Int): Stream[F, O]

    Permalink

    Alias for self through pipe.buffer.

  11. def bufferAll: Stream[F, O]

    Permalink

    Alias for self through pipe.bufferAll.

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

    Permalink

    Alias for self through pipe.bufferBy.

  13. def chunkLimit(n: Int): Stream[F, NonEmptyChunk[O]]

    Permalink

    Alias for self through pipe.chunkLimit.

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

    Permalink

    Alias for self through pipe.chunkN.

  15. def chunks: Stream[F, NonEmptyChunk[O]]

    Permalink

    Alias for self through pipe.chunks.

  16. def clone(): AnyRef

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

    Permalink

    Alias for self through pipe.collect.

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

    Permalink

    Alias for self through pipe.collectFirst.

  19. def cons[O2 >: O](c: Chunk[O2])(implicit T: RealSupertype[O, O2]): Stream[F, O2]

    Permalink

    Prepend a single chunk onto the front of this stream.

  20. def cons1[O2 >: O](a: O2)(implicit T: RealSupertype[O, O2]): Stream[F, O2]

    Permalink

    Prepend a single value onto the front of this stream.

  21. def covary[F2[_]](implicit S: Sub1[F, F2]): Stream[F2, O]

    Permalink
  22. def delete(f: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.delete.

  23. def distinctConsecutive: Stream[F, O]

    Permalink

    Alias for self through pipe.distinctConsecutive.

  24. def distinctConsecutiveBy[O2](f: (O) ⇒ O2): Stream[F, O]

    Permalink

    Alias for self through pipe.distinctConsecutiveBy.

  25. def drain: Stream[F, Nothing]

    Permalink
  26. def drop(n: Int): Stream[F, O]

    Permalink

    Alias for self through pipe.drop.

  27. def dropLast: Stream[F, O]

    Permalink

    Alias for self through pipe.dropLast.

  28. def dropLastIf(p: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.dropLastIf.

  29. def dropRight(n: Int): Stream[F, O]

    Permalink

    Alias for self through pipe.dropRight.

  30. def dropWhile(p: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.dropWhile

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

    Permalink

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

  32. def ensuring(cond: (Stream[F, O]) ⇒ Boolean, msg: ⇒ Any): Stream[F, O]

    Permalink
    Implicit information
    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: (Stream[F, O]) ⇒ Boolean): Stream[F, O]

    Permalink
    Implicit information
    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. def ensuring(cond: Boolean, msg: ⇒ Any): Stream[F, O]

    Permalink
    Implicit information
    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
  35. def ensuring(cond: Boolean): Stream[F, O]

    Permalink
    Implicit information
    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
  36. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  38. def evalMap[G[_], Lub[_], O2](f: (O) ⇒ G[O2])(implicit L: Lub1[F, G, Lub]): Stream[Lub, O2]

    Permalink
  39. def exists(f: (O) ⇒ Boolean): Stream[F, Boolean]

    Permalink

    Alias for self through pipe.exists.

  40. def fetchAsync[F2[_], O2 >: O](implicit F2: Async[F2], S: Sub1[F, F2], T: RealSupertype[O, O2]): Stream[F2, ScopedFuture[F2, Stream[F2, O2]]]

    Permalink
  41. def filter(f: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.filter.

  42. def filterWithPrevious(f: (O, O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.filterWithPrevious.

  43. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  44. def find(f: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.find.

  45. def flatMap[G[_], Lub[_], O2](f: (O) ⇒ Stream[G, O2])(implicit L: Lub1[F, G, Lub]): Stream[Lub, O2]

    Permalink
  46. def fold[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, O2]

    Permalink

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

  47. def fold1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Permalink

    Alias for self through pipe.fold1(f).

  48. def forall(f: (O) ⇒ Boolean): Stream[F, Boolean]

    Permalink

    Alias for self through pipe.forall.

  49. def formatted(fmtstr: String): String

    Permalink
    Implicit information
    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()
  50. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  51. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  52. def interleave[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]

    Permalink
  53. def interleaveAll[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]

    Permalink
  54. def interruptWhen[F2[_]](haltWhenTrue: Signal[F2, Boolean])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]

    Permalink

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

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

    Permalink

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

  56. def intersperse[O2 >: O](separator: O2): Stream[F, O2]

    Permalink

    Alias for self through pipe.intersperse.

  57. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  58. def last: Stream[F, Option[O]]

    Permalink

    Alias for self through pipe.last.

  59. def lastOr[O2 >: O](li: ⇒ O2): Stream[F, O2]

    Permalink

    Alias for self through pipe.lastOr.

  60. def map[O2](f: (O) ⇒ O2): Stream[F, O2]

    Permalink
  61. def mapAccumulate[S, O2](init: S)(f: (S, O) ⇒ (S, O2)): Stream[F, (S, O2)]

    Permalink

    Alias for self through pipe.mapAccumulate

  62. def mapChunks[O2](f: (Chunk[O]) ⇒ Chunk[O2]): Stream[F, O2]

    Permalink
  63. def mask: Stream[F, O]

    Permalink
  64. def merge[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
  65. def mergeDrainL[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
  66. def mergeDrainR[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]

    Permalink
  67. def mergeHaltBoth[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
  68. def mergeHaltL[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
  69. def mergeHaltR[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
  70. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  71. def noneTerminate: Stream[F, Option[O]]

    Permalink
  72. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  73. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  74. def observe[F2[_], O2 >: O](sink: Sink[F2, O2])(implicit F: Async[F2], R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]

    Permalink
  75. def observeAsync[F2[_], O2 >: O](sink: Sink[F2, O2], maxQueued: Int)(implicit F: Async[F2], R: RealSupertype[O, O2], S: Sub1[F, F2]): Stream[F2, O2]

    Permalink
  76. def onError[G[_], Lub[_], O2 >: O](f: (Throwable) ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[F, G, Lub]): Stream[Lub, O2]

    Permalink
  77. def onFinalize[F2[_]](f: F2[Unit])(implicit S: Sub1[F, F2], F2: Monad[F2]): Stream[F2, O]

    Permalink
  78. def open: Pull[F, Nothing, Handle[F, O]]

    Permalink
  79. def output: Pull[F, O, Unit]

    Permalink
  80. def prefetch[F2[_]](implicit S: Sub1[F, F2], F2: Async[F2]): Stream[F2, O]

    Permalink

    Alias for self through pipe.prefetch(f).

  81. def pull[F2[_], O2](using: (Handle[F, O]) ⇒ Pull[F2, O2, Any])(implicit S: Sub1[F, F2]): Stream[F2, O2]

    Permalink
  82. def pure(implicit S: Sub1[F, Pure]): Stream[Pure, O]

    Permalink

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

  83. def rechunkN(n: Int, allowFewer: Boolean = true): Stream[F, O]

    Permalink

    Alias for self through pipe.rechunkN(f).

  84. def reduce[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Permalink

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

  85. def repeat: Stream[F, O]

    Permalink

    Repeat this stream an infinite number of times.

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

  86. def runFoldFree[O2](z: O2)(f: (O2, O) ⇒ O2): Free[F, O2]

    Permalink
  87. def runFoldTraceFree[O2](t: Trace)(z: O2)(f: (O2, O) ⇒ O2): Free[F, O2]

    Permalink
  88. def runFree: Free[F, Unit]

    Permalink
  89. def runLogFree: Free[F, Vector[O]]

    Permalink
  90. def runTraceFree(t: Trace): Free[F, Unit]

    Permalink
  91. def scan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, O2]

    Permalink

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

  92. def scan1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[F, O2]

    Permalink

    Alias for self through pipe.scan1(f).

  93. def scope: Stream[F, O]

    Permalink
  94. def shiftRight[O2 >: O](head: O2*): Stream[F, O2]

    Permalink

    Alias for self through pipe.shiftRight.

  95. def sliding(n: Int): Stream[F, Vector[O]]

    Permalink

    Alias for self through pipe.sliding.

  96. def split(f: (O) ⇒ Boolean): Stream[F, Vector[O]]

    Permalink

    Alias for self through pipe.split.

  97. def step: Pull[F, Nothing, (NonEmptyChunk[O], Handle[F, O])]

    Permalink
  98. def stepAsync[F2[_], O2 >: O](implicit S: Sub1[F, F2], F2: Async[F2], T: RealSupertype[O, O2]): Pull[F2, Nothing, ScopedFuture[F2, Pull[F2, Nothing, (NonEmptyChunk[O2], Handle[F2, O2])]]]

    Permalink
  99. def sum[O2 >: O](implicit arg0: Numeric[O2]): Stream[F, O2]

    Permalink

    Alias for self through pipe.sum(f).

  100. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  101. def tail: Stream[F, O]

    Permalink

    Alias for self through pipe.tail.

  102. def take(n: Long): Stream[F, O]

    Permalink

    Alias for self through pipe.take(n).

  103. def takeRight(n: Long): Stream[F, O]

    Permalink

    Alias for self through pipe.takeRight.

  104. def takeThrough(p: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.takeThrough.

  105. def takeWhile(p: (O) ⇒ Boolean): Stream[F, O]

    Permalink

    Alias for self through pipe.takeWhile.

  106. def through2v[F2[_], O2, O3](s2: Stream[F2, O2])(f: Pipe2[F2, O, O2, O3])(implicit S: Sub1[F, F2]): Stream[F2, O3]

    Permalink

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

  107. def throughv[F2[_], O2](f: Pipe[F2, O, O2])(implicit S: Sub1[F, F2]): Stream[F2, O2]

    Permalink

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

  108. def toList: List[O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to StreamPureOps[O] performed by method StreamPureOps in fs2.Stream. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    StreamPureOps
  109. def toString(): String

    Permalink
    Definition Classes
    Stream → AnyRef → Any
  110. def toVector: Vector[O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to StreamPureOps[O] performed by method StreamPureOps in fs2.Stream. This conversion will take place only if F is a subclass of Pure (F <: Pure).
    Definition Classes
    StreamPureOps
  111. def tov[F2[_]](f: Sink[F2, O])(implicit S: Sub1[F, F2]): Stream[F2, Unit]

    Permalink

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

  112. def translate[G[_]](u: ~>[F, G]): Stream[G, O]

    Permalink
  113. def unchunk: Stream[F, O]

    Permalink

    Alias for self through pipe.unchunk.

  114. def uncons: Stream[F, Option[(NonEmptyChunk[O], Stream[F, O])]]

    Permalink
  115. def uncons1: Stream[F, Option[(O, Stream[F, O])]]

    Permalink
  116. def vectorChunkN(n: Int, allowFewer: Boolean = true): Stream[F, Vector[O]]

    Permalink

    Alias for self through pipe.vectorChunkN.

  117. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  120. def zip[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[F, F2]): Stream[F2, (O, O2)]

    Permalink
  121. def zipWith[F2[_], O2, O3](s2: Stream[F2, O2])(f: (O, O2) ⇒ O3)(implicit S: Sub1[F, F2]): Stream[F2, O3]

    Permalink
  122. def zipWithIndex: Stream[F, (O, Int)]

    Permalink

    Alias for self through pipe.zipWithIndex.

  123. def zipWithNext: Stream[F, (O, Option[O])]

    Permalink

    Alias for self through pipe.zipWithNext.

  124. def zipWithPrevious: Stream[F, (Option[O], O)]

    Permalink

    Alias for self through pipe.zipWithPrevious.

  125. def zipWithPreviousAndNext: Stream[F, (Option[O], O, Option[O])]

    Permalink

    Alias for self through pipe.zipWithPreviousAndNext.

  126. def zipWithScan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, (O, O2)]

    Permalink

    Alias for self through pipe.zipWithScan.

  127. def zipWithScan1[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[F, (O, O2)]

    Permalink

    Alias for self through pipe.zipWithScan1.

  128. def [B](y: B): (Stream[F, O], B)

    Permalink
    Implicit information
    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) and at the same time O is a subclass of Option[Nothing] (O <: Option[Nothing]).
    Definition Classes
    ArrowAssoc

Shadowed Implicit Value Members

  1. def ++[G[_], Lub[_], O2 >: O](s2: ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[Nothing, G, Lub]): Stream[Lub, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).++(s2)(R, L)
  2. def append[G[_], Lub[_], O2 >: O](s2: ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[Nothing, G, Lub]): Stream[Lub, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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(s2)(R, L)
  3. def attempt: Stream[Nothing, Attempt[O]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  4. def buffer(n: Int): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.buffer.

    Alias for self through pipe.buffer.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  5. def bufferAll: Stream[Nothing, O]

    Permalink

    Alias for self through pipe.bufferAll.

    Alias for self through pipe.bufferAll.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  6. def bufferBy(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.bufferBy.

    Alias for self through pipe.bufferBy.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  7. def chunkLimit(n: Int): Stream[Nothing, NonEmptyChunk[O]]

    Permalink

    Alias for self through pipe.chunkLimit.

    Alias for self through pipe.chunkLimit.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  8. def chunkN(n: Int, allowFewer: Boolean = true): Stream[Nothing, List[NonEmptyChunk[O]]]

    Permalink

    Alias for self through pipe.chunkN.

    Alias for self through pipe.chunkN.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  9. def chunks: Stream[Nothing, NonEmptyChunk[O]]

    Permalink

    Alias for self through pipe.chunks.

    Alias for self through pipe.chunks.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  10. def collect[O2](pf: PartialFunction[O, O2]): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.collect.

    Alias for self through pipe.collect.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  11. def collectFirst[O2](pf: PartialFunction[O, O2]): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.collectFirst.

    Alias for self through pipe.collectFirst.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  12. def cons[O2 >: O](c: Chunk[O2])(implicit T: RealSupertype[O, O2]): Stream[Nothing, O2]

    Permalink

    Prepend a single chunk onto the front of this stream.

    Prepend a single chunk onto the front of this stream.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  13. def cons1[O2 >: O](a: O2)(implicit T: RealSupertype[O, O2]): Stream[Nothing, O2]

    Permalink

    Prepend a single value onto the front of this stream.

    Prepend a single value onto the front of this stream.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  14. def covary[F2[_]](implicit S: Sub1[Nothing, F2]): Stream[F2, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  15. def delete(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.delete.

    Alias for self through pipe.delete.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  16. def distinctConsecutive: Stream[Nothing, O]

    Permalink

    Alias for self through pipe.distinctConsecutive.

    Alias for self through pipe.distinctConsecutive.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).distinctConsecutive
  17. def distinctConsecutiveBy[O2](f: (O) ⇒ O2): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.distinctConsecutiveBy.

    Alias for self through pipe.distinctConsecutiveBy.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).distinctConsecutiveBy(f)
  18. def drain: Stream[Nothing, Nothing]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  19. def drop(n: Int): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.drop.

    Alias for self through pipe.drop.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  20. def dropLast: Stream[Nothing, O]

    Permalink

    Alias for self through pipe.dropLast.

    Alias for self through pipe.dropLast.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  21. def dropLastIf(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.dropLastIf.

    Alias for self through pipe.dropLastIf.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  22. def dropRight(n: Int): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.dropRight.

    Alias for self through pipe.dropRight.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  23. def dropWhile(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.dropWhile

    Alias for self through pipe.dropWhile

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  24. def either[F2[_], O2](s2: Stream[F2, O2])(implicit arg0: Async[F2], S: Sub1[Nothing, F2]): Stream[F2, Either[O, O2]]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  25. def evalMap[G[_], Lub[_], O2](f: (O) ⇒ G[O2])(implicit L: Lub1[Nothing, G, Lub]): Stream[Lub, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  26. def exists(f: (O) ⇒ Boolean): Stream[Nothing, Boolean]

    Permalink

    Alias for self through pipe.exists.

    Alias for self through pipe.exists.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  27. def fetchAsync[F2[_], O2 >: O](implicit F2: Async[F2], S: Sub1[Nothing, F2], T: RealSupertype[O, O2]): Stream[F2, ScopedFuture[F2, Stream[F2, O2]]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  28. def filter(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.filter.

    Alias for self through pipe.filter.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  29. def filterWithPrevious(f: (O, O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.filterWithPrevious.

    Alias for self through pipe.filterWithPrevious.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).filterWithPrevious(f)
  30. def find(f: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.find.

    Alias for self through pipe.find.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  31. def flatMap[G[_], Lub[_], O2](f: (O) ⇒ Stream[G, O2])(implicit L: Lub1[Nothing, G, Lub]): Stream[Lub, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  32. def fold[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, O2]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  33. def fold1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.fold1(f).

    Alias for self through pipe.fold1(f).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  34. def forall(f: (O) ⇒ Boolean): Stream[Nothing, Boolean]

    Permalink

    Alias for self through pipe.forall.

    Alias for self through pipe.forall.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  35. def interleave[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  36. def interleaveAll[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  37. def interruptWhen[F2[_]](haltWhenTrue: Signal[F2, Boolean])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  38. def interruptWhen[F2[_]](haltWhenTrue: Stream[F2, Boolean])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  39. def intersperse[O2 >: O](separator: O2): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.intersperse.

    Alias for self through pipe.intersperse.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  40. def last: Stream[Nothing, Option[O]]

    Permalink

    Alias for self through pipe.last.

    Alias for self through pipe.last.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  41. def lastOr[O2 >: O](li: ⇒ O2): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.lastOr.

    Alias for self through pipe.lastOr.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  42. def map[O2](f: (O) ⇒ O2): Stream[Nothing, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  43. def mapAccumulate[S, O2](init: S)(f: (S, O) ⇒ (S, O2)): Stream[Nothing, (S, O2)]

    Permalink

    Alias for self through pipe.mapAccumulate

    Alias for self through pipe.mapAccumulate

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  44. def mapChunks[O2](f: (Chunk[O]) ⇒ Chunk[O2]): Stream[Nothing, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  45. def mask: Stream[Nothing, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  46. def merge[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  47. def mergeDrainL[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  48. def mergeDrainR[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  49. def mergeHaltBoth[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  50. def mergeHaltL[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  51. def mergeHaltR[F2[_], O2 >: O](s2: Stream[F2, O2])(implicit R: RealSupertype[O, O2], S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  52. def noneTerminate: Stream[Nothing, Option[O]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  53. def observe[F2[_], O2 >: O](sink: Sink[F2, O2])(implicit F: Async[F2], R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).observe(sink)(F, R, S)
  54. def observeAsync[F2[_], O2 >: O](sink: Sink[F2, O2], maxQueued: Int)(implicit F: Async[F2], R: RealSupertype[O, O2], S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).observeAsync(sink, maxQueued)(F, R, S)
  55. def onError[G[_], Lub[_], O2 >: O](f: (Throwable) ⇒ Stream[G, O2])(implicit R: RealSupertype[O, O2], L: Lub1[Nothing, G, Lub]): Stream[Lub, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  56. def onFinalize[F2[_]](f: F2[Unit])(implicit S: Sub1[Nothing, F2], F2: Monad[F2]): Stream[F2, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  57. def open: Pull[Nothing, Nothing, Handle[Nothing, O]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  58. def output: Pull[Nothing, O, Unit]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  59. def prefetch[F2[_]](implicit S: Sub1[Nothing, F2], F2: Async[F2]): Stream[F2, O]

    Permalink

    Alias for self through pipe.prefetch(f).

    Alias for self through pipe.prefetch(f).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).prefetch(S, F2)
  60. def pull[F2[_], O2](using: (Handle[Nothing, O]) ⇒ Pull[F2, O2, Any])(implicit S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).pull(using)(S)
  61. def pure(implicit S: Sub1[Nothing, Pure]): Stream[Pure, O]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  62. def rechunkN(n: Int, allowFewer: Boolean = true): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.rechunkN(f).

    Alias for self through pipe.rechunkN(f).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).rechunkN(n, allowFewer)
  63. def reduce[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  64. def repeat: Stream[Nothing, O]

    Permalink

    Repeat this stream an infinite number of times.

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  65. def runFoldFree[O2](z: O2)(f: (O2, O) ⇒ O2): Free[Nothing, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  66. def runFoldTraceFree[O2](t: Trace)(z: O2)(f: (O2, O) ⇒ O2): Free[Nothing, O2]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  67. def runFree: Free[Nothing, Unit]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  68. def runLogFree: Free[Nothing, Vector[O]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  69. def runTraceFree(t: Trace): Free[Nothing, Unit]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  70. def scan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, O2]

    Permalink

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

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

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  71. def scan1[O2 >: O](f: (O2, O2) ⇒ O2): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.scan1(f).

    Alias for self through pipe.scan1(f).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  72. def scope: Stream[Nothing, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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]).scope
  73. def shiftRight[O2 >: O](head: O2*): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.shiftRight.

    Alias for self through pipe.shiftRight.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  74. def sliding(n: Int): Stream[Nothing, Vector[O]]

    Permalink

    Alias for self through pipe.sliding.

    Alias for self through pipe.sliding.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  75. def split(f: (O) ⇒ Boolean): Stream[Nothing, Vector[O]]

    Permalink

    Alias for self through pipe.split.

    Alias for self through pipe.split.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  76. def step: Pull[Nothing, Nothing, (NonEmptyChunk[O], Handle[Nothing, O])]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  77. def stepAsync[F2[_], O2 >: O](implicit S: Sub1[Nothing, F2], F2: Async[F2], T: RealSupertype[O, O2]): Pull[F2, Nothing, ScopedFuture[F2, Pull[F2, Nothing, (NonEmptyChunk[O2], Handle[F2, O2])]]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  78. def sum[O2 >: O](implicit arg0: Numeric[O2]): Stream[Nothing, O2]

    Permalink

    Alias for self through pipe.sum(f).

    Alias for self through pipe.sum(f).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  79. def tail: Stream[Nothing, O]

    Permalink

    Alias for self through pipe.tail.

    Alias for self through pipe.tail.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  80. def take(n: Long): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.take(n).

    Alias for self through pipe.take(n).

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  81. def takeRight(n: Long): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.takeRight.

    Alias for self through pipe.takeRight.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  82. def takeThrough(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.takeThrough.

    Alias for self through pipe.takeThrough.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  83. def takeWhile(p: (O) ⇒ Boolean): Stream[Nothing, O]

    Permalink

    Alias for self through pipe.takeWhile.

    Alias for self through pipe.takeWhile.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  84. def through2v[F2[_], O2, O3](s2: Stream[F2, O2])(f: Pipe2[F2, O, O2, O3])(implicit S: Sub1[Nothing, F2]): Stream[F2, O3]

    Permalink

    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 information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  85. def throughv[F2[_], O2](f: Pipe[F2, O, O2])(implicit S: Sub1[Nothing, F2]): Stream[F2, O2]

    Permalink

    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 information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  86. def toString(): String

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  87. def tov[F2[_]](f: Sink[F2, O])(implicit S: Sub1[Nothing, F2]): Stream[F2, Unit]

    Permalink

    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 information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  88. def translate[G[_]](u: ~>[Nothing, G]): Stream[G, O]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  89. def unchunk: Stream[Nothing, O]

    Permalink

    Alias for self through pipe.unchunk.

    Alias for self through pipe.unchunk.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  90. def uncons: Stream[Nothing, Option[(NonEmptyChunk[O], Stream[Nothing, O])]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  91. def uncons1: Stream[Nothing, Option[(O, Stream[Nothing, O])]]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  92. def vectorChunkN(n: Int, allowFewer: Boolean = true): Stream[Nothing, Vector[O]]

    Permalink

    Alias for self through pipe.vectorChunkN.

    Alias for self through pipe.vectorChunkN.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  93. def zip[F2[_], O2](s2: Stream[F2, O2])(implicit S: Sub1[Nothing, F2]): Stream[F2, (O, O2)]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  94. def zipWith[F2[_], O2, O3](s2: Stream[F2, O2])(f: (O, O2) ⇒ O3)(implicit S: Sub1[Nothing, F2]): Stream[F2, O3]

    Permalink
    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  95. def zipWithIndex: Stream[Nothing, (O, Int)]

    Permalink

    Alias for self through pipe.zipWithIndex.

    Alias for self through pipe.zipWithIndex.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  96. def zipWithNext: Stream[Nothing, (O, Option[O])]

    Permalink

    Alias for self through pipe.zipWithNext.

    Alias for self through pipe.zipWithNext.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  97. def zipWithPrevious: Stream[Nothing, (Option[O], O)]

    Permalink

    Alias for self through pipe.zipWithPrevious.

    Alias for self through pipe.zipWithPrevious.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  98. def zipWithPreviousAndNext: Stream[Nothing, (Option[O], O, Option[O])]

    Permalink

    Alias for self through pipe.zipWithPreviousAndNext.

    Alias for self through pipe.zipWithPreviousAndNext.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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
  99. def zipWithScan[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, (O, O2)]

    Permalink

    Alias for self through pipe.zipWithScan.

    Alias for self through pipe.zipWithScan.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)
  100. def zipWithScan1[O2](z: O2)(f: (O2, O) ⇒ O2): Stream[Nothing, (O, O2)]

    Permalink

    Alias for self through pipe.zipWithScan1.

    Alias for self through pipe.zipWithScan1.

    Implicit information
    This member is added by an implicit conversion from Stream[F, O] to Stream[Nothing, O] performed by method covaryPure in fs2.Stream. 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)

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 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