Packages

class TemporalZio[R] extends AsyncZio[R] with Temporal2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Linear Supertypes
Temporal2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], WeakTemporal2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], TemporalInstances, AsyncZio[R], Async2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], WeakAsync2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], IO2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Panic2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], PanicSyntax, Bracket2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Error2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], ErrorAccumulatingOps2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Monad2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], ApplicativeError2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Bifunctor2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Guarantee2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Applicative2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Functor2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Concurrent2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], ParallelErrorAccumulatingOps2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Parallel2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], RootBifunctor[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]], Root, PredefinedHelper, DivergenceHelper, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TemporalZio
  2. Temporal2
  3. WeakTemporal2
  4. TemporalInstances
  5. AsyncZio
  6. Async2
  7. WeakAsync2
  8. IO2
  9. Panic2
  10. PanicSyntax
  11. Bracket2
  12. Error2
  13. ErrorAccumulatingOps2
  14. Monad2
  15. ApplicativeError2
  16. Bifunctor2
  17. Guarantee2
  18. Applicative2
  19. Functor2
  20. Concurrent2
  21. ParallelErrorAccumulatingOps2
  22. Parallel2
  23. RootBifunctor
  24. Root
  25. PredefinedHelper
  26. DivergenceHelper
  27. AnyRef
  28. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. Protected

Instance Constructors

  1. new TemporalZio()

Type Members

  1. type Divergence = Nondivergent
    Definition Classes
    DivergenceHelper
  2. type IsPredefined = NotPredefined
    Definition Classes
    PredefinedHelper

Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##: Int
    Definition Classes
    AnyRef → Any
  3. final def *>[E, A, B](f: ZIO[R, E, A], next: => ZIO[R, E, B]): ZIO[R, E, B]

    execute two operations in order, return result of second operation

    execute two operations in order, return result of second operation

    Definition Classes
    AsyncZioMonad2Applicative2
    Annotations
    @inline()
  4. final def <*[E, A, B](f: ZIO[R, E, A], next: => ZIO[R, E, B]): ZIO[R, E, A]

    execute two operations in order, same as *>, but return result of first operation

    execute two operations in order, same as *>, but return result of first operation

    Definition Classes
    AsyncZioMonad2Applicative2
    Annotations
    @inline()
  5. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  6. def InnerF: TemporalZio.this.type
    Definition Classes
    AsyncZioAsync2WeakAsync2ApplicativeError2Bifunctor2Concurrent2ParallelErrorAccumulatingOps2Parallel2
    Annotations
    @inline()
  7. def accumulateErrorsImpl[ColL[_], ColR[x] <: IterableOnce[x], E, E1, A, B, B1, AC](col: ColR[A])(effect: (A) => ZIO[R, E, B], onLeft: (E) => IterableOnce[E1], init: AC, onRight: (AC, B) => AC, end: (AC) => B1)(implicit buildL: Factory[E1, ColL[E1]]): ZIO[R, ColL[E1], B1]
    Attributes
    protected
    Definition Classes
    IO2ErrorAccumulatingOps2
  8. final def apply[A](effect: => A): ZIO[R, Throwable, A]
    Definition Classes
    IO2
    Annotations
    @inline()
  9. final def as[E, A, B](r: ZIO[R, E, A])(v: => B): ZIO[R, E, B]
    Definition Classes
    AsyncZioFunctor2
    Annotations
    @inline()
  10. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  11. final def async[E, A](register: ((Either[E, A]) => Unit) => Unit): ZIO[Any, E, A]

    Construct an effect from an asynchronous callback-based API.

    Construct an effect from an asynchronous callback-based API.

    The callback provided to register must be invoked exactly once with either a success value wrapped in Right or an error wrapped in Left.

    Example:

    def readFile[F[+_, +_]: WeakAsync2](path: String): F[Throwable, String] = {
      F.async { cb =>
        asyncFileReader.read(path)(
          onSuccess = content => cb(Right(content)),
          onError = err => cb(Left(err))
        )
      }
    }
    Definition Classes
    AsyncZioAsync2WeakAsync2
    Annotations
    @inline()
    Note

    Effects created with async, asyncF, asyncWithOnInterrupt, fromFuture and fromFutureJava are INTERRUPTIBLE.

    • In case of async and asyncF if the current fiber is interrupted, the registered callback will be simply THROWN AWAY.
    • If a cleanup action is required to wind down the async operation safely, use asyncWithOnInterrupt to provide a cleanup action.
    • If an async operation's callback CANNOT be safely discarded OR interrupted, wrap your expression in Panic2.uninterruptible.
  12. final def asyncF[E, A](register: ((Either[E, A]) => Unit) => ZIO[R, E, Unit]): ZIO[R, E, A]

    Same as async, but registration action can use F capabilities.

    Same as async, but registration action can use F capabilities. Registration action itself is uninterruptible, but the produced effect is interruptible.

    Definition Classes
    AsyncZioAsync2
    Annotations
    @inline()
    Note

    Effects created with async, asyncF, asyncWithOnInterrupt, fromFuture and fromFutureJava are INTERRUPTIBLE.

    • In case of async and asyncF if the current fiber is interrupted, the registered callback will be simply THROWN AWAY.
    • If a cleanup action is required to wind down the async operation safely, use asyncWithOnInterrupt to provide a cleanup action.
    • If an async operation's callback CANNOT be safely discarded OR interrupted, wrap your expression in Panic2.uninterruptible.
  13. final def asyncWithOnInterrupt[E, A](register: ((Either[E, A]) => Unit) => InterruptAction[[+β$2$, +γ$3$]ZIO[R, β$2$, γ$3$]]): ZIO[R, E, A]

    Just as in async, registers async callback impurely, but also returns an F effect that will be executed to interrupt the async action if the current fiber is interrupted

    Just as in async, registers async callback impurely, but also returns an F effect that will be executed to interrupt the async action if the current fiber is interrupted

    Definition Classes
    AsyncZioAsync2
    Annotations
    @inline()
    Note

    Effects created with async, asyncF, asyncWithOnInterrupt, fromFuture and fromFutureJava are INTERRUPTIBLE.

    • In case of async and asyncF if the current fiber is interrupted, the registered callback will be simply THROWN AWAY.
    • If a cleanup action is required to wind down the async operation safely, use asyncWithOnInterrupt to provide a cleanup action.
    • If an async operation's callback CANNOT be safely discarded OR interrupted, wrap your expression in Panic2.uninterruptible.
  14. final def attempt[E, A](r: ZIO[R, E, A]): ZIO[R, Nothing, Either[E, A]]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  15. final def bimap[E, A, E2, B](r: ZIO[R, E, A])(f: (E) => E2, g: (A) => B): ZIO[R, E2, B]
    Definition Classes
    AsyncZioError2Bifunctor2
    Annotations
    @inline()
  16. final def bracket[E, A, B](acquire: ZIO[R, E, A])(release: (A) => ZIO[R, Nothing, Unit])(use: (A) => ZIO[R, E, B]): ZIO[R, E, B]
    Definition Classes
    AsyncZioBracket2
    Annotations
    @inline()
  17. final def bracketCase[E, A, B](acquire: ZIO[R, E, A])(release: (A, Exit[E, B]) => ZIO[R, Nothing, Unit])(use: (A) => ZIO[R, E, B]): ZIO[R, E, B]
    Definition Classes
    AsyncZioPanic2Bracket2
    Annotations
    @inline()
  18. final def bracketExcept[E, A, B](acquire: (RestoreInterruption2[[+β$10$, +γ$11$]ZIO[R, β$10$, γ$11$]]) => ZIO[R, E, A])(release: (A, Exit[E, B]) => ZIO[R, Nothing, Unit])(use: (A) => ZIO[R, E, B]): ZIO[R, E, B]

    Like bracketCase, but acquire can contain marked interruptible regions as in uninterruptibleExcept

    Like bracketCase, but acquire can contain marked interruptible regions as in uninterruptibleExcept

    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
  19. final def bracketOnFailure[E, A, B](acquire: ZIO[R, E, A])(cleanupOnFailure: (A, Failure[E]) => ZIO[R, Nothing, Unit])(use: (A) => ZIO[R, E, B]): ZIO[R, E, B]

    Run release action only on a failure – _any failure_, INCLUDING interruption.

    Run release action only on a failure – _any failure_, INCLUDING interruption. Do not run release action if use finished successfully.

    Definition Classes
    Bracket2
  20. final def catchAll[E, A, E2](r: ZIO[R, E, A])(f: (E) => ZIO[R, E2, A]): ZIO[R, E2, A]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  21. final def catchSome[E, A, E1 >: E](r: ZIO[R, E, A])(f: PartialFunction[E, ZIO[R, E1, A]]): ZIO[R, E1, A]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  22. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.CloneNotSupportedException]) @native()
  23. def collect[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, Option[B]]): ZIO[R, E, List[B]]
    Definition Classes
    Applicative2
  24. final def collectFirst[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, Option[B]]): ZIO[R, E, Option[B]]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  25. final def currentEC: ZIO[Any, Nothing, ExecutionContext]
    Definition Classes
    AsyncZioAsync2
    Annotations
    @inline()
  26. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  27. def equals(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef → Any
  28. final def fail[E](v: => E): ZIO[Any, E, Nothing]
    Definition Classes
    AsyncZioApplicativeError2
    Annotations
    @inline()
  29. final def filter[E, A](l: Iterable[A])(f: (A) => ZIO[R, E, Boolean]): ZIO[R, E, List[A]]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  30. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.Throwable])
  31. final def find[E, A](l: Iterable[A])(f: (A) => ZIO[R, E, Boolean]): ZIO[R, E, Option[A]]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  32. final def flatMap[E, A, B](r: ZIO[R, E, A])(f0: (A) => ZIO[R, E, B]): ZIO[R, E, B]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  33. def flatSequence[E, A](l: Iterable[ZIO[R, E, Iterable[A]]]): ZIO[R, E, List[A]]
    Definition Classes
    Applicative2
  34. def flatSequenceAccumErrors[ColR[x] <: IterableOnce[x], ColIn[x] <: IterableOnce[x], ColL[_], E, A](col: ColR[ZIO[R, ColL[E], ColIn[A]]])(implicit buildR: Factory[A, ColR[A]], buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], ColR[A]]

    flatSequence with error accumulation

    flatSequence with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  35. def flatTraverse[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, Iterable[B]]): ZIO[R, E, List[B]]
    Definition Classes
    Applicative2
  36. def flatTraverseAccumErrors[ColR[x] <: IterableOnce[x], ColIn[x] <: IterableOnce[x], ColL[_], E, A, B](col: ColR[A])(f: (A) => ZIO[R, ColL[E], ColIn[B]])(implicit buildR: Factory[B, ColR[B]], buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], ColR[B]]

    flatTraverse with error accumulation

    flatTraverse with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  37. final def flatten[E, A](r: ZIO[R, E, ZIO[R, E, A]]): ZIO[R, E, A]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  38. final def flip[E, A](r: ZIO[R, E, A]): ZIO[R, A, E]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  39. final def foldLeft[E, A, AC](l: Iterable[A])(z: AC)(f: (AC, A) => ZIO[R, E, AC]): ZIO[R, E, AC]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  40. final def forever[E, A](r: ZIO[R, E, A]): ZIO[R, E, Nothing]
    Definition Classes
    Applicative2
    Annotations
    @inline()
  41. final def fromAttempt[A](effect: => A): ZIO[R, Throwable, A]

    For lazy monads: alias for IO2#syncThrowable.

    For lazy monads: alias for IO2#syncThrowable. For strict monads, shorthand for F.fromTry(Try(effect))

    Definition Classes
    AsyncZioIO2ApplicativeError2
    Annotations
    @inline()
  42. final def fromEither[E, A](effect: => Either[E, A]): ZIO[Any, E, A]
    Definition Classes
    AsyncZioIO2ApplicativeError2
    Annotations
    @inline()
  43. final def fromFuture[A](mkFuture: (ExecutionContext) => Future[A]): ZIO[Any, Throwable, A]

    Definition Classes
    AsyncZioAsync2WeakAsync2
    Annotations
    @inline()
    Note

    to implementors: The effect produced MUST be interruptible (cats.effect.IO's fromFuture is not!)

  44. final def fromFuture[A](mkFuture: => Future[A]): ZIO[R, Throwable, A]
    Definition Classes
    WeakAsync2
    Annotations
    @inline()
  45. final def fromFutureJava[A](javaFuture: => CompletionStage[A]): ZIO[Any, Throwable, A]

    Definition Classes
    AsyncZioAsync2
    Annotations
    @inline()
    Note

    to implementors: The effect produced MUST be interruptible and call java.util.concurrent.Future.cancel on interrupt

  46. final def fromOption[E, A](errorOnNone: => E)(effect: => Option[A]): ZIO[Any, E, A]
    Definition Classes
    AsyncZioIO2ApplicativeError2
    Annotations
    @inline()
  47. def fromOption[E, A](errorOnNone: => E, r: ZIO[R, E, Option[A]]): ZIO[R, E, A]

    Extracts the optional value or fails with the errorOnNone error

    Extracts the optional value or fails with the errorOnNone error

    Definition Classes
    Error2
  48. final def fromOptionF[E, A](fallbackOnNone: => ZIO[R, E, A], r: ZIO[R, E, Option[A]]): ZIO[R, E, A]

    Extracts the optional value, or executes the fallbackOnNone effect

    Extracts the optional value, or executes the fallbackOnNone effect

    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  49. final def fromOptionOr[E, A](valueOnNone: => A, r: ZIO[R, E, Option[A]]): ZIO[R, E, A]

    Extracts the optional value, or returns the given valueOnNone value

    Extracts the optional value, or returns the given valueOnNone value

    Definition Classes
    AsyncZioFunctor2
    Annotations
    @inline()
  50. def fromSandboxExit[E, A](effect: => Uninterrupted[E, A]): ZIO[R, E, A]
    Definition Classes
    IO2Panic2
  51. final def fromTry[A](effect: => Try[A]): ZIO[Any, Throwable, A]
    Definition Classes
    AsyncZioIO2ApplicativeError2
    Annotations
    @inline()
  52. final def getClass(): Class[_ <: AnyRef]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  53. final def guarantee[E, A](f: ZIO[R, E, A], cleanup: ZIO[R, Nothing, Unit]): ZIO[R, E, A]
    Definition Classes
    AsyncZioBracket2Guarantee2
    Annotations
    @inline()
  54. final def guaranteeCase[E, A](f: ZIO[R, E, A], cleanup: (Exit[E, A]) => ZIO[R, Nothing, Unit]): ZIO[R, E, A]
    Definition Classes
    AsyncZioBracket2
    Annotations
    @inline()
  55. final def guaranteeExceptOnInterrupt[E, A](f: ZIO[R, E, A], cleanupOnNonInterruption: (Uninterrupted[E, A]) => ZIO[R, Nothing, Unit]): ZIO[R, E, A]

    Run cleanup on both _success_ and _failure_, if the failure IS NOT an interruption.

    Run cleanup on both _success_ and _failure_, if the failure IS NOT an interruption.

    Definition Classes
    Bracket2
  56. final def guaranteeOnFailure[E, A](f: ZIO[R, E, A], cleanupOnFailure: (Failure[E]) => ZIO[R, Nothing, Unit]): ZIO[R, E, A]

    Run cleanup only on a failure – _any failure_, INCLUDING interruption.

    Run cleanup only on a failure – _any failure_, INCLUDING interruption. Do not run cleanup if use finished successfully.

    Definition Classes
    Bracket2
  57. final def guaranteeOnInterrupt[E, A](f: ZIO[R, E, A], cleanupOnInterruption: (Interruption) => ZIO[R, Nothing, Unit]): ZIO[R, E, A]

    Run cleanup only on interruption.

    Run cleanup only on interruption. Do not run cleanup if use finished successfully.

    Definition Classes
    Bracket2
  58. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  59. final def ifThenElse[E, E1, A](cond: ZIO[R, E, Boolean])(ifTrue: => ZIO[R, E1, A], ifFalse: => ZIO[R, E1, A])(implicit ev: <:<[E, E1]): ZIO[R, E1, A]
    Definition Classes
    Monad2
    Annotations
    @inline()
  60. final def ifThenElse[E, A](cond: Boolean)(ifTrue: => ZIO[R, E, A], ifFalse: => ZIO[R, E, A]): ZIO[R, E, A]
    Definition Classes
    Applicative2
    Annotations
    @inline()
  61. final def ifThenFail[E](cond: Boolean)(errorIfTrue: => E): ZIO[R, E, Unit]
    Definition Classes
    ApplicativeError2
    Annotations
    @inline()
  62. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  63. final def iterateUntil[E, A](r: ZIO[R, E, A])(p: (A) => Boolean): ZIO[R, E, A]

    Execute an action repeatedly until its result satisfies the given predicate and return that result, discarding all others.

    Execute an action repeatedly until its result satisfies the given predicate and return that result, discarding all others.

    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  64. def iterateUntilF[E, A](init: A)(f: (A) => ZIO[R, E, A])(p: (A) => Boolean): ZIO[R, E, A]

    Apply an effectful function iteratively until its result satisfies the given predicate and return that result.

    Apply an effectful function iteratively until its result satisfies the given predicate and return that result.

    Definition Classes
    Monad2
  65. final def iterateWhile[E, A](r: ZIO[R, E, A])(p: (A) => Boolean): ZIO[R, E, A]

    Execute an action repeatedly until its result fails to satisfy the given predicate and return that result, discarding all others.

    Execute an action repeatedly until its result fails to satisfy the given predicate and return that result, discarding all others.

    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  66. def iterateWhileF[E, A](init: A)(f: (A) => ZIO[R, E, A])(p: (A) => Boolean): ZIO[R, E, A]

    Apply an effectful function iteratively until its result fails to satisfy the given predicate and return that result.

    Apply an effectful function iteratively until its result fails to satisfy the given predicate and return that result.

    Definition Classes
    Monad2
  67. final def leftFlatMap[E, A, E2](r: ZIO[R, E, A])(f: (E) => ZIO[R, Nothing, E2]): ZIO[R, E2, A]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  68. final def leftMap[E, A, E2](r: ZIO[R, E, A])(f: (E) => E2): ZIO[R, E2, A]
    Definition Classes
    AsyncZioBifunctor2
    Annotations
    @inline()
  69. final def leftMap2[E, A, E2, E3](firstOp: ZIO[R, E, A], secondOp: => ZIO[R, E2, A])(f: (E, E2) => E3): ZIO[R, E3, A]

    map errors from two operations into a new error if both fail

    map errors from two operations into a new error if both fail

    Definition Classes
    AsyncZioError2ApplicativeError2
    Annotations
    @inline()
  70. final def map[E, A, B](r: ZIO[R, E, A])(f: (A) => B): ZIO[R, E, B]
    Definition Classes
    AsyncZioMonad2Functor2
    Annotations
    @inline()
  71. final def map2[E, A, B, C](r1: ZIO[R, E, A], r2: => ZIO[R, E, B])(f: (A, B) => C): ZIO[R, E, C]

    execute two operations in order, map their results

    execute two operations in order, map their results

    Definition Classes
    AsyncZioMonad2Applicative2
    Annotations
    @inline()
  72. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  73. final def never: ZIO[Any, Nothing, Nothing]
    Definition Classes
    AsyncZioAsync2WeakAsync2Concurrent2
    Annotations
    @inline()
  74. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  75. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  76. final def onEC[E, A](ec: ExecutionContext)(f: ZIO[R, E, A]): ZIO[R, E, A]
    Definition Classes
    AsyncZioAsync2
    Annotations
    @inline()
  77. final def orElse[E, A, E2](r: ZIO[R, E, A], f: => ZIO[R, E2, A]): ZIO[R, E2, A]

    execute second operation only if the first one fails

    execute second operation only if the first one fails

    Definition Classes
    AsyncZioError2ApplicativeError2
    Annotations
    @inline()
  78. final def orTerminate[A](r: ZIO[R, Throwable, A]): ZIO[R, Nothing, A]
    Definition Classes
    Panic2
    Annotations
    @inline()
  79. final def orTerminateK: Morphism1[[β$0$]ZIO[R, Throwable, β$0$], [β$1$]ZIO[R, Nothing, β$1$]]
    Definition Classes
    Panic2
    Annotations
    @inline()
  80. final def parTraverse[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, B]): ZIO[R, E, List[B]]
    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  81. def parTraverseAccumErrors[ColL[_], E, A, B](col: Iterable[A])(f: (A) => ZIO[R, ColL[E], B])(implicit buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], List[B]]
  82. def parTraverseAccumErrors_[ColL[_], E, A](col: Iterable[A])(f: (A) => ZIO[R, ColL[E], Unit])(implicit buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], Unit]
  83. final def parTraverseN[E, A, B](maxConcurrent: Int)(l: Iterable[A])(f: (A) => ZIO[R, E, B]): ZIO[R, E, List[B]]
    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  84. final def parTraverseNCore[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, B]): ZIO[R, E, List[B]]

    parTraverseN with maxConcurrent set to the number of cores, or 2 when on single-core processor

    parTraverseN with maxConcurrent set to the number of cores, or 2 when on single-core processor

    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  85. final def parTraverseNCore_[E, A](l: Iterable[A])(f: (A) => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  86. final def parTraverseN_[E, A](maxConcurrent: Int)(l: Iterable[A])(f: (A) => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  87. final def parTraverse_[E, A](l: Iterable[A])(f: (A) => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  88. def partition[E, A](l: Iterable[ZIO[R, E, A]]): ZIO[R, Nothing, (List[E], List[A])]
    Definition Classes
    Error2
    Annotations
    @nowarn()
  89. final def pure[A](a: A): ZIO[Any, Nothing, A]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  90. final def race[E, A](r1: ZIO[R, E, A], r2: ZIO[R, E, A]): ZIO[R, E, A]

    Race two actions, the winner is the first action to TERMINATE, whether by success or failure

    Race two actions, the winner is the first action to TERMINATE, whether by success or failure

    Definition Classes
    AsyncZioConcurrent2
    Annotations
    @inline()
  91. final def racePairUnsafe[E, A, B](r1: ZIO[R, E, A], r2: ZIO[R, E, B]): ZIO[R, E, Either[(Exit[E, A], Fiber2[[+β$4$, +γ$5$]ZIO[R, β$4$, γ$5$], E, B]), (Fiber2[[+β$6$, +γ$7$]ZIO[R, β$6$, γ$7$], E, A], Exit[E, B])]]

    Race two actions, the winner is the first action to TERMINATE, whether by success or failure

    Race two actions, the winner is the first action to TERMINATE, whether by success or failure

    Unlike race, the loser is not interrupted after the winner has terminated - whether by success or failure.

    Definition Classes
    AsyncZioConcurrent2
    Annotations
    @inline()
  92. final def redeem[E, A, E2, B](r: ZIO[R, E, A])(err: (E) => ZIO[R, E2, B], succ: (A) => ZIO[R, E2, B]): ZIO[R, E2, B]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  93. final def redeemPure[E, A, B](r: ZIO[R, E, A])(err: (E) => B, succ: (A) => B): ZIO[R, Nothing, B]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  94. final def repeatUntil[E, A](action: ZIO[R, E, Option[A]])(tooManyAttemptsError: => E, sleep: FiniteDuration, maxAttempts: Int): ZIO[R, E, A]
    Definition Classes
    WeakTemporal2
    Annotations
    @inline()
  95. final def retryUntil[E, A](r: ZIO[R, E, A])(f: (E) => Boolean): ZIO[R, E, A]

    Retries this effect until its error satisfies the specified predicate.

    Retries this effect until its error satisfies the specified predicate.

    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  96. final def retryUntilF[E, A](r: ZIO[R, E, A])(f: (E) => ZIO[R, Nothing, Boolean]): ZIO[R, E, A]

    Retries this effect until its error satisfies the specified effectful predicate.

    Retries this effect until its error satisfies the specified effectful predicate.

    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  97. final def retryWhile[E, A](r: ZIO[R, E, A])(f: (E) => Boolean): ZIO[R, E, A]

    Retries this effect while its error satisfies the specified predicate.

    Retries this effect while its error satisfies the specified predicate.

    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  98. final def retryWhileF[E, A](r: ZIO[R, E, A])(f: (E) => ZIO[R, Nothing, Boolean]): ZIO[R, E, A]

    Retries this effect while its error satisfies the specified effectful predicate.

    Retries this effect while its error satisfies the specified effectful predicate.

    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  99. final def sandbox[E, A](r: ZIO[R, E, A]): ZIO[R, FailureUninterrupted[E], A]

    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
    Note

    Will return either Exit.Success, Exit.Error or Exit.Termination. Exit.Interruption cannot be sandboxed – use guaranteeOnInterrupt for cleanups on interruptions.

  100. final def sandboxCatchAll[E, A, E2](r: ZIO[R, E, A])(f: (FailureUninterrupted[E]) => ZIO[R, E2, A]): ZIO[R, E2, A]
    Definition Classes
    Panic2
    Annotations
    @inline()
  101. final def sandboxExit[E, A](r: ZIO[R, E, A]): ZIO[R, Nothing, Uninterrupted[E, A]]

    Definition Classes
    Panic2
    Annotations
    @inline()
    Note

    Will return either Exit.Success, Exit.Error or Exit.Termination. Exit.Interruption cannot be sandboxed. Use guaranteeOnInterrupt for cleanups on interruptions.

  102. final def sendInterruptToSelf: ZIO[Any, Nothing, Unit]

    Signal interruption to this fiber.

    Signal interruption to this fiber.

    This is _NOT_ the same as

    F.halt(Exit.Interrupted(Trace.forUnknownError))

    The code above exits with Exit.Interrupted failure *unconditionally*, whereas sendInterruptToSelf will not exit when in an uninterruptible region. Example:

    F.uninterruptible {
      F.halt(Exit.Interrupted(Trace.forUnknownError)) *>
      F.sync(println("Hello!")) // interrupted above. Hello _not_ printed
    }

    But with sendInterruptToSelf:

    F.uninterruptible {
      F.sendInterruptToSelf *>
      F.sync(println("Hello!")) // Hello IS printed.
    } *> F.sync(println("Impossible")) // interrupted immediately after `uninterruptible` block ends. Impossible _not_ printed
    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
    See also

  103. final def sequence[E, A](l: Iterable[ZIO[R, E, A]]): ZIO[R, E, List[A]]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  104. def sequenceAccumErrors[ColR[x] <: IterableOnce[x], ColL[_], E, A](col: ColR[ZIO[R, ColL[E], A]])(implicit buildR: Factory[A, ColR[A]], buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], ColR[A]]

    sequence with error accumulation

    sequence with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  105. def sequenceAccumErrorsNEList[ColR[x] <: IterableOnce[x], E, A](col: ColR[ZIO[R, E, A]])(implicit buildR: Factory[A, ColR[A]]): ZIO[R, NEList[E], ColR[A]]

    sequence with error accumulation

    sequence with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  106. def sequenceAccumErrors_[ColR[x] <: IterableOnce[x], ColL[_], E, A](col: ColR[ZIO[R, ColL[E], A]])(implicit buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], Unit]

    sequence_ with error accumulation

    sequence_ with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  107. final def sequence_[E](l: Iterable[ZIO[R, E, Unit]]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  108. final def sleep(duration: Duration): ZIO[R, Nothing, Unit]
    Definition Classes
    TemporalZioTemporal2WeakTemporal2
    Annotations
    @inline()
  109. final def suspendSafe[E, A](effect: => ZIO[R, E, A]): ZIO[R, E, A]

    Capture an _exception-safe_ side-effect that returns another effect

    Capture an _exception-safe_ side-effect that returns another effect

    Definition Classes
    AsyncZioIO2
    Annotations
    @inline()
  110. final def suspendThrowable[A](effect: => ZIO[R, Throwable, A]): ZIO[R, Throwable, A]

    Capture a side-effectful block of code that can throw exceptions and returns another effect

    Capture a side-effectful block of code that can throw exceptions and returns another effect

    Definition Classes
    AsyncZioIO2
    Annotations
    @inline()
  111. final def sync[A](effect: => A): ZIO[Any, Nothing, A]

    Capture an _exception-safe_ side-effect such as memory mutation or randomness

    Capture an _exception-safe_ side-effect such as memory mutation or randomness

    Definition Classes
    AsyncZioIO2
    Annotations
    @inline()
    Example:
    1. import izumi.functional.bio.F
      
      val exceptionSafeArrayAllocation: F[Nothing, Array[Byte]] = {
        F.sync(new Array(256))
      }
    Note

    If you're not completely sure that a captured block can't throw, use syncThrowable

    ,

    sync means synchronous, that is, a blocking CPU effect, as opposed to a non-blocking asynchronous effect or a long blocking I/O effect (izumi.functional.bio.BlockingIO2#syncBlocking)

  112. final def syncThrowable[A](effect: => A): ZIO[Any, Throwable, A]

    Capture a side-effectful block of code that can throw exceptions

    Capture a side-effectful block of code that can throw exceptions

    Definition Classes
    AsyncZioIO2
    Annotations
    @inline()
    Note

    sync means synchronous, that is, a blocking CPU effect, as opposed to a non-blocking asynchronous effect or a long blocking I/O effect (izumi.functional.bio.BlockingIO2#syncBlocking)

  113. final def synchronized[T0](arg0: => T0): T0
    Definition Classes
    AnyRef
  114. def tailRecM[E, A, B](a: A)(f: (A) => ZIO[R, E, Either[A, B]]): ZIO[R, E, B]
    Definition Classes
    Monad2
  115. final def tap[E, A](r: ZIO[R, E, A], f: (A) => ZIO[R, E, Unit]): ZIO[R, E, A]
    Definition Classes
    AsyncZioMonad2
    Annotations
    @inline()
  116. final def tapBoth[E, A, E1 >: E](r: ZIO[R, E, A])(err: (E) => ZIO[R, E1, Unit], succ: (A) => ZIO[R, E1, Unit]): ZIO[R, E1, A]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  117. final def tapError[E, A, E1 >: E](r: ZIO[R, E, A])(f: (E) => ZIO[R, E1, Unit]): ZIO[R, E1, A]
    Definition Classes
    AsyncZioError2
    Annotations
    @inline()
  118. final def terminate(v: => Throwable): ZIO[Any, Nothing, Nothing]
    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
  119. final def timeout[E, A](duration: Duration)(r: ZIO[R, E, A]): ZIO[R, E, Option[A]]
    Definition Classes
    TemporalZioTemporal2
    Annotations
    @inline()
  120. final def timeoutFail[E, A](duration: Duration)(e: => E, r: ZIO[R, E, A]): ZIO[R, E, A]
    Definition Classes
    Temporal2
    Annotations
    @inline()
  121. def toString(): String
    Definition Classes
    AnyRef → Any
  122. final def traverse[E, A, B](l: Iterable[A])(f: (A) => ZIO[R, E, B]): ZIO[R, E, List[B]]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  123. final def traverse[E, A, B](o: Option[A])(f: (A) => ZIO[R, E, B]): ZIO[R, E, Option[B]]
    Definition Classes
    Applicative2
    Annotations
    @inline()
  124. def traverseAccumErrors[ColR[x] <: IterableOnce[x], ColL[_], E, A, B](col: ColR[A])(f: (A) => ZIO[R, ColL[E], B])(implicit buildR: Factory[B, ColR[B]], buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], ColR[B]]

    traverse with error accumulation

    traverse with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  125. def traverseAccumErrorsNEList[ColR[x] <: IterableOnce[x], E, A, B](col: ColR[A])(f: (A) => ZIO[R, E, B])(implicit buildR: Factory[B, ColR[B]]): ZIO[R, NEList[E], ColR[B]]

    traverse with error accumulation

    traverse with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  126. def traverseAccumErrors_[ColR[x] <: IterableOnce[x], ColL[_], E, A](col: ColR[A])(f: (A) => ZIO[R, ColL[E], Unit])(implicit buildL: Factory[E, ColL[E]], iterL: (ColL[E]) => IterableOnce[E]): ZIO[R, ColL[E], Unit]

    traverse_ with error accumulation

    traverse_ with error accumulation

    Definition Classes
    ErrorAccumulatingOps2
  127. final def traverse_[E, A](l: Iterable[A])(f: (A) => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  128. final def uninterruptible[E, A](f: ZIO[R, E, A]): ZIO[R, E, A]
    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
  129. final def uninterruptibleExcept[E, A](f: (RestoreInterruption2[[+β$8$, +γ$9$]ZIO[R, β$8$, γ$9$]]) => ZIO[R, E, A]): ZIO[R, E, A]

    Designate the effect uninterruptible, with the exception of regions in it that are specifically marked to restore previous interruptibility status using the provided RestoreInterruption function

    Designate the effect uninterruptible, with the exception of regions in it that are specifically marked to restore previous interruptibility status using the provided RestoreInterruption function

    Definition Classes
    AsyncZioPanic2
    Annotations
    @inline()
    Example:
    1. F.uninterruptibleExcept {
        restoreInterruption =>
          val workLoop = {
            importantWorkThatMustNotBeInterrupted() *>
            log.info("Taking a break for a second, you can interrupt me while I wait!") *>
            restoreInterruption.apply {
              F.sleep(1.second)
               .guaranteeOnInterrupt(_ => log.info("Got interrupted!"))
            } *>
            log.info("No interruptions, going back to work!") *>
            workLoop
          }
      
          workLoop
      }
    Note

    Interruptibility status will be restored to what it was in the outer region, so if the outer region was also uninterruptible, the provided RestoreInterruption will have no effect. e.g. the expression F.uninterruptible { F.uninterruptibleExcept { restore => restore(F.sleep(1.second)) } is fully uninterruptible throughout

  130. final def unit: ZIO[Any, Nothing, Unit]
    Definition Classes
    AsyncZioApplicative2
    Annotations
    @inline()
  131. final def unless[E, E1](cond: ZIO[R, E, Boolean])(ifFalse: => ZIO[R, E1, Unit])(implicit ev: <:<[E, E1]): ZIO[R, E1, Unit]
    Definition Classes
    Monad2
    Annotations
    @inline()
  132. final def unless[E](cond: Boolean)(ifFalse: => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    Applicative2
    Annotations
    @inline()
  133. final def void[E, A](r: ZIO[R, E, A]): ZIO[R, E, Unit]
    Definition Classes
    AsyncZioFunctor2
    Annotations
    @inline()
  134. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  135. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException])
  136. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws(classOf[java.lang.InterruptedException]) @native()
  137. final def when[E, E1](cond: ZIO[R, E, Boolean])(ifTrue: => ZIO[R, E1, Unit])(implicit ev: <:<[E, E1]): ZIO[R, E1, Unit]
    Definition Classes
    Monad2
    Annotations
    @inline()
  138. final def when[E](cond: Boolean)(ifTrue: => ZIO[R, E, Unit]): ZIO[R, E, Unit]
    Definition Classes
    Applicative2
    Annotations
    @inline()
  139. final def widen[E, A, A1](r: ZIO[R, E, A])(implicit ev: <:<[A, A1]): ZIO[R, E, A1]
    Definition Classes
    Functor2
    Annotations
    @inline()
  140. final def widenBoth[E, A, E1, A1](r: ZIO[R, E, A])(implicit ev: <:<[E, E1], ev2: <:<[A, A1]): ZIO[R, E1, A1]
    Definition Classes
    Bifunctor2
    Annotations
    @inline()
  141. final def widenError[E, A, E1](r: ZIO[R, E, A])(implicit ev: <:<[E, E1]): ZIO[R, E1, A]
    Definition Classes
    Bifunctor2
    Annotations
    @inline()
  142. final def withFilter[E, A](r: ZIO[R, E, A])(predicate: (A) => Boolean)(implicit filter: WithFilter[E], pos: SourceFilePositionMaterializer): ZIO[R, E, A]

    for-comprehensions sugar:

    for-comprehensions sugar:

    for {
      (1, 2) <- F.pure((2, 1))
    } yield ()

    Use widenError to for pattern matching with non-Throwable errors:

    val f = for {
      (1, 2) <- F.pure((2, 1)).widenError[Option[Unit]]
    } yield ()
    // f: F[Option[Unit], Unit] = F.fail(Some(())
    Definition Classes
    Error2
    Annotations
    @inline()
  143. final def yieldNow: ZIO[Any, Nothing, Unit]
    Definition Classes
    AsyncZioConcurrent2
    Annotations
    @inline()
  144. def zip[E, A, B](firstOp: ZIO[R, E, A], secondOp: => ZIO[R, E, B]): ZIO[R, E, (A, B)]
    Definition Classes
    Applicative2
  145. final def zipPar[E, A, B](fa: ZIO[R, E, A], fb: ZIO[R, E, B]): ZIO[R, E, (A, B)]

    Returns an effect that executes both effects, in parallel, combining their results into a tuple.

    Returns an effect that executes both effects, in parallel, combining their results into a tuple. If either side fails, then the other side will be interrupted.

    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  146. final def zipParLeft[E, A, B](fa: ZIO[R, E, A], fb: ZIO[R, E, B]): ZIO[R, E, A]

    Returns an effect that executes both effects, in parallel, the left effect result is returned.

    Returns an effect that executes both effects, in parallel, the left effect result is returned. If either side fails, then the other side will be interrupted.

    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  147. final def zipParRight[E, A, B](fa: ZIO[R, E, A], fb: ZIO[R, E, B]): ZIO[R, E, B]

    Returns an effect that executes both effects, in parallel, the right effect result is returned.

    Returns an effect that executes both effects, in parallel, the right effect result is returned. If either side fails, then the other side will be interrupted.

    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()
  148. final def zipWithPar[E, A, B, C](fa: ZIO[R, E, A], fb: ZIO[R, E, B])(f: (A, B) => C): ZIO[R, E, C]

    Returns an effect that executes both effects, in parallel, combining their results with the specified f function.

    Returns an effect that executes both effects, in parallel, combining their results with the specified f function. If either side fails, then the other side will be interrupted.

    Definition Classes
    AsyncZioParallel2
    Annotations
    @inline()

Deprecated Value Members

  1. final def asyncCancelable[E, A](register: ((Either[E, A]) => Unit) => InterruptAction[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]): ZIO[R, E, A]
    Definition Classes
    Async2
    Annotations
    @deprecated
    Deprecated

    (Since version 1.3) renamed to asyncWithOnInterrupt

  2. def suspend[A](effect: => ZIO[R, Throwable, A]): ZIO[R, Throwable, A]
    Definition Classes
    IO2
    Annotations
    @deprecated
    Deprecated

    (Since version 1.3) renamed to suspendThrowable

Inherited from Temporal2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from WeakTemporal2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from TemporalInstances

Inherited from AsyncZio[R]

Inherited from Async2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from WeakAsync2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from IO2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Panic2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from PanicSyntax

Inherited from Bracket2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Error2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from ErrorAccumulatingOps2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Monad2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from ApplicativeError2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Bifunctor2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Guarantee2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Applicative2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Functor2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Concurrent2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from ParallelErrorAccumulatingOps2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Parallel2[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from RootBifunctor[[+β$0$, +γ$1$]ZIO[R, β$0$, γ$1$]]

Inherited from Root

Inherited from PredefinedHelper

Inherited from DivergenceHelper

Inherited from AnyRef

Inherited from Any

Ungrouped