fs2
package fs2
- Source
- fs2.scala
- Alphabetic
- By Inheritance
- fs2
- AnyRef
- Any
- Hide All
- Show All
- Public
- Protected
Package Members
- package compat
- package compression
- package concurrent
Provides several concurrency primitives.
Provides several concurrency primitives. *
- package interop
- package io
- package protocols
- package timeseries
Type Members
- abstract class Chunk[+O] extends Serializable with ChunkPlatform[O] with ChunkRuntimePlatform[O]
Immutable, strict, finite sequence of values that supports efficient index-based random access of elements, is memory efficient for all sizes, and avoids unnecessary copying.
Immutable, strict, finite sequence of values that supports efficient index-based random access of elements, is memory efficient for all sizes, and avoids unnecessary copying.
Chunk
s can be created from a variety of collection types using methods on theChunk
companion (e.g.,Chunk.array
,Chunk.seq
,Chunk.vector
).Chunks can be appended via the
++
method. The returned chunk is a composite of the input chunks -- that is, there's no copying of the source chunks. For example,Chunk(1, 2) ++ Chunk(3, 4) ++ Chunk(5, 6)
returns aChunk.Queue(Chunk(1, 2), Chunk(3, 4), Chunk(5, 6))
. As a result, indexed based lookup of an appended chunk is amortizedO(log2(number of underlying chunks))
. In the worst case, where each constituent chunk has size 1, indexed lookup isO(log2(size))
. To restoreO(1)
lookup, callcompact
, which copies all the underlying chunk elements to a single array backed chunk. Notecompact
requires aClassTag
of the element type.Alternatively, a collection of chunks can be directly copied to a new array backed chunk via
Chunk.concat(chunks)
. Likecompact
,Chunk.concat
requires aClassTag
for the element type.Various subtypes of
Chunk
are exposed for efficiency reasons:Chunk.Singleton
Chunk.ArraySlice
Chunk.Queue
In particular, calling
.toArraySlice
on a chunk returns aChunk.ArraySlice
, which provides access to the underlying backing array, along with an offset and length, referring to a slice of that array. - trait Collector[-A] extends AnyRef
Supports building a result of type
Out
from zero or moreChunk[A]
.Supports building a result of type
Out
from zero or moreChunk[A]
.This is similar to the standard library collection builders but optimized for building a collection from a stream.
The companion object provides implicit conversions (methods starting with
supports
), which adapts various collections to theCollector
trait. - trait CollectorK[+C[_]] extends AnyRef
Mixin trait for companions of collections that can build a
C[A]
for allA
. - sealed trait Compiler[F[_], G[_]] extends AnyRef
Provides compilation of a
Stream[F, O]
to aG[*]
.Provides compilation of a
Stream[F, O]
to aG[*]
.In the most common case,
F = G = IO
or another "fully featured" effect type. However, there are other common instantiations likeF = Pure, G = Id
, which allows compiling aStream[Pure, A]
in to pure values.For the common case where
F = G
, thetarget
implicit constructor provides an instance ofCompiler[F, F]
--target
requires aCompiler.Target[F]
instance. TheCompiler.Target[F]
is a super chargedMonadErrorThrow[F]
, providing additional capabilities needed for stream compilation.Compiler.Target[F]
instances are given for allF[_]
which have:Concurrent[F]
instances- both
MonadCancelThrow[F]
andSync[F]
intances - only
Sync[F]
instances Support for stream interruption requires compilation to an effect which has aConcurrent
instance.
- Annotations
- @implicitNotFound()
- case class CompositeFailure(head: Throwable, tail: NonEmptyList[Throwable]) extends Throwable with Product with Serializable
Represents multiple (>1) exceptions were thrown.
- sealed trait Fallible[A] extends AnyRef
Indicates that a stream evaluates no effects but unlike Pure, may raise errors.
Indicates that a stream evaluates no effects but unlike Pure, may raise errors.
Uninhabited.
A
Stream[Fallible,O]
can be safely converted to aStream[F,O]
for allF
vias.lift[F]
, provided anApplicativeError[F, Throwable]
is available. - type Pipe[F[_], -I, +O] = (Stream[F, I]) => Stream[F, O]
A stream transformation represented as a function from stream to stream.
A stream transformation represented as a function from stream to stream.
Pipes are typically applied with the
through
operation onStream
. - type Pipe2[F[_], -I, -I2, +O] = (Stream[F, I], Stream[F, I2]) => Stream[F, O]
A stream transformation that combines two streams in to a single stream, represented as a function from two streams to a single stream.
A stream transformation that combines two streams in to a single stream, represented as a function from two streams to a single stream.
Pipe2
s are typically applied with thethrough2
operation onStream
. - sealed abstract class Pull[+F[_], +O, +R] extends AnyRef
A purely functional data structure that describes a process.
A purely functional data structure that describes a process. This process may evaluate actions in an effect type F, emit any number of output values of type O (or None), and may a) terminate with a single result of type R; or b) terminate abnormally by raising (inside the effect
F
) an exception, or c) terminate because it was cancelled by another process, or d) not terminate.Like types from other effect libraries, pulls are pure and immutable values. They preserve referential transparency.
Chunking
The output values of a pull are emitted not one by one, but in chunks. A
Chunk
is an immutable sequence with constant-time indexed lookup. For example, a pullp: Pull[F, Byte, R]
internally operates and emitsChunk[Byte]
values, which can wrap unboxed byte arrays -- avoiding boxing/unboxing costs. ThePull
API provides mechanisms for working at both the chunk level and the individual element level. Generally, working at the chunk level will result in better performance but at the cost of more complex implementationsA pull only emits non-empty chunks.
However, chunks are not merely an operational matter of efficiency. Each pull is emitted from a chunk atomically, which is to say, any errors or interruptions in a pull can only happen between chunks, not within a chunk. For instance, if creating a new chunk of values fails (raises an uncaught exception) while creating an intermediate value, then it fails to create the entire chunk and previous values are discarded.
Evaluation
Like other functional effect types (e.g.
cats.effect.IO
), a pull describes a _process_ or _computation_. It is not a running process nor a handle for the result of a spawned, running process, likescala.concurrent.Future
.A pull can be converted to a stream and then compiled to an effectful value. For a
Pull[F, O, Unit]
, the result of compilation is a combination, via the monad instance ofF
, of all the actions in the effectF
present in the pull. The result of thatF
action is the result of combining the outputs emitted by the pull, in the order it emits them, using a _fold_ function. Depending on that function, outputs may be collected into a list (or vector or array or ...), combined together into a single value, or just discarded altogether (by _draining_ the pull).Compilation is pull-based, rather than push-based (hence the name of the datatype). It is the compilation process itself, that determines when the evaluation of each single effect can proceed or is held back. Effects and outputs later in the pull are not performed or emitted, _unless and until_ the compilation calls for them.
Resource scoping
The effects in a
Pull
may operate on resources, which must be retained during the execution of the pull, may be shared by several pulls, and must be properly finalised when no longer needed, regardless of whether the pull completed successfully or not. A pull tracks its resources using scopes, which register how many pulls are actively using each resource, and finalises resources when no longer used.Some operations of the
Pull
API can be used to introduce new resource scopes, or resource boundaries.Functional typeclasses
The
Pull
data structure is a "free" implementation ofMonad
and has an instance forcats.effect.kernel.Sync
.For any types
F[_]
andO
, aPull[F, O, *]
holds the following laws:pure >=> f == f
f >=> pure == f
(f >=> g) >=> h == f >=> (g >=> h)
wheref >=> g
is defined asa => a flatMap f flatMap g
handleErrorWith(raiseError(e))(f) == f(e)
- O
The outputs emitted by this Pull. An output type of
Nothing
means that this pull does not emit any outputs.- R
The type of result returned by this Pull upon successful termination. An output type of
Nothing
indicates that this pull cannot terminate successfully: it may fail, be cancelled, or never terminate.
- abstract type Pure[A] <: Nothing
Indicates that a stream evaluates no effects.
Indicates that a stream evaluates no effects.
Because Stream is covariant, A
Stream[Pure,O]
is also an instance ofStream[F,O]
for allF
.This should not be confused with cats.Id, which provides an alternative encoding of pure streams, namely
Stream[Id, O]
. The difference is thatStream[Id, O]
achieves purity by using an effect type whose evaluation is a no-op, whereasStream[Pure, O]
achieves purity by using an effect type that has no instances and therefore cannot be instantiated in the first place. - trait RaiseThrowable[F[_]] extends AnyRef
Witnesses that
F
supports raising throwables.Witnesses that
F
supports raising throwables.An instance of
RaiseThrowable
is available for anyF
which has anApplicativeError[F, Throwable]
instance. Alternatively, an instance is available for the uninhabited typeFallible
.- Annotations
- @implicitNotFound()
- final class Scan[S, -I, +O] extends AnyRef
A stateful transformation of the elements of a stream.
A stateful transformation of the elements of a stream.
A scan is primarily represented as a function
(S, I) => (S, Chunk[O])
. Scans also have an initial state value of typeS
and the ability to emit elements upon completion via a functionS => Chunk[O]
.A scan is built up incrementally via various combinators and then converted to a pipe via
.toPipe
. For example,s.through(Scan.lift(identity).toPipe) == s
.A scan is much less powerful than a pull. Scans cannot evaluate effects or terminate early. These limitations allow combinators that are not possible on pulls though. For example, the first method converts a
Scan[S, I, O]
to aScan[S, (I, A), (O, A)]
. Critically, this method relies on the ability to feed a singleI
to the original scan and collect the resultingO
values, pairing eachO
with theA
that was paired withI
. - final class Stream[+F[_], +O] extends AnyRef
A stream producing output of type
O
and which may evaluateF
effects.A stream producing output of type
O
and which may evaluateF
effects.- Purely functional a value of type
Stream[F, O]
_describes_ an effectful computation. A function that returns aStream[F, O]
builds a _description_ of an effectful computation, but does not perform them. The methods of theStream
class derive new descriptions from others. This is similar to how effect types likecats.effect.IO
andmonix.Task
build descriptions of computations.- Pull: to evaluate a stream, a consumer pulls its values from it, by repeatedly performing one pull step at a time. Each step is a
F
-effectful computation that may yield someO
values (or none), and a stream from which to continue pulling. The consumer controls the evaluation of the stream, which effectful operations are performed, and when.- Non-Strict: stream evaluation only pulls from the stream a prefix large enough to compute its results. Thus, although a stream may yield an unbounded number of values or, after successfully yielding several values, either raise an error or hang up and never yield any value, the consumer need not reach those points of failure. For the same reason, in general, no effect in
F
is evaluated unless and until the consumer needs it.- Abstract: a stream needs not be a plain finite list of fixed effectful computations in F. It can also represent an input or output connection through which data incrementally arrives. It can represent an effectful computation, such as reading the system's time, that can be re-evaluated as often as the consumer of the stream requires.
Special properties for streams
There are some special properties or cases of streams:
- A stream is finite if we can reach the end after a limited number of pull steps, which may yield a finite number of values. It is empty if it terminates and yields no values.
- A singleton stream is a stream that ends after yielding one single value.
- A pure stream is one in which the
F
is Pure, which indicates that it evaluates no effects. - A never stream is a stream that never terminates and never yields any value.
Pure Streams and operations
We can sometimes think of streams, naively, as lists of
O
elements withF
-effects. This is particularly true for pure streams, which are instances ofStream
which use the Pure effect type. We can convert every pure and finite stream into aList[O]
using the.toList
method. Also, we can convert pure infinite streams into instances of theStream[O]
class from the Scala standard library.A method of the
Stream
class is pure if it can be applied to pure streams. Such methods are identified in that their signature includes no type-class constraint (or implicit parameter) on theF
method. Pure methods inStream[F, O]
can be projected naturally to methods in theList
class, which means that applying the stream's method and converting the result to a list gets the same result as first converting the stream to a list, and then applying list methods.Some methods that project directly to list are
map
,filter
,takeWhile
, etc. There are other methods, likeexists
orfind
, that in theList
class they return a value or anOption
, but their stream counterparts return an (either empty or singleton) stream. Other methods, likezipWithPrevious
, have a more complicated but still pure translation to list methods.Type-Class instances and laws of the Stream Operations
Laws (using infix syntax):
append
forms a monoid in conjunction withempty
:empty append s == s
ands append empty == s
.(s1 append s2) append s3 == s1 append (s2 append s3)
And
cons
is consistent with using++
to prepend a single chunk:s.cons(c) == Stream.chunk(c) ++ s
Stream.raiseError
propagates until being caught byhandleErrorWith
:Stream.raiseError(e) handleErrorWith h == h(e)
Stream.raiseError(e) ++ s == Stream.raiseError(e)
Stream.raiseError(e) flatMap f == Stream.raiseError(e)
Stream
forms a monad withemit
andflatMap
:Stream.emit >=> f == f
(left identity)f >=> Stream.emit === f
(right identity - note weaker equality notion here)(f >=> g) >=> h == f >=> (g >=> h)
(associativity) whereStream.emit(a)
is defined aschunk(Chunk.singleton(a))
andf >=> g
is defined asa => a flatMap f flatMap g
The monad is the list-style sequencing monad:
(a ++ b) flatMap f == (a flatMap f) ++ (b flatMap f)
Stream.empty flatMap f == Stream.empty
Technical notes
Note: since the chunk structure of the stream is observable, and
s flatMap Stream.emit
produces a stream of singleton chunks, the right identity law uses a weaker notion of equality,===
which normalizes both sides with respect to chunk structure:(s1 === s2) = normalize(s1) == normalize(s2)
where==
is full equality (a == b
ifff(a)
is identical tof(b)
for allf
)normalize(s)
can be defined ass.flatMap(Stream.emit)
, which just produces a singly-chunked stream from any input streams
.For instance, for a stream
s
and a functionf: A => B
, - the result ofs.map(f)
is a Stream with the same _chunking_ as thes
; whereas... - the result ofs.flatMap(x => S.emit(f(x)))
is a Stream structured as a sequence of singleton chunks. The latter is using the definition ofmap
that is derived from theMonad
instance.This is not unlike equality for maps or sets, which is defined by which elements they contain, not by how these are spread between a tree's branches or a hashtable buckets. However, a
Stream
structure can be _observed_ through thechunks
method, so two streams "_equal_" under that notion may give different results through this method.Note: For efficiency
Stream.map
function operates on an entire chunk at a time and preserves chunk structure, which differs from themap
derived from the monad (s map f == s flatMap (f andThen Stream.emit)
) which would produce singleton chunk. In particular, iff
throws errors, the chunked version will fail on the first chunk with an error, while the unchunked version will fail on the first element with an error. Exceptions in pure code like this are strongly discouraged.
Deprecated Type Members
Value Members
- object Chunk extends CollectorK[Chunk] with ChunkCompanionPlatform with ChunkCompanionRuntimePlatform with Serializable
- object Collector extends CollectorPlatform
- object CollectorK
- object Compiler extends CompilerLowPriority
- object CompositeFailure extends Serializable
- object Fallible
- object Pull extends PullLowPriority
- object RaiseThrowable
- object Scan
- object Stream extends StreamLowPriority
- object hash
Provides various cryptographic hashes as pipes.
- object text
Provides utilities for working with streams of text (e.g., encoding byte streams to strings).