Stream

object Stream extends StreamLowPriority
Companion
class
trait StreamLowPriority
class Object
trait Matchable
class Any

Type members

Classlikes

final class CompileOps[F[_], G[_], O]

Projection of a Stream providing various ways to compile a Stream[F,O] to a G[...].

Projection of a Stream providing various ways to compile a Stream[F,O] to a G[...].

final class FallibleOps[O](self: Stream[[A] =>> Fallible[A], O]) extends AnyVal

Provides syntax for fallible streams.

Provides syntax for fallible streams.

final class IdOps[O](self: Stream[Id, O]) extends AnyVal

Provides syntax for pure pipes based on cats.Id.

Provides syntax for pure pipes based on cats.Id.

final class InvariantOps[F[_], O](self: Stream[F, O]) extends AnyVal

Provides syntax for streams that are invariant in F and O.

Provides syntax for streams that are invariant in F and O.

final class NestedStreamOps[F[_], O](outer: Stream[F, Stream[F, O]]) extends AnyVal

Provides syntax for streams of streams.

Provides syntax for streams of streams.

final class NothingStreamOps[F[_]](self: Stream[F, Nothing]) extends AnyVal
final class OptionStreamOps[F[_], O](self: Stream[F, Option[O]]) extends AnyVal
final class PipeOps[F[_], I, O](self: (F, I) => O) extends AnyVal

Provides operations on effectful pipes for syntactic convenience.

Provides operations on effectful pipes for syntactic convenience.

final class PureOps[O](self: Stream[Pure, O]) extends AnyVal

Provides syntax for pure streams.

Provides syntax for pure streams.

final class PurePipe2Ops[I, I2, O](self: (Pure, I, I2) => O) extends AnyVal

Provides operations on pure pipes for syntactic convenience.

Provides operations on pure pipes for syntactic convenience.

final class PurePipeOps[I, O](self: (Pure, I) => O) extends AnyVal

Provides operations on pure pipes for syntactic convenience.

Provides operations on pure pipes for syntactic convenience.

final class StepLeg[+F[_], +O](val head: Chunk[O], val scopeId: Token, val next: Pull[F, O, Unit])

When merging multiple streams, this represents step of one leg.

When merging multiple streams, this represents step of one leg.

It is common to uncons, however unlike uncons, it keeps track of stream scope independently of the main scope of the stream.

This assures, that after each next stepLeg each Stream leg keeps its scope when interpreting.

Usual scenarios is to first invoke stream.pull.stepLeg and then consume whatever is available in leg.head. If the next step is required leg.stepLeg will yield next Leg.

Once the stream will stop to be interleaved (merged), then stream allows to return to normal stream invocation.

final class ToPull[F[_], O] extends AnyVal

Projection of a Stream providing various ways to get a Pull from the Stream.

Projection of a Stream providing various ways to get a Pull from the Stream.

Value members

Concrete methods

def apply[F[x], O](os: O*): Stream[F, O]

Creates a pure stream that emits the supplied values. To convert to an effectful stream, use covary.

Creates a pure stream that emits the supplied values. To convert to an effectful stream, use covary.

def attemptEval[F[x], O](fo: F[O]): Stream[F, Either[Throwable, O]]

Creates a single element stream that gets its value by evaluating the supplied effect. If the effect fails, a Left is emitted. Otherwise, a Right is emitted.

Creates a single element stream that gets its value by evaluating the supplied effect. If the effect fails, a Left is emitted. Otherwise, a Right is emitted.

Use eval instead if a failure while evaluating the effect should fail the stream.

Example
scala> import cats.effect.SyncIO
scala> Stream.attemptEval(SyncIO(10)).compile.toVector.unsafeRunSync()
res0: Vector[Either[Throwable,Int]] = Vector(Right(10))
scala> Stream.attemptEval(SyncIO(throw new RuntimeException)).compile.toVector.unsafeRunSync()
res1: Vector[Either[Throwable,Nothing]] = Vector(Left(java.lang.RuntimeException))
def awakeDelay[F[_]](period: FiniteDuration)(t: Temporal[F]): Stream[F, FiniteDuration]

Light weight alternative to awakeEvery that sleeps for duration d before each pulled element.

Light weight alternative to awakeEvery that sleeps for duration d before each pulled element.

def awakeEvery[F[_]](period: FiniteDuration)(`evidence$31`: Temporal[F]): Stream[F, FiniteDuration]

Discrete stream that every d emits elapsed duration since the start time of stream consumption.

Discrete stream that every d emits elapsed duration since the start time of stream consumption.

Missed periods are dampened to a single tick.

For example: awakeEvery[IO](5 seconds) will return (approximately) 5s, 10s, 15s, and will lie dormant between emitted values.

Value Params
period

duration between emits of the resulting stream

def awakeEvery[F[_]](period: FiniteDuration, dampen: Boolean)(t: Temporal[F]): Stream[F, FiniteDuration]

Discrete stream that every d emits elapsed duration since the start time of stream consumption.

Discrete stream that every d emits elapsed duration since the start time of stream consumption.

For example: awakeEvery[IO](5 seconds) will return (approximately) 5s, 10s, 15s, and will lie dormant between emitted values.

Value Params
dampen

whether missed periods result in 1 emitted tick or 1 per missed period, see fixedRate for more info

period

duration between emits of the resulting stream

def bracket[F[x], R](acquire: F[R])(release: R => F[Unit]): Stream[F, R]

Creates a stream that emits a resource allocated by an effect, ensuring the resource is eventually released regardless of how the stream is used.

Creates a stream that emits a resource allocated by an effect, ensuring the resource is eventually released regardless of how the stream is used.

A typical use case for bracket is working with files or network sockets. The resource effect opens a file and returns a reference to it. One can then flatMap on the returned Stream to access the file, e.g to read bytes and transform them in to some stream of elements (e.g., bytes, strings, lines, etc.). The release action then closes the file once the result Stream terminates, even in case of interruption or errors.

Value Params
acquire

resource to acquire at start of stream

release

function which returns an effect that releases the resource

def bracketCase[F[x], R](acquire: F[R])(release: (R, ExitCase) => F[Unit]): Stream[F, R]

Like bracket but the release action is passed an ExitCase[Throwable].

Like bracket but the release action is passed an ExitCase[Throwable].

ExitCase.Canceled is passed to the release action in the event of either stream interruption or overall compiled effect cancelation.

def bracketCaseWeak[F[x], R](acquire: F[R])(release: (R, ExitCase) => F[Unit]): Stream[F, R]

Like bracketCase but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

Like bracketCase but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

def bracketFull[F[x], R](acquire: Poll[F] => F[R])(release: (R, ExitCase) => F[Unit])(F: MonadCancel[F, _]): Stream[F, R]

Like bracketCase but the acquire action may be canceled.

Like bracketCase but the acquire action may be canceled.

def bracketFullWeak[F[x], R](acquire: Poll[F] => F[R])(release: (R, ExitCase) => F[Unit])(F: MonadCancel[F, _]): Stream[F, R]

Like bracketFull but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

Like bracketFull but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

def bracketWeak[F[x], R](acquire: F[R])(release: R => F[Unit]): Stream[F, R]

Like bracket but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

Like bracket but no scope is introduced, causing resource finalization to occur at the end of the current scope at the time of acquisition.

def chunk[F[x], O](os: Chunk[O]): Stream[F, O]

Creates a pure stream that emits the elements of the supplied chunk.

Creates a pure stream that emits the elements of the supplied chunk.

Example
scala> Stream.chunk(Chunk(1,2,3)).toList
res0: List[Int] = List(1, 2, 3)
def constant[F[x], O](o: O, chunkSize: Int): Stream[F, O]

Creates an infinite pure stream that always returns the supplied value.

Creates an infinite pure stream that always returns the supplied value.

Elements are emitted in finite chunks with chunkSize number of elements.

Example
scala> Stream.constant(0).take(5).toList
res0: List[Int] = List(0, 0, 0, 0, 0)
def duration[F[_]](F: Clock[F]): Stream[F, FiniteDuration]

A continuous stream of the elapsed time, computed using System.nanoTime. Note that the actual granularity of these elapsed times depends on the OS, for instance the OS may only update the current time every ten milliseconds or so.

A continuous stream of the elapsed time, computed using System.nanoTime. Note that the actual granularity of these elapsed times depends on the OS, for instance the OS may only update the current time every ten milliseconds or so.

def emit[F[x], O](o: O): Stream[F, O]

Creates a singleton pure stream that emits the supplied value.

Creates a singleton pure stream that emits the supplied value.

Example
scala> Stream.emit(0).toList
res0: List[Int] = List(0)
def emits[F[x], O](os: Seq[O]): Stream[F, O]

Creates a pure stream that emits the supplied values.

Creates a pure stream that emits the supplied values.

Example
scala> Stream.emits(List(1, 2, 3)).toList
res0: List[Int] = List(1, 2, 3)
def eval[F[_], O](fo: F[O]): Stream[F, O]

Creates a single element stream that gets its value by evaluating the supplied effect. If the effect fails, the returned stream fails.

Creates a single element stream that gets its value by evaluating the supplied effect. If the effect fails, the returned stream fails.

Use attemptEval instead if a failure while evaluating the effect should be emitted as a value.

Example
scala> import cats.effect.SyncIO
scala> Stream.eval(SyncIO(10)).compile.toVector.unsafeRunSync()
res0: Vector[Int] = Vector(10)
scala> Stream.eval(SyncIO(throw new RuntimeException)).covaryOutput[Int].compile.toVector.attempt.unsafeRunSync()
res1: Either[Throwable,Vector[Int]] = Left(java.lang.RuntimeException)
def evalSeq[F[_], S <: ([A] =>> Seq[A]), O](fo: F[S[O]]): Stream[F, O]

Like evals, but lifts any Seq in the effect.

Like evals, but lifts any Seq in the effect.

def evalUnChunk[F[_], O](fo: F[Chunk[O]]): Stream[F, O]

Like eval but resulting chunk is flatten efficiently.

Like eval but resulting chunk is flatten efficiently.

def evals[F[_], S[_], O](fo: F[S[O]])(`evidence$32`: Foldable[S]): Stream[F, O]

Like eval, but lifts a foldable structure.

Like eval, but lifts a foldable structure.

def every[F[_]](d: FiniteDuration)(clock: Clock[F], F: Functor[F]): Stream[F, Boolean]

A continuous stream which is true after d, 2d, 3d... elapsed duration, and false otherwise. If you'd like a 'discrete' stream that will actually block until d has elapsed, use awakeEvery instead.

A continuous stream which is true after d, 2d, 3d... elapsed duration, and false otherwise. If you'd like a 'discrete' stream that will actually block until d has elapsed, use awakeEvery instead.

def exec[F[_]](action: F[Unit]): Stream[F, INothing]

As a result, the returned stream emits no elements and hence has output type INothing.

As a result, the returned stream emits no elements and hence has output type INothing.

Example
scala> import cats.effect.SyncIO
scala> Stream.exec(SyncIO(println("Ran"))).covaryOutput[Int].compile.toVector.unsafeRunSync()
res0: Vector[Int] = Vector()
def fixedDelay[F[_]](period: FiniteDuration)(t: Temporal[F]): Stream[F, Unit]

Light weight alternative to fixedRate that sleeps for duration d before each pulled element.

Light weight alternative to fixedRate that sleeps for duration d before each pulled element.

Behavior differs from fixedRate because the sleep between elements occurs after the next element is pulled whereas fixedRate accounts for the time it takes to process the emitted unit. This difference can roughly be thought of as the difference between scheduleWithFixedDelay and scheduleAtFixedRate in java.util.concurrent.Scheduler.

Alias for sleep(period).repeat.

def fixedRate[F[_]](period: FiniteDuration)(t: Temporal[F]): Stream[F, Unit]

Discrete stream that emits a unit every d, with missed period ticks dampened.

Discrete stream that emits a unit every d, with missed period ticks dampened.

See fixedDelay for an alternative that sleeps d between elements.

Value Params
period

duration between emits of the resulting stream

def fixedRate[F[_]](period: FiniteDuration, dampen: Boolean)(F: Temporal[F]): Stream[F, Unit]

Discrete stream that emits a unit every d.

Discrete stream that emits a unit every d.

See fixedDelay for an alternative that sleeps d between elements.

This operation differs in that the time between ticks should roughly be equal to the specified period, regardless of how much time it takes to process that tick downstream. For example, with a 1 second period and a task that takes 100ms, the task would run at timestamps, 1s, 2s, 3s, etc. when using fixedRate >> task whereas it would run at timestamps 1s, 2.1s, 3.2s, etc. when using fixedDelay >> task.

In the case where task processing takes longer than a single period, 1 or more ticks are immediately emitted to "catch-up". The dampen parameter controls whether a single tick is emitted or whether one per missed period is emitted.

Value Params
dampen

true if a single unit should be emitted when multiple periods have passed since last execution, false if a unit for each period should be emitted

period

period between emits of the resulting stream

def foldable[F[x], G[_], O](os: G[O])(`evidence$37`: Foldable[G]): Stream[F, O]

Like emits, but works for any G that has a Foldable instance.

Like emits, but works for any G that has a Foldable instance.

def force[F[_], A](f: F[Stream[F, A]]): Stream[F, A]

Lifts an effect that generates a stream in to a stream. Alias for eval(f).flatMap(_).

Lifts an effect that generates a stream in to a stream. Alias for eval(f).flatMap(_).

Example
scala> import cats.effect.SyncIO
scala> Stream.force(SyncIO(Stream(1,2,3).covary[SyncIO])).compile.toVector.unsafeRunSync()
res0: Vector[Int] = Vector(1, 2, 3)
def fromBlockingIterator[F[_]]: PartiallyAppliedFromIterator[F]

Lifts an iterator into a Stream, shifting any interaction with the iterator to the blocking pool.

Lifts an iterator into a Stream, shifting any interaction with the iterator to the blocking pool.

def fromEither[F[_]]: PartiallyAppliedFromEither[F]

Lifts an Either[Throwable, A] to an effectful Stream.

Lifts an Either[Throwable, A] to an effectful Stream.

Example
scala> import cats.effect.SyncIO, scala.util.Try
scala> Stream.fromEither[SyncIO](Right(42)).compile.toList.unsafeRunSync()
res0: List[Int] = List(42)
scala> Try(Stream.fromEither[SyncIO](Left(new RuntimeException)).compile.toList.unsafeRunSync())
res1: Try[List[Nothing]] = Failure(java.lang.RuntimeException)
def fromIterator[F[_]]: PartiallyAppliedFromIterator[F]

Lifts an iterator into a Stream.

Lifts an iterator into a Stream.

def fromOption[F[_]]: PartiallyAppliedFromOption[F]

Lifts an Option[A] to an effectful Stream.

Lifts an Option[A] to an effectful Stream.

Example
scala> import cats.effect.SyncIO
scala> Stream.fromOption[SyncIO](Some(42)).compile.toList.unsafeRunSync()
res0: List[Int] = List(42)
scala> Stream.fromOption[SyncIO](None).compile.toList.unsafeRunSync()
res1: List[Nothing] = List()
def fromQueueNoneTerminated[F[_], A](queue: Queue[F, Option[A]], limit: Int)(`evidence$36`: Functor[F]): Stream[F, A]

Returns a stream of elements from the supplied queue.

Returns a stream of elements from the supplied queue.

The stream terminates upon dequeuing a None.

All elements that are available, up to the specified limit, are dequeued and emitted as a single chunk.

def fromQueueNoneTerminatedChunk[F[_], A](queue: Queue[F, Option[Chunk[A]]], limit: Int): Stream[F, A]

Returns a stream of elements from the supplied queue.

Returns a stream of elements from the supplied queue.

The stream terminates upon dequeuing a None.

All elements that are available, up to the specified limit, are dequeued and emitted as a single chunk.

def fromQueueUnterminated[F[_], A](queue: Queue[F, A], limit: Int)(`evidence$34`: Functor[F]): Stream[F, A]

Returns a stream of elements from the supplied queue.

Returns a stream of elements from the supplied queue.

All elements that are available, up to the specified limit, are dequeued and emitted as a single chunk.

def fromQueueUnterminatedChunk[F[_], A](queue: Queue[F, Chunk[A]], limit: Int)(`evidence$35`: Functor[F]): Stream[F, A]

Returns a stream of elements from the supplied queue.

Returns a stream of elements from the supplied queue.

All elements that are available, up to the specified limit, are dequeued and emitted as a single chunk.

def iterable[F[x], A](os: Iterable[A]): Stream[F, A]

Like emits, but works for any class that extends Iterable

Like emits, but works for any class that extends Iterable

def iterate[F[x], A](start: A)(f: A => A): Stream[F, A]

An infinite Stream that repeatedly applies a given function to a start value. start is the first value emitted, followed by f(start), then f(f(start)), and so on.

An infinite Stream that repeatedly applies a given function to a start value. start is the first value emitted, followed by f(start), then f(f(start)), and so on.

Example
scala> Stream.iterate(0)(_ + 1).take(10).toList
res0: List[Int] = List(0, 1, 2, 3, 4, 5, 6, 7, 8, 9)
def iterateEval[F[_], A](start: A)(f: A => F[A]): Stream[F, A]

Like iterate, but takes an effectful function for producing the next state. start is the first value emitted.

Like iterate, but takes an effectful function for producing the next state. start is the first value emitted.

Example
scala> import cats.effect.SyncIO
scala> Stream.iterateEval(0)(i => SyncIO(i + 1)).take(10).compile.toVector.unsafeRunSync()
res0: Vector[Int] = Vector(0, 1, 2, 3, 4, 5, 6, 7, 8, 9)
def never[F[_]](F: Spawn[F]): Stream[F, Nothing]

A stream that never emits and never terminates.

A stream that never emits and never terminates.

def raiseError[F[_]](e: Throwable)(`evidence$38`: RaiseThrowable[F]): Stream[F, INothing]

Creates a stream that, when run, fails with the supplied exception.

Creates a stream that, when run, fails with the supplied exception.

The F type must be explicitly provided (e.g., via raiseError[IO] or raiseError[Fallible]).

Example
scala> import cats.effect.SyncIO
scala> Stream.raiseError[Fallible](new RuntimeException).toList
res0: Either[Throwable,List[INothing]] = Left(java.lang.RuntimeException)
scala> Stream.raiseError[SyncIO](new RuntimeException).covaryOutput[Int].compile.drain.attempt.unsafeRunSync()
res0: Either[Throwable,Unit] = Left(java.lang.RuntimeException)
def range[F[x], O](start: O, stopExclusive: O)(`evidence$39`: Numeric[O]): Stream[F, O]

Lazily produces the sequence [start, start + 1, start + 2, ..., stopExclusive). If you want to produce the sequence in one chunk, instead of lazily, use emits(start until stopExclusive).

Lazily produces the sequence [start, start + 1, start + 2, ..., stopExclusive). If you want to produce the sequence in one chunk, instead of lazily, use emits(start until stopExclusive).

Example
scala> Stream.range(10, 20).toList
res0: List[Int] = List(10, 11, 12, 13, 14, 15, 16, 17, 18, 19)
def range[F[x], O](start: O, stopExclusive: O, step: O)(`evidence$40`: Numeric[O]): Stream[F, O]

Lazily produce the sequence [start, start + step, start + 2 * step, ..., stopExclusive). If you want to produce the sequence in one chunk, instead of lazily, use emits(start until stopExclusive by step).

Lazily produce the sequence [start, start + step, start + 2 * step, ..., stopExclusive). If you want to produce the sequence in one chunk, instead of lazily, use emits(start until stopExclusive by step).

Example
scala> Stream.range(10, 20, 2).toList
res0: List[Int] = List(10, 12, 14, 16, 18)
def ranges[F[x]](start: Int, stopExclusive: Int, size: Int): Stream[F, (Int, Int)]

Lazily produce a sequence of nonoverlapping ranges, where each range contains size integers, assuming the upper bound is exclusive. Example: ranges(0, 1000, 10) results in the pairs (0, 10), (10, 20), (20, 30) ... (990, 1000)

Lazily produce a sequence of nonoverlapping ranges, where each range contains size integers, assuming the upper bound is exclusive. Example: ranges(0, 1000, 10) results in the pairs (0, 10), (10, 20), (20, 30) ... (990, 1000)

Note: The last emitted range may be truncated at stopExclusive. For instance, ranges(0,5,4) results in (0,4), (4,5).

Throws
IllegalArgumentException

if size <= 0

Example
scala> Stream.ranges(0, 20, 5).toList
res0: List[(Int,Int)] = List((0,5), (5,10), (10,15), (15,20))
def repeatEval[F[_], O](fo: F[O]): Stream[F, O]

Alias for eval(fo).repeat.

Alias for eval(fo).repeat.

def resource[F[_], O](r: Resource[F, O])(F: MonadCancel[F, _]): Stream[F, O]

Converts the supplied resource in to a singleton stream.

Converts the supplied resource in to a singleton stream.

def resourceWeak[F[_], O](r: Resource[F, O])(F: MonadCancel[F, _]): Stream[F, O]

Like resource but does not introduce a scope, allowing finalization to occur after subsequent appends or other scope-preserving transformations.

Like resource but does not introduce a scope, allowing finalization to occur after subsequent appends or other scope-preserving transformations.

Scopes can be manually introduced via scope if desired.

def retry[F[_], O](fo: F[O], delay: FiniteDuration, nextDelay: FiniteDuration => FiniteDuration, maxAttempts: Int, retriable: Throwable => Boolean)(`evidence$41`: Temporal[F], `evidence$42`: RaiseThrowable[F]): Stream[F, O]

Retries fo on failure, returning a singleton stream with the result of fo as soon as it succeeds.

Retries fo on failure, returning a singleton stream with the result of fo as soon as it succeeds.

Value Params
delay

Duration of delay before the first retry

maxAttempts

Number of attempts before failing with the latest error, if fo never succeeds

nextDelay

Applied to the previous delay to compute the next, e.g. to implement exponential backoff

retriable

Function to determine whether a failure is retriable or not, defaults to retry every NonFatal. A failed stream is immediately returned when a non-retriable failure is encountered

def sleep[F[_]](d: FiniteDuration)(t: Temporal[F]): Stream[F, Unit]

A single-element Stream that waits for the duration d before emitting unit.

A single-element Stream that waits for the duration d before emitting unit.

def sleep_[F[_]](d: FiniteDuration)(t: Temporal[F]): Stream[F, INothing]

Alias for sleep(d).drain. Often used in conjunction with ++ (i.e., sleep_(..) ++ s) as a more performant version of sleep(..) >> s.

Alias for sleep(d).drain. Often used in conjunction with ++ (i.e., sleep_(..) ++ s) as a more performant version of sleep(..) >> s.

def supervise[F[_], A](fa: F[A])(F: Spawn[F]): Stream[F, Fiber[F, Throwable, A]]

Starts the supplied task and cancels it as finalization of the returned stream.

Starts the supplied task and cancels it as finalization of the returned stream.

def suspend[F[_], O](s: => Stream[F, O]): Stream[F, O]

Returns a stream that evaluates the supplied by-name each time the stream is used, allowing use of a mutable value in stream computations.

Returns a stream that evaluates the supplied by-name each time the stream is used, allowing use of a mutable value in stream computations.

Note: it's generally easier to reason about such computations using effectful values. That is, allocate the mutable value in an effect and then use Stream.eval(fa).flatMap { a => ??? }.

Example
scala> Stream.suspend {
    |   val digest = java.security.MessageDigest.getInstance("SHA-256")
    |   val bytes: Stream[Pure,Byte] = ???
    |   bytes.chunks.fold(digest) { (d,c) => d.update(c.toBytes.values); d }
    | }
def unfold[F[x], S, O](s: S)(f: S => Option[(O, S)]): Stream[F, O]

Creates a stream by successively applying f until a None is returned, emitting each output O and using each output S as input to the next invocation of f.

Creates a stream by successively applying f until a None is returned, emitting each output O and using each output S as input to the next invocation of f.

Example
scala> Stream.unfold(0)(i => if (i < 5) Some(i -> (i+1)) else None).toList
res0: List[Int] = List(0, 1, 2, 3, 4)
def unfoldChunk[F[x], S, O](s: S)(f: S => Option[(Chunk[O], S)]): Stream[F, O]

Like unfold but each invocation of f provides a chunk of output.

Like unfold but each invocation of f provides a chunk of output.

Example
scala> Stream.unfoldChunk(0)(i => if (i < 5) Some(Chunk.seq(List.fill(i)(i)) -> (i+1)) else None).toList
res0: List[Int] = List(1, 2, 2, 3, 3, 3, 4, 4, 4, 4)
def unfoldChunkEval[F[_], S, O](s: S)(f: S => F[Option[(Chunk[O], S)]]): Stream[F, O]

Like unfoldChunk, but takes an effectful function.

Like unfoldChunk, but takes an effectful function.

def unfoldEval[F[_], S, O](s: S)(f: S => F[Option[(O, S)]]): Stream[F, O]

Like unfold, but takes an effectful function.

Like unfold, but takes an effectful function.

def unfoldLoop[F <: ([x] =>> Pure[x]), S, O](s: S)(f: S => (O, Option[S])): Stream[F, O]

Creates a stream by successively applying f to a S, emitting each output O and using each output S as input to the next invocation of f if it is Some, or terminating on None

Creates a stream by successively applying f to a S, emitting each output O and using each output S as input to the next invocation of f if it is Some, or terminating on None

Example
scala> Stream.unfoldLoop(0)(i => (i, if (i < 5) Some(i+1) else None)).toList
res0: List[Int] = List(0, 1, 2, 3, 4, 5)
def unfoldLoopEval[F[_], S, O](s: S)(f: S => F[(O, Option[S])]): Stream[F, O]

Like unfoldLoop, but takes an effectful function.

Like unfoldLoop, but takes an effectful function.

Deprecated methods

@deprecated("Use exec if passing an F[Unit] or eval(fa).drain if passing an F[A]", "2.5.0")
def eval_[F[_], A](fa: F[A]): Stream[F, INothing]

Creates a stream that evaluates the supplied fa for its effect, discarding the output value. As a result, the returned stream emits no elements and hence has output type INothing.

Creates a stream that evaluates the supplied fa for its effect, discarding the output value. As a result, the returned stream emits no elements and hence has output type INothing.

Alias for eval(fa).drain.

Deprecated

Concrete fields

Empty pure stream.

Empty pure stream.

Implicits

Implicits

implicit def alignInstance[F[_]]: Align[[_] =>> Stream[F, _$189]]

Align instance for Stream.

Align instance for Stream.

  • @example
scala> import cats.syntax.all._
scala> Stream(1,2,3).align(Stream("A","B","C","D","E")).toList
res0: List[cats.data.Ior[Int,String]] = List(Both(1,A), Both(2,B), Both(3,C), Right(D), Right(E))
implicit def deferInstance[F[_]]: Defer[[_] =>> Stream[F, _$214]]

Defer instance for Stream

Defer instance for Stream

implicit def functionKInstance[F[_]]: FunctionK[F, [_] =>> Stream[F, _$208]]

FunctionK instance for F ~> Stream[F, *]

FunctionK instance for F ~> Stream[F, *]

Example
scala> import cats.Id
scala> Stream.functionKInstance[Id](42).compile.toList
res0: cats.Id[List[Int]] = List(42)
implicit def functorFilterInstance[F[_]]: FunctorFilter[[_] =>> Stream[F, _$202]]

FunctorFilter instance for Stream.

FunctorFilter instance for Stream.

Example
scala> import cats.syntax.all._, scala.util._
scala> Stream("1", "2", "NaN").mapFilter(s => Try(s.toInt).toOption).toList
res0: List[Int] = List(1, 2)
implicit def monadErrorInstance[F[_]](ev: ApplicativeError[F, Throwable]): MonadError[[_] =>> Stream[F, _$185], Throwable]

MonadError instance for Stream.

MonadError instance for Stream.

Example
scala> import cats.syntax.all._
scala> Stream(1, -2, 3).fproduct(_.abs).toList
res0: List[(Int, Int)] = List((1,1), (-2,2), (3,3))
implicit def monoidInstance[F[_], O]: Monoid[Stream[F, O]]

Monoid instance for Stream.

Monoid instance for Stream.

implicit def monoidKInstance[F[_]]: MonoidK[[_] =>> Stream[F, _$211]]

Inherited implicits

implicit def monadInstance[F[_]]: Monad[[_] =>> Stream[F, _$217]]
Inherited from
StreamLowPriority