Object/Class

monix.tail

Iterant

Related Docs: class Iterant | package tail

Permalink

object Iterant extends IterantInstances with Serializable

Defines the standard Iterant builders.

Linear Supertypes
Serializable, Serializable, IterantInstances, IterantInstances1, IterantInstances0, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Iterant
  2. Serializable
  3. Serializable
  4. IterantInstances
  5. IterantInstances1
  6. IterantInstances0
  7. AnyRef
  8. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Type Members

  1. class CatsAsyncInstances[F[_]] extends IterantInstances1.CatsSyncInstances[F] with Async[[α]Iterant[F, α]]

    Permalink

    Provides the cats.effect.Async instance for Iterant.

    Provides the cats.effect.Async instance for Iterant.

    Definition Classes
    IterantInstances1
  2. class CatsSyncInstances[F[_]] extends Sync[[α]Iterant[F, α]] with MonoidK[[α]Iterant[F, α]] with CoflatMap[[α]Iterant[F, α]]

    Permalink

    Provides the cats.effect.Sync instance for Iterant.

    Provides the cats.effect.Sync instance for Iterant.

    Definition Classes
    IterantInstances0
  3. final case class Halt[F[_], A](e: Option[Throwable]) extends Iterant[F, A] with Product with Serializable

    Permalink

    The Halt state of the Iterant represents the completion state of a stream, with an optional exception if an error happened.

    The Halt state of the Iterant represents the completion state of a stream, with an optional exception if an error happened.

    Halt is received as a final state in the iteration process. This state cannot be followed by any other element and represents the end of the stream.

    e

    is an error to signal at the end of the stream, or None in case the stream has completed normally

  4. final case class Last[F[_], A](item: A) extends Iterant[F, A] with Product with Serializable

    Permalink

    The Last state of the Iterant represents a completion state as an alternative to Halt(None), describing one last element.

    The Last state of the Iterant represents a completion state as an alternative to Halt(None), describing one last element.

    It is introduced as an optimization, being equivalent to Next(item, F.pure(Halt(None)), F.unit), to avoid extra processing in the monadic F[_] and to short-circuit operations such as concatenation and flatMap.

    item

    is the last element being signaled, after which the consumer can stop the iteration

  5. final case class Next[F[_], A](item: A, rest: F[Iterant[F, A]], stop: F[Unit]) extends Iterant[F, A] with Product with Serializable

    Permalink

    The Next state of the Iterant represents a head / rest cons pair, where the head is a strict value.

    The Next state of the Iterant represents a head / rest cons pair, where the head is a strict value.

    Note the head being a strict value means that it is already known, whereas the rest is meant to be lazy and can have asynchronous behavior as well, depending on the F type used.

    See NextCursor for a state where the head is a strict immutable list.

    item

    is the current element to be signaled

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  6. final case class NextBatch[F[_], A](batch: Batch[A], rest: F[Iterant[F, A]], stop: F[Unit]) extends Iterant[F, A] with Product with Serializable

    Permalink

    The NextBatch state of the Iterant represents an batch / rest cons pair, where batch is an Iterable type that can generate a whole batch of elements.

    The NextBatch state of the Iterant represents an batch / rest cons pair, where batch is an Iterable type that can generate a whole batch of elements.

    batch

    is a Iterable type that can generate elements by traversing a collection, a standard array or any Iterable

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  7. final case class NextCursor[F[_], A](cursor: BatchCursor[A], rest: F[Iterant[F, A]], stop: F[Unit]) extends Iterant[F, A] with Product with Serializable

    Permalink

    The NextCursor state of the Iterant represents an batch / rest cons pair, where batch is an Iterator type that can generate a whole batch of elements.

    The NextCursor state of the Iterant represents an batch / rest cons pair, where batch is an Iterator type that can generate a whole batch of elements.

    Useful for doing buffering, or by giving it an empty iterator, useful to postpone the evaluation of the next element.

    cursor

    is an Iterator type that can generate elements by traversing a collection, a standard array or any Iterator

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  8. final case class Suspend[F[_], A](rest: F[Iterant[F, A]], stop: F[Unit]) extends Iterant[F, A] with Product with Serializable

    Permalink

    Builds a stream state equivalent with Iterant.NextCursor.

    Builds a stream state equivalent with Iterant.NextCursor.

    The Suspend state of the Iterant represents a suspended stream to be evaluated in the F context. It is useful to delay the evaluation of a stream by deferring to F.

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

Value Members

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

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

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. def apply[F[_]](implicit F: From[F]): Builders

    Permalink

    Returns an IterantBuilders instance for the specified F monadic type that can be used to build Iterant instances.

    Returns an IterantBuilders instance for the specified F monadic type that can be used to build Iterant instances.

    Example:

    Iterant[Task].range(0, 10)
  5. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  6. def bracket[F[_], A, B](acquire: F[A])(use: (A) ⇒ Iterant[F, B], release: (A) ⇒ F[Unit])(implicit F: Sync[F]): Iterant[F, B]

    Permalink

    Creates a stream that depends on resource allocated by a monadic value, ensuring the resource is released.

    Creates a stream that depends on resource allocated by a monadic value, ensuring the resource is released.

    Typical use-cases are working with files or network sockets

    acquire

    resource to acquire at the start of the stream

    use

    function that uses the resource to generate a stream of outputs

    release

    function that releases the acquired resource Example:

    val writeLines =
      Iterant.bracket(IO { new PrintWriter("./lines.txt") })(
        writer => Iterant[IO]
          .fromIterator(Iterator.from(1))
          .mapEval(i => IO { writer.println(s"Line #$i") }),
        writer => IO { writer.close() }
      )
    // Write 100 numbered lines to the file
    // closing the writer when finished
    writeLines.take(100).completeL.unsafeRunSync()
  7. implicit def catsAsyncInstances[F[_]](implicit F: Async[F]): CatsAsyncInstances[F]

    Permalink

    Provides the cats.effect.Async instance for Iterant.

    Provides the cats.effect.Async instance for Iterant.

    Definition Classes
    IterantInstances1
  8. implicit val catsInstancesForCoeval: CatsSyncInstances[Coeval]

    Permalink

    Provides type class instances for Iterant[Coeval, A], based on the default instances provided by Coeval.catsSync.

    Provides type class instances for Iterant[Coeval, A], based on the default instances provided by Coeval.catsSync.

    Definition Classes
    IterantInstances
  9. implicit val catsInstancesForIO: CatsAsyncInstances[IO]

    Permalink

    Provides type class instances for Iterant[IO, A].

    Provides type class instances for Iterant[IO, A].

    Definition Classes
    IterantInstances
  10. implicit val catsInstancesForTask: CatsAsyncInstances[Task]

    Permalink

    Provides type class instances for Iterant[Task, A], based on the default instances provided by Task.catsAsync.

    Provides type class instances for Iterant[Task, A], based on the default instances provided by Task.catsAsync.

    Definition Classes
    IterantInstances
  11. implicit def catsSyncInstances[F[_]](implicit F: Sync[F]): CatsSyncInstances[F]

    Permalink

    Provides the cats.effect.Sync instance for Iterant.

    Provides the cats.effect.Sync instance for Iterant.

    Definition Classes
    IterantInstances0
  12. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  13. def defer[F[_], A](fa: ⇒ Iterant[F, A])(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Alias for suspend.

    Alias for suspend.

    Promote a non-strict value representing a stream to a stream of the same type, effectively delaying its initialisation.

    fa

    is the by-name parameter that will generate the stream when evaluated

  14. def empty[F[_], A]: Iterant[F, A]

    Permalink

    Returns an empty stream.

  15. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  17. def eval[F[_], A](a: ⇒ A)(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Lifts a non-strict value into the stream context, returning a stream of one element that is lazily evaluated.

  18. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  19. def fromArray[F[_], A](xs: Array[A])(implicit arg0: ClassTag[A], F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts any standard Array into a stream.

  20. def fromIndexedSeq[F[_], A](xs: IndexedSeq[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts any Scala collection.IndexedSeq into a stream (e.g.

    Converts any Scala collection.IndexedSeq into a stream (e.g. Vector).

  21. def fromIterable[F[_], A](xs: Iterable[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts a scala.collection.Iterable into a stream.

  22. def fromIterator[F[_], A](xs: Iterator[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts a scala.collection.Iterator into a stream.

  23. def fromList[F[_], A](xs: LinearSeq[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts any Scala collection.immutable.LinearSeq into a stream.

  24. def fromSeq[F[_], A](xs: Seq[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Converts any scala.collection.Seq into a stream.

  25. def fromStateAction[F[_], S, A](f: (S) ⇒ (A, S))(seed: ⇒ S)(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an Iterant that keeps generating NextBatch items produced by our generator function with default recommendedBatchSize.

    Given an initial state and a generator function that produces the next state and the next element in the sequence, creates an Iterant that keeps generating NextBatch items produced by our generator function with default recommendedBatchSize.

    Example:

    val f = (x: Int) => (x + 1, x * 2)
    val seed = 1
    val stream = Iterant.fromStateAction[Task, Int, Int](f)(seed)
    
    // Yields 2, 3, 5, 9
    stream.take(5)
    See also

    fromStateActionL for version supporting F[_] in result of generator function and seed element

  26. def fromStateActionL[F[_], S, A](f: (S) ⇒ F[(A, S)])(seed: ⇒ F[S])(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Given an initial state and a generator function that produces the next state and the next element in the sequence in F[_] context, creates an Iterant that keeps generating Next items produced by our generator function.

    Given an initial state and a generator function that produces the next state and the next element in the sequence in F[_] context, creates an Iterant that keeps generating Next items produced by our generator function.

    Example:

    val f = (x: Int) => F.pure((x + 1, x * 2))
    val seed = F.pure(1)
    val stream = Iterant.fromStateAction[Task, Int, Int](f)(seed)
    
    // Yields 2, 3, 5, 9
    stream.take(5)
    See also

    fromStateAction for version without F[_] context which generates NextBatch items

  27. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  28. def haltS[F[_], A](e: Option[Throwable]): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.Halt.

    Builds a stream state equivalent with Iterant.Halt.

    The Halt state of the Iterant represents the completion state of a stream, with an optional exception if an error happened.

    Halt is received as a final state in the iteration process. This state cannot be followed by any other element and represents the end of the stream.

    e

    is an error to signal at the end of the stream, or None in case the stream has completed normally

  29. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  30. def intervalAtFixedRate[F[_]](initialDelay: FiniteDuration, period: FiniteDuration)(implicit F: Async[F], timer: Timer[F]): Iterant[F, Long]

    Permalink

    Creates an iterant that emits auto-incremented natural numbers (longs).

    Creates an iterant that emits auto-incremented natural numbers (longs). at a fixed rate, as given by the specified period. The amount of time it takes to process an incoming value gets subtracted from provided period, thus created iterant tries to emit events spaced by the given time interval, regardless of how long further processing takes

    This version of the intervalAtFixedRate allows specifying an initialDelay before first value is emitted

    initialDelay

    initial delay before emitting the first value

    period

    period between 2 successive emitted values

    timer

    is the timer implementation used to generate delays and to fetch the current time

  31. def intervalAtFixedRate[F[_]](period: FiniteDuration)(implicit F: Async[F], timer: Timer[F]): Iterant[F, Long]

    Permalink

    Creates an iterant that emits auto-incremented natural numbers (longs).

    Creates an iterant that emits auto-incremented natural numbers (longs). at a fixed rate, as given by the specified period. The amount of time it takes to process an incoming value gets subtracted from provided period, thus created iterant tries to emit events spaced by the given time interval, regardless of how long further processing takes

    period

    period between 2 successive emitted values

    timer

    is the timer implementation used to generate delays and to fetch the current time

  32. def intervalWithFixedDelay[F[_]](initialDelay: FiniteDuration, delay: FiniteDuration)(implicit F: Async[F], timer: Timer[F]): Iterant[F, Long]

    Permalink

    Creates an iterant that emits auto-incremented natural numbers (longs) spaced by a given time interval.

    Creates an iterant that emits auto-incremented natural numbers (longs) spaced by a given time interval. Starts from 0 with no delay, after which it emits incremented numbers spaced by the period of time. The given period of time acts as a fixed delay between successive events.

    initialDelay

    is the delay to wait before emitting the first event

    delay

    the time to wait between 2 successive events

    timer

    is the timer implementation used to generate delays and to fetch the current time

  33. def intervalWithFixedDelay[F[_]](delay: FiniteDuration)(implicit F: Async[F], timer: Timer[F]): Iterant[F, Long]

    Permalink

    Creates an iterant that emits auto-incremented natural numbers (longs) spaced by a given time interval.

    Creates an iterant that emits auto-incremented natural numbers (longs) spaced by a given time interval. Starts from 0 with no delay, after which it emits incremented numbers spaced by the period of time. The given period of time acts as a fixed delay between successive events.

    Without having an initial delay specified, this overload will immediately emit the first item, without any delays.

    delay

    the time to wait between 2 successive events

    timer

    is the timer implementation used to generate delays and to fetch the current time

  34. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  35. def lastS[F[_], A](item: A): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.Last.

    Builds a stream state equivalent with Iterant.Last.

    The Last state of the Iterant represents a completion state as an alternative to Halt(None), describing one last element.

    It is introduced as an optimization, being equivalent to Next(item, F.pure(Halt(None)), F.unit), to avoid extra processing in the monadic F[_] and to short-circuit operations such as concatenation and flatMap.

    item

    is the last element being signaled, after which the consumer can stop the iteration

  36. def liftF[F[_], A](fa: F[A])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Lifts a value from monadic context into the stream context, returning a stream of one element

  37. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  38. def nextBatchS[F[_], A](items: Batch[A], rest: F[Iterant[F, A]], stop: F[Unit]): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.NextBatch.

    Builds a stream state equivalent with Iterant.NextBatch.

    The NextBatch state of the Iterant represents an batch / rest cons pair, where batch is an Iterable type that can generate a whole batch of elements.

    items

    is a Iterable type that can generate elements by traversing a collection, a standard array or any Iterable

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  39. def nextCursorS[F[_], A](items: BatchCursor[A], rest: F[Iterant[F, A]], stop: F[Unit]): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.NextCursor.

    Builds a stream state equivalent with Iterant.NextCursor.

    The NextCursor state of the Iterant represents an batch / rest cons pair, where batch is an Iterator type that can generate a whole batch of elements.

    Useful for doing buffering, or by giving it an empty iterator, useful to postpone the evaluation of the next element.

    items

    is an Iterator type that can generate elements by traversing a collection, a standard array or any Iterator

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  40. def nextS[F[_], A](item: A, rest: F[Iterant[F, A]], stop: F[Unit]): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.Next.

    Builds a stream state equivalent with Iterant.Next.

    The Next state of the Iterant represents a head / rest cons pair, where the head is a strict value.

    Note the head being a strict value means that it is already known, whereas the rest is meant to be lazy and can have asynchronous behavior as well, depending on the F type used.

    See NextCursor for a state where the head is a strict immutable list.

    item

    is the current element to be signaled

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

  41. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  43. def now[F[_], A](a: A): Iterant[F, A]

    Permalink

    Lifts a strict value into the stream context, returning a stream of one element.

  44. def pure[F[_], A](a: A): Iterant[F, A]

    Permalink

    Alias for now.

  45. def raiseError[F[_], A](ex: Throwable): Iterant[F, A]

    Permalink

    Returns an empty stream that ends with an error.

  46. def range[F[_]](from: Int, until: Int, step: Int = 1)(implicit F: Applicative[F]): Iterant[F, Int]

    Permalink

    Builds a stream that on evaluation will produce equally spaced values in some integer interval.

    Builds a stream that on evaluation will produce equally spaced values in some integer interval.

    from

    the start value of the stream

    until

    the end value of the stream (exclusive from the stream)

    step

    the increment value of the tail (must be positive or negative)

    returns

    the tail producing values from, from + step, ... up to, but excluding until

  47. def repeat[F[_], A](elems: A*)(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Builds a stream that repeats the items provided in argument.

    Builds a stream that repeats the items provided in argument.

    It terminates either on error or if the source is empty.

  48. def repeatEval[F[_], A](thunk: ⇒ A)(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Builds a stream that suspends provided thunk and evaluates it indefinitely on-demand.

    Builds a stream that suspends provided thunk and evaluates it indefinitely on-demand.

    The stream will only terminate if evaluation throws an exception

    Referentially transparent alternative to Iterator.continually

    Example: infinite sequence of random numbers

    import scala.util.Random
    
    val randomInts = Iterant[Coeval].repeatEval(Random.nextInt())
  49. def repeatEvalF[F[_], A](fa: F[A])(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Builds a stream that evaluates provided effectful values indefinitely.

    Builds a stream that evaluates provided effectful values indefinitely.

    The stream will only terminate if an error is raised in F context

  50. def suspend[F[_], A](rest: F[Iterant[F, A]])(implicit F: Applicative[F]): Iterant[F, A]

    Permalink

    Defers the stream generation to the underlying evaluation context (e.g.

    Defers the stream generation to the underlying evaluation context (e.g. Task, Coeval, IO, etc), building a reference equivalent with Iterant.Suspend.

    The Suspend state of the Iterant represents a suspended stream to be evaluated in the F context. It is useful to delay the evaluation of a stream by deferring to F.

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

  51. def suspend[F[_], A](fa: ⇒ Iterant[F, A])(implicit F: Sync[F]): Iterant[F, A]

    Permalink

    Promote a non-strict value representing a stream to a stream of the same type, effectively delaying its initialisation.

    Promote a non-strict value representing a stream to a stream of the same type, effectively delaying its initialisation.

    fa

    is the by-name parameter that will generate the stream when evaluated

  52. def suspendS[F[_], A](rest: F[Iterant[F, A]], stop: F[Unit]): Iterant[F, A]

    Permalink

    Builds a stream state equivalent with Iterant.NextCursor.

    Builds a stream state equivalent with Iterant.NextCursor.

    The Suspend state of the Iterant represents a suspended stream to be evaluated in the F context. It is useful to delay the evaluation of a stream by deferring to F.

    rest

    is the next state in the sequence that will produce the rest of the stream when evaluated

    stop

    is a computation to be executed in case streaming is stopped prematurely, giving it a chance to do resource cleanup (e.g. close file handles)

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

    Permalink
    Definition Classes
    AnyRef
  54. def tailRecM[F[_], A, B](a: A)(f: (A) ⇒ Iterant[F, Either[A, B]])(implicit F: Sync[F]): Iterant[F, B]

    Permalink

    Keeps calling f and concatenating the resulting iterants for each scala.util.Left event emitted by the source, concatenating the resulting iterants and generating events out of scala.util.Right[B] values.

    Keeps calling f and concatenating the resulting iterants for each scala.util.Left event emitted by the source, concatenating the resulting iterants and generating events out of scala.util.Right[B] values.

    Based on Phil Freeman's Stack Safety for Free.

  55. def toString(): String

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

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from Serializable

Inherited from Serializable

Inherited from IterantInstances

Inherited from IterantInstances1

Inherited from IterantInstances0

Inherited from AnyRef

Inherited from Any

Ungrouped