zio

package zio

Type members

Classlikes

object <*>
@implicitNotFound("${A} must not be ${B}")
abstract class =!=[A, B] extends Serializable

Evidence type A is not equal to type B.

Evidence type A is not equal to type B.

Companion:
object
object =!=
Companion:
class
trait Accessible[R]

A simple, macro-less means of creating accessors from Services. Extend the companion object with Accessible[ServiceName], then simply call Companion(_.someMethod), to return a ZIO effect that requires the Service in its environment.

A simple, macro-less means of creating accessors from Services. Extend the companion object with Accessible[ServiceName], then simply call Companion(_.someMethod), to return a ZIO effect that requires the Service in its environment.

Example:

 trait FooService {
   def magicNumber: UIO[Int]
   def castSpell(chant: String): UIO[Boolean]
 }

 object FooService extends Accessible[FooService]

 val example: ZIO[Has[FooService], Nothing, Unit] =
   for {
     int  <- FooService(_.magicNumber)
     bool <- FooService(_.castSpell("Oogabooga!"))
   } yield ()
Companion:
object
object Accessible
Companion:
class
trait App extends BootstrapRuntime

The entry point for a purely-functional application on the JVM.

The entry point for a purely-functional application on the JVM.

import zio.App
import zio.console._

object MyApp extends App {

 final def run(args: List[String]) =
   myAppLogic.exitCode

 def myAppLogic =
   for {
     _ <- putStrLn("Hello! What is your name?")
     n <- getStrLn
     _ <- putStrLn("Hello, " + n + ", good to meet you!")
   } yield ()
}
trait BootstrapRuntime extends Runtime[ZEnv]
case object BuildInfo

This object was generated by sbt-buildinfo.

This object was generated by sbt-buildinfo.

@implicitNotFound("This error handling operation assumes your effect can fail. However, ".+("your effect has Nothing for the error type, which means it cannot ").+("fail, so there is no need to handle the failure. To find out which ").+("method you can use instead of this operation, please see the ").+("reference chart at: https://zio.dev/version-1.x/can_fail"))
sealed abstract class CanFail[-E]

A value of type CanFail[E] provides implicit evidence that an effect with error type E can fail, that is, that E is not equal to Nothing.

A value of type CanFail[E] provides implicit evidence that an effect with error type E can fail, that is, that E is not equal to Nothing.

Companion:
object
object CanFail extends CanFail[Any]
Companion:
class
abstract class CancelableFuture[+A](val future: Future[A]) extends Future[A]
sealed abstract class Cause[+E] extends Product with Serializable
Companion:
object
object Cause extends Serializable
Companion:
class
sealed abstract class Chunk[+A] extends ChunkLike[A]

A Chunk[A] represents a chunk of values of type A. Chunks are designed are usually backed by arrays, but expose a purely functional, safe interface to the underlying elements, and they become lazy on operations that would be costly with arrays, such as repeated concatenation.

A Chunk[A] represents a chunk of values of type A. Chunks are designed are usually backed by arrays, but expose a purely functional, safe interface to the underlying elements, and they become lazy on operations that would be costly with arrays, such as repeated concatenation.

The implementation of balanced concatenation is based on the one for Conc-Trees in "Conc-Trees for Functional and Parallel Programming" by Aleksandar Prokopec and Martin Odersky. http://aleksandar-prokopec.com/resources/docs/lcpc-conc-trees.pdf

NOTE: For performance reasons Chunk does not box primitive types. As a result, it is not safe to construct chunks from heterogeneous primitive types.

Companion:
object
object Chunk
Companion:
class
sealed abstract class ChunkBuilder[A] extends Builder[A, Chunk[A]]

A ChunkBuilder[A] can build a Chunk[A] given elements of type A. ChunkBuilder is a mutable data structure that is implemented to efficiently build chunks of unboxed primitives and for compatibility with the Scala collection library.

A ChunkBuilder[A] can build a Chunk[A] given elements of type A. ChunkBuilder is a mutable data structure that is implemented to efficiently build chunks of unboxed primitives and for compatibility with the Scala collection library.

Companion:
object
Companion:
class

ChunkLike represents the capability for a Chunk to extend Scala's collection library. Because of changes to Scala's collection library in 2.13, separate versions of this trait are implemented for 2.11 / 2.12 and 2.13 / Dotty. This allows code in Chunk to be written without concern for the implementation details of Scala's collection library to the maximum extent possible.

ChunkLike represents the capability for a Chunk to extend Scala's collection library. Because of changes to Scala's collection library in 2.13, separate versions of this trait are implemented for 2.11 / 2.12 and 2.13 / Dotty. This allows code in Chunk to be written without concern for the implementation details of Scala's collection library to the maximum extent possible.

Note that IndexedSeq is not a referentially transparent interface in that it exposes methods that are partial (e.g. apply), allocate mutable state (e.g. iterator), or are purely side effecting (e.g. foreach). Chunk extends IndexedSeq to provide interoperability with Scala's collection library but users should avoid these methods whenever possible.

Companion:
object
object ChunkLike extends SeqFactory[Chunk]
Companion:
class
sealed abstract class ExecutionStrategy

Describes a strategy for evaluating multiple effects, potentially in parallel. There are three possible execution strategies: Sequential, Parallel, and ParallelN.

Describes a strategy for evaluating multiple effects, potentially in parallel. There are three possible execution strategies: Sequential, Parallel, and ParallelN.

Companion:
object
Companion:
class
sealed abstract class Exit[+E, +A] extends Product with Serializable

An Exit[E, A] describes the result of executing an IO value. The result is either succeeded with a value A, or failed with a Cause[E].

An Exit[E, A] describes the result of executing an IO value. The result is either succeeded with a value A, or failed with a Cause[E].

Companion:
object
object Exit extends Serializable
Companion:
class
final case class ExitCode(code: Int)
Companion:
object
object ExitCode
Companion:
class
sealed abstract class Fiber[+E, +A]

A fiber is a lightweight thread of execution that never consumes more than a whole thread (but may consume much less, depending on contention and asynchronicity). Fibers are spawned by forking ZIO effects, which run concurrently with the parent effect.

A fiber is a lightweight thread of execution that never consumes more than a whole thread (but may consume much less, depending on contention and asynchronicity). Fibers are spawned by forking ZIO effects, which run concurrently with the parent effect.

Fibers can be joined, yielding their result to other fibers, or interrupted, which terminates the fiber, safely releasing all resources.

def parallel[A, B](io1: Task[A], io2: Task[B]): Task[(A, B)] =
 for {
   fiber1 <- io1.fork
   fiber2 <- io2.fork
   a      <- fiber1.join
   b      <- fiber2.join
 } yield (a, b)
Companion:
object
object Fiber
Companion:
class
final case class FiberFailure(cause: Cause[Any]) extends Throwable

Represents a failure in a fiber. This could be caused by some non- recoverable error, such as a defect or system error, by some typed error, or by interruption (or combinations of all of the above).

Represents a failure in a fiber. This could be caused by some non- recoverable error, such as a defect or system error, by some typed error, or by interruption (or combinations of all of the above).

This class is used to wrap ZIO failures into something that can be thrown, to better integrate with Scala exception handling.

final class FiberRef[A] extends Serializable

Fiber's counterpart for Java's ThreadLocal. Value is automatically propagated to child on fork and merged back in after joining child.

Fiber's counterpart for Java's ThreadLocal. Value is automatically propagated to child on fork and merged back in after joining child.

for {
 fiberRef <- FiberRef.make("Hello world!")
 child <- fiberRef.set("Hi!).fork
 result <- child.join
} yield result

result will be equal to "Hi!" as changes done by child were merged on join.

FiberRef#make also allows specifying how the values will be combined when joining. By default this will use the value of the joined fiber.

for {
 fiberRef <- FiberRef.make(0, math.max)
 child    <- fiberRef.update(_ + 1).fork
 _        <- fiberRef.update(_ + 2)
 _        <- child.join
 value    <- fiberRef.get
} yield value

value will be 2 as the value in the joined fiber is lower and we specified max as our combine function.

Companion:
object
object FiberRef extends Serializable
Companion:
class
final class Has[A] extends Serializable

The trait Has[A] is used with ZIO environment to express an effect's dependency on a service of type A. For example, RIO[Has[Console.Service], Unit] is an effect that requires a Console.Service service. Inside the ZIO library, type aliases are provided as shorthands for common services, e.g.:

The trait Has[A] is used with ZIO environment to express an effect's dependency on a service of type A. For example, RIO[Has[Console.Service], Unit] is an effect that requires a Console.Service service. Inside the ZIO library, type aliases are provided as shorthands for common services, e.g.:

type Console = Has[ConsoleService]

Services parameterized on path dependent types are not supported.

Companion:
object
object Has
Companion:
class
object IO
sealed abstract class InterruptStatus(val isInterruptible: Boolean) extends Serializable with Product

The InterruptStatus of a fiber determines whether or not it can be interrupted. The status can change over time in different regions.

The InterruptStatus of a fiber determines whether or not it can be interrupted. The status can change over time in different regions.

Companion:
object
Companion:
class
@implicitNotFound("This operation assumes that your effect requires an environment. ".+("However, your effect has Any for the environment type, which means it ").+("has no requirement, so there is no need to provide the environment."))
sealed abstract class NeedsEnv[+R] extends Serializable

A value of type NeedsEnv[R] provides implicit evidence that an effect with environment type R needs an environment, that is, that R is not equal to Any.

A value of type NeedsEnv[R] provides implicit evidence that an effect with environment type R needs an environment, that is, that R is not equal to Any.

Companion:
object
object NeedsEnv extends NeedsEnv[Nothing]
Companion:
class
final class NonEmptyChunk[+A]

A NonEmptyChunk is a Chunk that is guaranteed to contain at least one element. As a result, operations which would not be safe when performed on Chunk, such as head or reduce, are safe when performed on NonEmptyChunk. Operations on NonEmptyChunk which could potentially return an empty chunk will return a Chunk instead.

A NonEmptyChunk is a Chunk that is guaranteed to contain at least one element. As a result, operations which would not be safe when performed on Chunk, such as head or reduce, are safe when performed on NonEmptyChunk. Operations on NonEmptyChunk which could potentially return an empty chunk will return a Chunk instead.

Companion:
object
Companion:
class
final class Promise[E, A] extends Serializable

A promise represents an asynchronous variable, of zio.IO type, that can be set exactly once, with the ability for an arbitrary number of fibers to suspend (by calling await) and automatically resume when the variable is set.

A promise represents an asynchronous variable, of zio.IO type, that can be set exactly once, with the ability for an arbitrary number of fibers to suspend (by calling await) and automatically resume when the variable is set.

Promises can be used for building primitive actions whose completions require the coordinated action of multiple fibers, and for building higher-level concurrent or asynchronous structures.

for {
 promise <- Promise.make[Nothing, Int]
 _       <- promise.succeed(42).delay(1.second).fork
 value   <- promise.await // Resumes when forked fiber completes promise
} yield value
Companion:
object
object Promise
Companion:
class
object Queue
object RIO
object Ref extends Serializable
object RefM
final case class Reservation[-R, +E, +A](acquire: ZIO[R, E, A], release: Exit[Any, Any] => URIO[R, Any])

A Reservation[-R, +E, +A] encapsulates resource acquisition and disposal without specifying when or how that resource might be used.

A Reservation[-R, +E, +A] encapsulates resource acquisition and disposal without specifying when or how that resource might be used.

See ZManaged#reserve and ZIO#reserve for details of usage.

trait Runtime[+R]

A Runtime[R] is capable of executing tasks within an environment R.

A Runtime[R] is capable of executing tasks within an environment R.

Companion:
object
object Runtime
Companion:
class
sealed abstract class Schedule[-Env, -In, +Out] extends Serializable

A Schedule[Env, In, Out] defines a recurring schedule, which consumes values of type In, and which returns values of type Out.

A Schedule[Env, In, Out] defines a recurring schedule, which consumes values of type In, and which returns values of type Out.

Schedules are defined as a possibly infinite set of intervals spread out over time. Each interval defines a window in which recurrence is possible.

When schedules are used to repeat or retry effects, the starting boundary of each interval produced by a schedule is used as the moment when the effect will be executed again.

Schedules compose in the following primary ways:

  • Union. This performs the union of the intervals of two schedules. * Intersection. This performs the intersection of the intervals of two schedules. * Sequence. This concatenates the intervals of one schedule onto another.

In addition, schedule inputs and outputs can be transformed, filtered (to terminate a schedule early in response to some input or output), and so forth.

A variety of other operators exist for transforming and combining schedules, and the companion object for Schedule contains all common types of schedules, both for performing retrying, as well as performing repetition.

Companion:
object
object Schedule
Companion:
class
final class Semaphore extends Serializable

An asynchronous semaphore, which is a generalization of a mutex. Semaphores have a certain number of permits, which can be held and released concurrently by different parties. Attempts to acquire more permits than available result in the acquiring fiber being suspended until the specified number of permits become available.

An asynchronous semaphore, which is a generalization of a mutex. Semaphores have a certain number of permits, which can be held and released concurrently by different parties. Attempts to acquire more permits than available result in the acquiring fiber being suspended until the specified number of permits become available.

Companion:
object
object Semaphore extends Serializable
Companion:
class
abstract class Supervisor[+A]

A Supervisor[A] is allowed to supervise the launching and termination of fibers, producing some visible value of type A from the supervision.

A Supervisor[A] is allowed to supervise the launching and termination of fibers, producing some visible value of type A from the supervision.

Companion:
object
object Supervisor
Companion:
class
object Task
Companion:
object
Companion:
class
sealed abstract class TracingStatus extends Serializable with Product

Whether ZIO Tracing is enabled for the current fiber in the current region.

Whether ZIO Tracing is enabled for the current fiber in the current region.

Companion:
object
Companion:
class
object UIO
object URIO
trait Unzippable[A, B]
Companion:
object
Companion:
class
sealed abstract class ZHub[-RA, -RB, +EA, +EB, -A, +B] extends Serializable

A ZHub[RA, RB, EA, EB, A, B] is an asynchronous message hub. Publishers can publish messages of type A to the hub and subscribers can subscribe to take messages of type B from the hub. Publishing messages can require an environment of type RA and fail with an error of type EA. Taking messages can require an environment of type RB and fail with an error of type EB.

A ZHub[RA, RB, EA, EB, A, B] is an asynchronous message hub. Publishers can publish messages of type A to the hub and subscribers can subscribe to take messages of type B from the hub. Publishing messages can require an environment of type RA and fail with an error of type EA. Taking messages can require an environment of type RB and fail with an error of type EB.

Companion:
object
object ZHub
Companion:
class
sealed trait ZIO[-R, +E, +A] extends Serializable

A ZIO[R, E, A] value is an immutable value that lazily describes a workflow or job. The workflow requires some environment R, and may fail with an error of type E, or succeed with a value of type A.

A ZIO[R, E, A] value is an immutable value that lazily describes a workflow or job. The workflow requires some environment R, and may fail with an error of type E, or succeed with a value of type A.

These lazy workflows, referred to as effects, can be informally thought of as functions in the form:

R => Either[E, A]

ZIO effects model resourceful interaction with the outside world, including synchronous, asynchronous, concurrent, and parallel interaction.

ZIO effects use a fiber-based concurrency model, with built-in support for scheduling, fine-grained interruption, structured concurrency, and high scalability.

To run an effect, you need a Runtime, which is capable of executing effects. Runtimes bundle a thread pool together with the environment that effects need.

Companion:
object
object ZIO
Companion:
class
abstract class ZInputStream
Companion:
object
Companion:
class
sealed abstract class ZLayer[-RIn, +E, +ROut]

A ZLayer[A, E, B] describes a layer of an application: every layer in an application requires some services (the input) and produces some services (the output).

A ZLayer[A, E, B] describes a layer of an application: every layer in an application requires some services (the input) and produces some services (the output).

Layers can be thought of as recipes for producing bundles of services, given their dependencies (other services).

Construction of layers can be effectful and utilize resources that must be acquired and safely released when the services are done being utilized.

By default layers are shared, meaning that if the same layer is used twice the layer will only be allocated a single time.

Because of their excellent composition properties, layers are the idiomatic way in ZIO to create services that depend on other services.

Companion:
object
object ZLayer
Companion:
class
sealed abstract class ZManaged[-R, +E, +A] extends Serializable

A ZManaged[R, E, A] is a managed resource of type A, which may be used by invoking the use method of the resource. The resource will be automatically acquired before the resource is used, and automatically released after the resource is used.

A ZManaged[R, E, A] is a managed resource of type A, which may be used by invoking the use method of the resource. The resource will be automatically acquired before the resource is used, and automatically released after the resource is used.

Resources do not survive the scope of use, meaning that if you attempt to capture the resource, leak it from use, and then use it after the resource has been consumed, the resource will not be valid anymore and may fail with some checked error, as per the type of the functions provided by the resource.

Companion:
object
object ZManaged
Companion:
class
abstract class ZOutputStream
Companion:
object
Companion:
class
trait ZPool[+E, Item]

A ZPool[E, A] is a pool of items of type A, each of which may be associated with the acquisition and release of resources. An attempt to get an item A from a pool may fail with an error of type E.

A ZPool[E, A] is a pool of items of type A, each of which may be associated with the acquisition and release of resources. An attempt to get an item A from a pool may fail with an error of type E.

Companion:
object
object ZPool
Companion:
class
abstract class ZQueue[-RA, -RB, +EA, +EB, -A, +B] extends Serializable

A ZQueue[RA, RB, EA, EB, A, B] is a lightweight, asynchronous queue into which values of type A can be enqueued and of which elements of type B can be dequeued. The queue's enqueueing operations may utilize an environment of type RA and may fail with errors of type EA. The dequeueing operations may utilize an environment of type RB and may fail with errors of type EB.

A ZQueue[RA, RB, EA, EB, A, B] is a lightweight, asynchronous queue into which values of type A can be enqueued and of which elements of type B can be dequeued. The queue's enqueueing operations may utilize an environment of type RA and may fail with errors of type EA. The dequeueing operations may utilize an environment of type RB and may fail with errors of type EB.

Companion:
object
object ZQueue
Companion:
class
sealed abstract class ZRef[+EA, +EB, -A, +B] extends Serializable

A ZRef[EA, EB, A, B] is a polymorphic, purely functional description of a mutable reference. The fundamental operations of a ZRef are set and get. set takes a value of type A and sets the reference to a new value, potentially failing with an error of type EA. get gets the current value of the reference and returns a value of type B, potentially failing with an error of type EB.

A ZRef[EA, EB, A, B] is a polymorphic, purely functional description of a mutable reference. The fundamental operations of a ZRef are set and get. set takes a value of type A and sets the reference to a new value, potentially failing with an error of type EA. get gets the current value of the reference and returns a value of type B, potentially failing with an error of type EB.

When the error and value types of the ZRef are unified, that is, it is a ZRef[E, E, A, A], the ZRef also supports atomic modify and update operations. All operations are guaranteed to be safe for concurrent access.

NOTE: While ZRef provides the functional equivalent of a mutable reference, the value inside the ZRef should be immutable. For performance reasons ZRef is implemented in terms of compare and swap operations rather than synchronization. These operations are not safe for mutable values that do not support concurrent access.

Companion:
object
object ZRef extends Serializable
Companion:
class
sealed abstract class ZRefM[-RA, -RB, +EA, +EB, -A, +B]

A ZRefM[RA, RB, EA, EB, A, B] is a polymorphic, purely functional description of a mutable reference. The fundamental operations of a ZRefM are set and get. set takes a value of type A and sets the reference to a new value, requiring an environment of type RA and potentially failing with an error of type EA. get gets the current value of the reference and returns a value of type B, requiring an environment of type RB and potentially failing with an error of type EB.

A ZRefM[RA, RB, EA, EB, A, B] is a polymorphic, purely functional description of a mutable reference. The fundamental operations of a ZRefM are set and get. set takes a value of type A and sets the reference to a new value, requiring an environment of type RA and potentially failing with an error of type EA. get gets the current value of the reference and returns a value of type B, requiring an environment of type RB and potentially failing with an error of type EB.

When the error and value types of the ZRefM are unified, that is, it is a ZRefM[E, E, A, A], the ZRefM also supports atomic modify and update operations.

Unlike ZRef, ZRefM allows performing effects within update operations, at some cost to performance. Writes will semantically block other writers, while multiple readers can read simultaneously.

Companion:
object
object ZRefM
Companion:
class
sealed abstract class ZScope[+A]

A ZScope[A] is a value that allows adding finalizers identified by a key. Scopes are closed with a value of type A, which is provided to all the finalizers when the scope is released.

A ZScope[A] is a value that allows adding finalizers identified by a key. Scopes are closed with a value of type A, which is provided to all the finalizers when the scope is released.

For safety reasons, this interface has no method to close a scope. Rather, an open scope may be required with ZScope.make, which returns a function that can close a scope. This allows scopes to be safely passed around without fear they will be accidentally closed.

Companion:
object
object ZScope
Companion:
class
final case class ZTrace(fiberId: Id, executionTrace: List[ZTraceElement], stackTrace: List[ZTraceElement], parentTrace: Option[ZTrace])
Companion:
object
object ZTrace
Companion:
class
trait Zippable[-A, -B]
Companion:
object
Companion:
class

Inherited classlikes

final implicit class Function0ToLayerSyntax[A](self: () => A)(implicit evidence$1: Tag[A])
Inherited from:
FunctionToLayerOps
final implicit class Function10ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K](self: (A, B, C, D, E, F, G, H, I, J) => K)(implicit evidence$56: Tag[A], evidence$57: Tag[B], evidence$58: Tag[C], evidence$59: Tag[D], evidence$60: Tag[E], evidence$61: Tag[F], evidence$62: Tag[G], evidence$63: Tag[H], evidence$64: Tag[I], evidence$65: Tag[J], evidence$66: Tag[K])
Inherited from:
FunctionToLayerOps
final implicit class Function11ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L](self: (A, B, C, D, E, F, G, H, I, J, K) => L)(implicit evidence$67: Tag[A], evidence$68: Tag[B], evidence$69: Tag[C], evidence$70: Tag[D], evidence$71: Tag[E], evidence$72: Tag[F], evidence$73: Tag[G], evidence$74: Tag[H], evidence$75: Tag[I], evidence$76: Tag[J], evidence$77: Tag[K], evidence$78: Tag[L])
Inherited from:
FunctionToLayerOps
final implicit class Function12ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M](self: (A, B, C, D, E, F, G, H, I, J, K, L) => M)(implicit evidence$79: Tag[A], evidence$80: Tag[B], evidence$81: Tag[C], evidence$82: Tag[D], evidence$83: Tag[E], evidence$84: Tag[F], evidence$85: Tag[G], evidence$86: Tag[H], evidence$87: Tag[I], evidence$88: Tag[J], evidence$89: Tag[K], evidence$90: Tag[L], evidence$91: Tag[M])
Inherited from:
FunctionToLayerOps
final implicit class Function13ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N](self: (A, B, C, D, E, F, G, H, I, J, K, L, M) => N)(implicit evidence$92: Tag[A], evidence$93: Tag[B], evidence$94: Tag[C], evidence$95: Tag[D], evidence$96: Tag[E], evidence$97: Tag[F], evidence$98: Tag[G], evidence$99: Tag[H], evidence$100: Tag[I], evidence$101: Tag[J], evidence$102: Tag[K], evidence$103: Tag[L], evidence$104: Tag[M], evidence$105: Tag[N])
Inherited from:
FunctionToLayerOps
final implicit class Function14ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N) => O)(implicit evidence$106: Tag[A], evidence$107: Tag[B], evidence$108: Tag[C], evidence$109: Tag[D], evidence$110: Tag[E], evidence$111: Tag[F], evidence$112: Tag[G], evidence$113: Tag[H], evidence$114: Tag[I], evidence$115: Tag[J], evidence$116: Tag[K], evidence$117: Tag[L], evidence$118: Tag[M], evidence$119: Tag[N], evidence$120: Tag[O])
Inherited from:
FunctionToLayerOps
final implicit class Function15ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O) => P)(implicit evidence$121: Tag[A], evidence$122: Tag[B], evidence$123: Tag[C], evidence$124: Tag[D], evidence$125: Tag[E], evidence$126: Tag[F], evidence$127: Tag[G], evidence$128: Tag[H], evidence$129: Tag[I], evidence$130: Tag[J], evidence$131: Tag[K], evidence$132: Tag[L], evidence$133: Tag[M], evidence$134: Tag[N], evidence$135: Tag[O], evidence$136: Tag[P])
Inherited from:
FunctionToLayerOps
final implicit class Function16ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P) => Q)(implicit evidence$137: Tag[A], evidence$138: Tag[B], evidence$139: Tag[C], evidence$140: Tag[D], evidence$141: Tag[E], evidence$142: Tag[F], evidence$143: Tag[G], evidence$144: Tag[H], evidence$145: Tag[I], evidence$146: Tag[J], evidence$147: Tag[K], evidence$148: Tag[L], evidence$149: Tag[M], evidence$150: Tag[N], evidence$151: Tag[O], evidence$152: Tag[P], evidence$153: Tag[Q])
Inherited from:
FunctionToLayerOps
final implicit class Function17ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q) => R)(implicit evidence$154: Tag[A], evidence$155: Tag[B], evidence$156: Tag[C], evidence$157: Tag[D], evidence$158: Tag[E], evidence$159: Tag[F], evidence$160: Tag[G], evidence$161: Tag[H], evidence$162: Tag[I], evidence$163: Tag[J], evidence$164: Tag[K], evidence$165: Tag[L], evidence$166: Tag[M], evidence$167: Tag[N], evidence$168: Tag[O], evidence$169: Tag[P], evidence$170: Tag[Q], evidence$171: Tag[R])
Inherited from:
FunctionToLayerOps
final implicit class Function18ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R) => S)(implicit evidence$172: Tag[A], evidence$173: Tag[B], evidence$174: Tag[C], evidence$175: Tag[D], evidence$176: Tag[E], evidence$177: Tag[F], evidence$178: Tag[G], evidence$179: Tag[H], evidence$180: Tag[I], evidence$181: Tag[J], evidence$182: Tag[K], evidence$183: Tag[L], evidence$184: Tag[M], evidence$185: Tag[N], evidence$186: Tag[O], evidence$187: Tag[P], evidence$188: Tag[Q], evidence$189: Tag[R], evidence$190: Tag[S])
Inherited from:
FunctionToLayerOps
final implicit class Function19ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S) => T)(implicit evidence$191: Tag[A], evidence$192: Tag[B], evidence$193: Tag[C], evidence$194: Tag[D], evidence$195: Tag[E], evidence$196: Tag[F], evidence$197: Tag[G], evidence$198: Tag[H], evidence$199: Tag[I], evidence$200: Tag[J], evidence$201: Tag[K], evidence$202: Tag[L], evidence$203: Tag[M], evidence$204: Tag[N], evidence$205: Tag[O], evidence$206: Tag[P], evidence$207: Tag[Q], evidence$208: Tag[R], evidence$209: Tag[S], evidence$210: Tag[T])
Inherited from:
FunctionToLayerOps
final implicit class Function1ToLayerSyntax[A, B](self: A => B)(implicit evidence$2: Tag[A], evidence$3: Tag[B])
Inherited from:
FunctionToLayerOps
final implicit class Function20ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T) => U)(implicit evidence$211: Tag[A], evidence$212: Tag[B], evidence$213: Tag[C], evidence$214: Tag[D], evidence$215: Tag[E], evidence$216: Tag[F], evidence$217: Tag[G], evidence$218: Tag[H], evidence$219: Tag[I], evidence$220: Tag[J], evidence$221: Tag[K], evidence$222: Tag[L], evidence$223: Tag[M], evidence$224: Tag[N], evidence$225: Tag[O], evidence$226: Tag[P], evidence$227: Tag[Q], evidence$228: Tag[R], evidence$229: Tag[S], evidence$230: Tag[T], evidence$231: Tag[U])
Inherited from:
FunctionToLayerOps
final implicit class Function21ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U, V](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U) => V)(implicit evidence$232: Tag[A], evidence$233: Tag[B], evidence$234: Tag[C], evidence$235: Tag[D], evidence$236: Tag[E], evidence$237: Tag[F], evidence$238: Tag[G], evidence$239: Tag[H], evidence$240: Tag[I], evidence$241: Tag[J], evidence$242: Tag[K], evidence$243: Tag[L], evidence$244: Tag[M], evidence$245: Tag[N], evidence$246: Tag[O], evidence$247: Tag[P], evidence$248: Tag[Q], evidence$249: Tag[R], evidence$250: Tag[S], evidence$251: Tag[T], evidence$252: Tag[U], evidence$253: Tag[V])
Inherited from:
FunctionToLayerOps
final implicit class Function2ToLayerSyntax[A, B, C](self: (A, B) => C)(implicit evidence$4: Tag[A], evidence$5: Tag[B], evidence$6: Tag[C])
Inherited from:
FunctionToLayerOps
final implicit class Function3ToLayerSyntax[A, B, C, D](self: (A, B, C) => D)(implicit evidence$7: Tag[A], evidence$8: Tag[B], evidence$9: Tag[C], evidence$10: Tag[D])
Inherited from:
FunctionToLayerOps
final implicit class Function4ToLayerSyntax[A, B, C, D, E](self: (A, B, C, D) => E)(implicit evidence$11: Tag[A], evidence$12: Tag[B], evidence$13: Tag[C], evidence$14: Tag[D], evidence$15: Tag[E])
Inherited from:
FunctionToLayerOps
final implicit class Function5ToLayerSyntax[A, B, C, D, E, F](self: (A, B, C, D, E) => F)(implicit evidence$16: Tag[A], evidence$17: Tag[B], evidence$18: Tag[C], evidence$19: Tag[D], evidence$20: Tag[E], evidence$21: Tag[F])
Inherited from:
FunctionToLayerOps
final implicit class Function6ToLayerSyntax[A, B, C, D, E, F, G](self: (A, B, C, D, E, F) => G)(implicit evidence$22: Tag[A], evidence$23: Tag[B], evidence$24: Tag[C], evidence$25: Tag[D], evidence$26: Tag[E], evidence$27: Tag[F], evidence$28: Tag[G])
Inherited from:
FunctionToLayerOps
final implicit class Function7ToLayerSyntax[A, B, C, D, E, F, G, H](self: (A, B, C, D, E, F, G) => H)(implicit evidence$29: Tag[A], evidence$30: Tag[B], evidence$31: Tag[C], evidence$32: Tag[D], evidence$33: Tag[E], evidence$34: Tag[F], evidence$35: Tag[G], evidence$36: Tag[H])
Inherited from:
FunctionToLayerOps
final implicit class Function8ToLayerSyntax[A, B, C, D, E, F, G, H, I](self: (A, B, C, D, E, F, G, H) => I)(implicit evidence$37: Tag[A], evidence$38: Tag[B], evidence$39: Tag[C], evidence$40: Tag[D], evidence$41: Tag[E], evidence$42: Tag[F], evidence$43: Tag[G], evidence$44: Tag[H], evidence$45: Tag[I])
Inherited from:
FunctionToLayerOps
final implicit class Function9ToLayerSyntax[A, B, C, D, E, F, G, H, I, J](self: (A, B, C, D, E, F, G, H, I) => J)(implicit evidence$46: Tag[A], evidence$47: Tag[B], evidence$48: Tag[C], evidence$49: Tag[D], evidence$50: Tag[E], evidence$51: Tag[F], evidence$52: Tag[G], evidence$53: Tag[H], evidence$54: Tag[I], evidence$55: Tag[J])
Inherited from:
FunctionToLayerOps
object ZEnv
Inherited from:
PlatformSpecific

Types

type Canceler[-R] = URIO[R, Any]
type Dequeue[+A] = ZQueue[Nothing, Any, Any, Nothing, Nothing, A]
type ERef[+E, A] = ZRef[E, E, A, A]
type ERefM[+E, A] = ZRefM[Any, Any, E, E, A, A]
type Enqueue[-A] = ZQueue[Any, Nothing, Nothing, Any, A, Any]
type Hub[A] = ZHub[Any, Any, Nothing, Nothing, A, A]
type IO[+E, +A] = ZIO[Any, E, A]
type Layer[+E, +ROut] = ZLayer[Any, E, ROut]
type Managed[+E, +A] = ZManaged[Any, E, A]
type Queue[A] = ZQueue[Any, Any, Nothing, Nothing, A, A]
type RIO[-R, +A] = ZIO[R, Throwable, A]
type RLayer[-RIn, +ROut] = ZLayer[RIn, Throwable, ROut]
type RManaged[-R, +A] = ZManaged[R, Throwable, A]
type Ref[A] = ZRef[Nothing, Nothing, A, A]
type RefM[A] = ZRefM[Any, Any, Nothing, Nothing, A, A]
type Task[+A] = ZIO[Any, Throwable, A]
type TaskLayer[+ROut] = ZLayer[Any, Throwable, ROut]
type TaskManaged[+A] = ZManaged[Any, Throwable, A]
type UIO[+A] = ZIO[Any, Nothing, A]
type ULayer[+ROut] = ZLayer[Any, Nothing, ROut]
type UManaged[+A] = ZManaged[Any, Nothing, A]
type URIO[-R, +A] = ZIO[R, Nothing, A]
type URLayer[-RIn, +ROut] = ZLayer[RIn, Nothing, ROut]
type URManaged[-R, +A] = ZManaged[R, Nothing, A]
type ZDequeue[-R, +E, +A] = ZQueue[Nothing, R, Any, E, Nothing, A]

A queue that can only be dequeued.

A queue that can only be dequeued.

type ZEnqueue[-R, +E, -A] = ZQueue[R, Nothing, E, Any, A, Any]

A queue that can only be enqueued.

A queue that can only be enqueued.

Inherited types

type BuildFrom[-From, -A, +C] = BuildFrom[From, A, C]
Inherited from:
BuildFromCompat
Inherited from:
VersionSpecific
type Tag[A] = Tag[A]
Inherited from:
VersionSpecific
type TagK[F[_]] = Tag[F]
Inherited from:
VersionSpecific
type TagK10[F[_, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK11[F[_, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK12[F[_, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK13[F[_, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK14[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK15[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK16[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK17[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK18[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK19[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK20[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK21[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK22[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK3[F[_, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK4[F[_, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK5[F[_, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK6[F[_, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK7[F[_, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK8[F[_, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagK9[F[_, _, _, _, _, _, _, _, _]] = Tag[F]
Inherited from:
VersionSpecific
type TagKK[F[_, _]] = Tag[F]
Inherited from:
VersionSpecific
Inherited from:
PlatformSpecific

Deprecated and Inherited types

@deprecated("use Tag", "1.0.0")
type Tagged[A] = Tag[A]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK", "1.0.0")
type TaggedF[F[_]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK10", "1.0.0")
type TaggedF10[F[_, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK11", "1.0.0")
type TaggedF11[F[_, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK12", "1.0.0")
type TaggedF12[F[_, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK13", "1.0.0")
type TaggedF13[F[_, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK14", "1.0.0")
type TaggedF14[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK15", "1.0.0")
type TaggedF15[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK16", "1.0.0")
type TaggedF16[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK17", "1.0.0")
type TaggedF17[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK18", "1.0.0")
type TaggedF18[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK19", "1.0.0")
type TaggedF19[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagKK", "1.0.0")
type TaggedF2[F[_, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK20", "1.0.0")
type TaggedF20[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK21", "1.0.0")
type TaggedF21[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK22", "1.0.0")
type TaggedF22[F[_, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK3", "1.0.0")
type TaggedF3[F[_, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK4", "1.0.0")
type TaggedF4[F[_, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK5", "1.0.0")
type TaggedF5[F[_, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK6", "1.0.0")
type TaggedF6[F[_, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK7", "1.0.0")
type TaggedF7[F[_, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK8", "1.0.0")
type TaggedF8[F[_, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use TagK9", "1.0.0")
type TaggedF9[F[_, _, _, _, _, _, _, _, _]] = Tag[F]
Deprecated
Inherited from:
VersionSpecific
@deprecated("use LightTypeTag", "1.0.0")
Deprecated
Inherited from:
VersionSpecific

Value members

Deprecated and Inherited methods

@deprecated("Use BuildFrom.buildFromIterableOps or buildFromNothing instead", "1.0.6")
def buildFromAny[Element, Collection <: ([Element] =>> Iterable[Element] & IterableOps[Any, LazyRef(...), Any])]: BuildFrom[Collection[Any], Element, Collection[Element]]
Deprecated
Inherited from:
BuildFromCompat

Concrete fields

val Hub: ZHub.type
val Managed: ZManaged.type

Inherited fields

lazy val Tag: Tag.type
Inherited from:
VersionSpecific
lazy val TagK: TagK.type
Inherited from:
VersionSpecific
lazy val TagK3: TagK3.type
Inherited from:
VersionSpecific
lazy val TagKK: TagKK.type
Inherited from:
VersionSpecific

Implicits

Inherited implicits

final implicit def Function0ToLayerSyntax[A : Tag](self: () => A): Function0ToLayerSyntax[A]
Inherited from:
FunctionToLayerOps
final implicit def Function10ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag](self: (A, B, C, D, E, F, G, H, I, J) => K): Function10ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K]
Inherited from:
FunctionToLayerOps
final implicit def Function11ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag](self: (A, B, C, D, E, F, G, H, I, J, K) => L): Function11ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L]
Inherited from:
FunctionToLayerOps
final implicit def Function12ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L) => M): Function12ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M]
Inherited from:
FunctionToLayerOps
final implicit def Function13ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M) => N): Function13ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N]
Inherited from:
FunctionToLayerOps
final implicit def Function14ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N) => O): Function14ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O]
Inherited from:
FunctionToLayerOps
final implicit def Function15ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O) => P): Function15ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P]
Inherited from:
FunctionToLayerOps
final implicit def Function16ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P) => Q): Function16ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q]
Inherited from:
FunctionToLayerOps
final implicit def Function17ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag, R : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q) => R): Function17ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R]
Inherited from:
FunctionToLayerOps
final implicit def Function18ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag, R : Tag, S : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R) => S): Function18ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S]
Inherited from:
FunctionToLayerOps
final implicit def Function19ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag, R : Tag, S : Tag, T : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S) => T): Function19ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T]
Inherited from:
FunctionToLayerOps
final implicit def Function1ToLayerSyntax[A : Tag, B : Tag](self: A => B): Function1ToLayerSyntax[A, B]
Inherited from:
FunctionToLayerOps
final implicit def Function20ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag, R : Tag, S : Tag, T : Tag, U : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T) => U): Function20ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U]
Inherited from:
FunctionToLayerOps
final implicit def Function21ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag, K : Tag, L : Tag, M : Tag, N : Tag, O : Tag, P : Tag, Q : Tag, R : Tag, S : Tag, T : Tag, U : Tag, V : Tag](self: (A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U) => V): Function21ToLayerSyntax[A, B, C, D, E, F, G, H, I, J, K, L, M, N, O, P, Q, R, S, T, U, V]
Inherited from:
FunctionToLayerOps
final implicit def Function2ToLayerSyntax[A : Tag, B : Tag, C : Tag](self: (A, B) => C): Function2ToLayerSyntax[A, B, C]
Inherited from:
FunctionToLayerOps
final implicit def Function3ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag](self: (A, B, C) => D): Function3ToLayerSyntax[A, B, C, D]
Inherited from:
FunctionToLayerOps
final implicit def Function4ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag](self: (A, B, C, D) => E): Function4ToLayerSyntax[A, B, C, D, E]
Inherited from:
FunctionToLayerOps
final implicit def Function5ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag](self: (A, B, C, D, E) => F): Function5ToLayerSyntax[A, B, C, D, E, F]
Inherited from:
FunctionToLayerOps
final implicit def Function6ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag](self: (A, B, C, D, E, F) => G): Function6ToLayerSyntax[A, B, C, D, E, F, G]
Inherited from:
FunctionToLayerOps
final implicit def Function7ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag](self: (A, B, C, D, E, F, G) => H): Function7ToLayerSyntax[A, B, C, D, E, F, G, H]
Inherited from:
FunctionToLayerOps
final implicit def Function8ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag](self: (A, B, C, D, E, F, G, H) => I): Function8ToLayerSyntax[A, B, C, D, E, F, G, H, I]
Inherited from:
FunctionToLayerOps
final implicit def Function9ToLayerSyntax[A : Tag, B : Tag, C : Tag, D : Tag, E : Tag, F : Tag, G : Tag, H : Tag, I : Tag, J : Tag](self: (A, B, C, D, E, F, G, H, I) => J): Function9ToLayerSyntax[A, B, C, D, E, F, G, H, I, J]
Inherited from:
FunctionToLayerOps
implicit def buildFromNothing[A, Collection <: ([Element] =>> Iterable[Element] & IterableOps[A, LazyRef(...), _])]: BuildFrom[Collection[A], Nothing, Collection[Nothing]]
Inherited from:
BuildFromCompat