Trait/Object

cats.effect

Concurrent

Related Docs: object Concurrent | package effect

Permalink

trait Concurrent[F[_]] extends Async[F] with Serializable

Type class for Async data types that are cancelable and can be started concurrently.

Thus this type class allows abstracting over data types that:

  1. implement the Async algebra, with all its restrictions
  2. can provide logic for cancellation, to be used in race conditions in order to release resources early (in its cancelable builder)

Due to these restrictions, this type class also affords to describe a start operation that can start async processing, suspended in the context of F[_] and that can be canceled or joined.

Without cancellation being baked in, we couldn't afford to do it. See below.

Cancelable builder

The signature exposed by the cancelable builder is this:

(Either[Throwable, A] => Unit) => IO[Unit]

IO[Unit] is used to represent a cancellation action which will send a signal to the producer, that may observe it and cancel the asynchronous process.

On Cancellation

Simple asynchronous processes, like Scala's Future, can be described with this very basic and side-effectful type and you should recognize what is more or less the signature of Future#onComplete or of Async.async (minus the error handling):

(A => Unit) => Unit

But many times the abstractions built to deal with asynchronous tasks can also provide a way to cancel such processes, to be used in race conditions in order to cleanup resources early, so a very basic and side-effectful definition of asynchronous processes that can be canceled would be:

(A => Unit) => Cancelable

This is approximately the signature of JavaScript's setTimeout, which will return a "task ID" that can be used to cancel it. Or of Java's ScheduledExecutorService#schedule, which will return a Java ScheduledFuture that has a .cancel() operation on it.

Similarly, for Concurrent data types, we can provide cancellation logic, that can be triggered in race conditions to cancel the on-going processing, only that Concurrent's cancelable token is an action suspended in an IO[Unit]. See IO.cancelable.

Suppose you want to describe a "sleep" operation, like that described by Timer to mirror Java's ScheduledExecutorService.schedule or JavaScript's setTimeout:

def sleep(d: FiniteDuration): F[Unit]

This signature is in fact incomplete for data types that are not cancelable, because such equivalent operations always return some cancellation token that can be used to trigger a forceful interruption of the timer. This is not a normal "dispose" or "finally" clause in a try/catch block, because "cancel" in the context of an asynchronous process is concurrent with the task's own run-loop.

To understand what this means, consider that in the case of our sleep as described above, on cancellation we'd need a way to signal to the underlying ScheduledExecutorService to forcefully remove the scheduled Runnable from its internal queue of scheduled tasks, before its execution. Therefore, without a cancelable data type, a safe signature needs to return a cancellation token, so it would look like this:

def sleep(d: FiniteDuration): F[(F[Unit], F[Unit])]

This function is returning a tuple, with one F[Unit] to wait for the completion of our sleep and a second F[Unit] to cancel the scheduled computation in case we need it. This is in fact the shape of Fiber's API. And this is exactly what the start operation returns.

The difference between a Concurrent data type and one that is only Async is that you can go from any F[A] to a F[Fiber[F, A]], to participate in race conditions and that can be canceled should the need arise, in order to trigger an early release of allocated resources.

Thus a Concurrent data type can safely participate in race conditions, whereas a data type that is only Async cannot do it without exposing and forcing the user to work with cancellation tokens. An Async data type cannot expose for example a start operation that is safe.

Annotations
@implicitNotFound( ... )
Source
Concurrent.scala
Linear Supertypes
Async[F], LiftIO[F], Sync[F], Bracket[F, Throwable], MonadError[F, Throwable], Monad[F], FlatMap[F], ApplicativeError[F, Throwable], Applicative[F], InvariantMonoidal[F], Apply[F], ApplyArityFunctions[F], InvariantSemigroupal[F], Semigroupal[F], Functor[F], Invariant[F], Serializable, Serializable, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. Concurrent
  2. Async
  3. LiftIO
  4. Sync
  5. Bracket
  6. MonadError
  7. Monad
  8. FlatMap
  9. ApplicativeError
  10. Applicative
  11. InvariantMonoidal
  12. Apply
  13. ApplyArityFunctions
  14. InvariantSemigroupal
  15. Semigroupal
  16. Functor
  17. Invariant
  18. Serializable
  19. Serializable
  20. AnyRef
  21. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract def async[A](k: ((Either[Throwable, A]) ⇒ Unit) ⇒ Unit): F[A]

    Permalink

    Creates a simple, noncancelable F[A] instance that executes an asynchronous process on evaluation.

    Creates a simple, noncancelable F[A] instance that executes an asynchronous process on evaluation.

    The given function is being injected with a side-effectful callback for signaling the final result of an asynchronous process.

    k

    is a function that should be called with a callback for signaling the result once it is ready

    Definition Classes
    Async
  2. abstract def bracketCase[A, B](acquire: F[A])(use: (A) ⇒ F[B])(release: (A, ExitCase[Throwable]) ⇒ F[Unit]): F[B]

    Permalink

    A generalized version of bracket which uses ExitCase to distinguish between different exit cases when releasing the acquired resource.

    A generalized version of bracket which uses ExitCase to distinguish between different exit cases when releasing the acquired resource.

    acquire

    is an action that "acquires" some expensive resource, that needs to be used and then discarded

    use

    is the action that uses the newly allocated resource and that will provide the final result

    release

    is the action that's supposed to release the allocated resource after use is done, by observing and acting on its exit condition

    Definition Classes
    Bracket
  3. abstract def cancelable[A](k: ((Either[Throwable, A]) ⇒ Unit) ⇒ IO[Unit]): F[A]

    Permalink

    Creates a cancelable F[A] instance that executes an asynchronous process on evaluation.

    Creates a cancelable F[A] instance that executes an asynchronous process on evaluation.

    This builder accepts a registration function that is being injected with a side-effectful callback, to be called when the asynchronous process is complete with a final result.

    The registration function is also supposed to return an IO[Unit] that captures the logic necessary for canceling the asynchronous process, for as long as it is still active.

    Example:

    import java.util.concurrent.ScheduledExecutorService
    import scala.concurrent.duration._
    
    def sleep[F[_]](d: FiniteDuration)
      (implicit F: Concurrent[F], ec: ScheduledExecutorService): F[Unit] = {
    
      F.cancelable { cb =>
        // Note the callback is pure, so we need to trigger evaluation
        val run = new Runnable { def run() = cb(Right(())) }
    
        // Schedules task to run after delay
        val future = ec.schedule(run, d.length, d.unit)
    
        // Cancellation logic, suspended in IO
        IO(future.cancel(true))
      }
    }
  4. abstract def flatMap[A, B](fa: F[A])(f: (A) ⇒ F[B]): F[B]

    Permalink
    Definition Classes
    FlatMap
  5. abstract def handleErrorWith[A](fa: F[A])(f: (Throwable) ⇒ F[A]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  6. abstract def onCancelRaiseError[A](fa: F[A], e: Throwable): F[A]

    Permalink

    Returns a new F value that mirrors the source for normal termination, but that triggers the given error on cancellation.

    Returns a new F value that mirrors the source for normal termination, but that triggers the given error on cancellation.

    This onCancelRaiseError operator transforms any task into one that on cancellation will terminate with the given error, thus transforming potentially non-terminating tasks into ones that yield a certain error.

    import scala.concurrent.CancellationException
    
    val F = Concurrent[IO]
    val timer = Timer[IO]
    
    val error = new CancellationException("Boo!")
    val fa = F.onCancelRaiseError(timer.sleep(5.seconds, error))
    
    fa.start.flatMap { fiber =>
      fiber.cancel *> fiber.join
    }

    Without "onCancelRaiseError" the sleep operation yields a non-terminating task on cancellation. But by applying "onCancelRaiseError", the yielded task above will terminate with the indicated "CancellationException" reference, which we can then also distinguish from other errors thrown in the F context.

    Depending on the implementation, tasks that are canceled can become non-terminating. This operation ensures that when cancellation happens, the resulting task is terminated with an error, such that logic can be scheduled to happen after cancellation:

    import scala.concurrent.CancellationException
    val wasCanceled = new CancellationException()
    
    F.onCancelRaiseError(fa, wasCanceled).attempt.flatMap {
      case Right(a) =>
        F.delay(println(s"Success: $a"))
      case Left(`wasCanceled`) =>
        F.delay(println("Was canceled!"))
      case Left(error) =>
        F.delay(println(s"Terminated in error: $error"))
    }

    This technique is how a "bracket" operation can be implemented.

    Besides sending the cancellation signal, this operation also cuts the connection between the producer and the consumer. Example:

    val F = Concurrent[IO]
    val timer = Timer[IO]
    
    // This task is uninterruptible ;-)
    val tick = F.uncancelable(
      for {
        _ <- timer.sleep(5.seconds)
        _ <- IO(println("Tick!"))
      } yield ())
    
    // Builds an value that triggers an exception on cancellation
    val loud = F.onCancelRaiseError(tick, new CancellationException)

    In this example the loud reference will be completed with a "CancellationException", as indicated via "onCancelRaiseError". The logic of the source won't get canceled, because we've embedded it all in uncancelable. But its bind continuation is not allowed to continue after that, its final result not being allowed to be signaled.

    Therefore this also transforms uncancelable values into ones that can be canceled. The logic of the source, its run-loop might not be interruptible, however cancel on a value on which onCancelRaiseError was applied will cut the connection from the producer, the consumer receiving the indicated error instead.

  7. abstract def pure[A](x: A): F[A]

    Permalink
    Definition Classes
    Applicative
  8. abstract def racePair[A, B](fa: F[A], fb: F[B]): F[Either[(A, Fiber[F, B]), (Fiber[F, A], B)]]

    Permalink

    Run two tasks concurrently, creating a race between them and returns a pair containing both the winner's successful value and the loser represented as a still-unfinished fiber.

    Run two tasks concurrently, creating a race between them and returns a pair containing both the winner's successful value and the loser represented as a still-unfinished fiber.

    If the first task completes in error, then the result will complete in error, the other task being canceled.

    On usage the user has the option of canceling the losing task, this being equivalent with plain race:

    val ioA: IO[A] = ???
    val ioB: IO[B] = ???
    
    Concurrent[IO].racePair(ioA, ioB).flatMap {
      case Left((a, fiberB)) =>
        fiberB.cancel.map(_ => a)
      case Right((fiberA, b)) =>
        fiberA.cancel.map(_ => b)
    }

    See race for a simpler version that cancels the loser immediately.

  9. abstract def raiseError[A](e: Throwable): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  10. abstract def start[A](fa: F[A]): F[Fiber[F, A]]

    Permalink

    Start concurrent execution of the source suspended in the F context.

    Start concurrent execution of the source suspended in the F context.

    Returns a Fiber that can be used to either join or cancel the running computation, being similar in spirit (but not in implementation) to starting a thread.

  11. abstract def suspend[A](thunk: ⇒ F[A]): F[A]

    Permalink

    Suspends the evaluation of an F reference.

    Suspends the evaluation of an F reference.

    Equivalent to FlatMap.flatten for pure expressions, the purpose of this function is to suspend side effects in F.

    Definition Classes
    Sync
  12. abstract def tailRecM[A, B](a: A)(f: (A) ⇒ F[Either[A, B]]): F[B]

    Permalink
    Definition Classes
    FlatMap
  13. abstract def uncancelable[A](fa: F[A]): F[A]

    Permalink

    Returns a new F that mirrors the source, but that is uninterruptible.

    Returns a new F that mirrors the source, but that is uninterruptible.

    This means that the cancel signal has no effect on the result of join and that the cancelable token returned by ConcurrentEffect.runCancelable on evaluation will have no effect.

    This operation is undoing the cancellation mechanism of cancelable, with this equivalence:

    F.uncancelable(F.cancelable { cb => f(cb); io }) <-> F.async(f)

    Sample:

    val F = Concurrent[IO]
    val timer = Timer[IO]
    
    // Normally Timer#sleep yields cancelable tasks
    val tick = F.uncancelable(timer.sleep(10.seconds))
    
    // This prints "Tick!" after 10 seconds, even if we are
    // canceling the Fiber after start:
    for {
      fiber <- F.start(tick)
      _ <- fiber.cancel
      _ <- fiber.join
    } yield {
      println("Tick!")
    }

    Cancelable effects are great in race conditions, however sometimes this operation is necessary to ensure that the bind continuation of a task (the following flatMap operations) are also evaluated no matter what.

Concrete 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 *>[A, B](fa: F[A])(fb: F[B]): F[B]

    Permalink
    Definition Classes
    Apply
    Annotations
    @inline()
  4. final def <*[A, B](fa: F[A])(fb: F[B]): F[A]

    Permalink
    Definition Classes
    Apply
    Annotations
    @inline()
  5. final def <*>[A, B](ff: F[(A) ⇒ B])(fa: F[A]): F[B]

    Permalink
    Definition Classes
    Apply
    Annotations
    @inline()
  6. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  7. def adaptError[A](fa: F[A])(pf: PartialFunction[Throwable, Throwable]): F[A]

    Permalink
    Definition Classes
    MonadError
  8. def ap[A, B](ff: F[(A) ⇒ B])(fa: F[A]): F[B]

    Permalink
    Definition Classes
    FlatMap → Apply
  9. def ap10[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  10. def ap11[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  11. def ap12[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  12. def ap13[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  13. def ap14[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  14. def ap15[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  15. def ap16[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  16. def ap17[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  17. def ap18[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  18. def ap19[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  19. def ap2[A, B, Z](ff: F[(A, B) ⇒ Z])(fa: F[A], fb: F[B]): F[Z]

    Permalink
    Definition Classes
    Apply
  20. def ap20[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  21. def ap21[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  22. def ap22[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20], f21: F[A21]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  23. def ap3[A0, A1, A2, Z](f: F[(A0, A1, A2) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  24. def ap4[A0, A1, A2, A3, Z](f: F[(A0, A1, A2, A3) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  25. def ap5[A0, A1, A2, A3, A4, Z](f: F[(A0, A1, A2, A3, A4) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  26. def ap6[A0, A1, A2, A3, A4, A5, Z](f: F[(A0, A1, A2, A3, A4, A5) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  27. def ap7[A0, A1, A2, A3, A4, A5, A6, Z](f: F[(A0, A1, A2, A3, A4, A5, A6) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  28. def ap8[A0, A1, A2, A3, A4, A5, A6, A7, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  29. def ap9[A0, A1, A2, A3, A4, A5, A6, A7, A8, Z](f: F[(A0, A1, A2, A3, A4, A5, A6, A7, A8) ⇒ Z])(f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8]): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  30. def as[A, B](fa: F[A], b: B): F[B]

    Permalink
    Definition Classes
    Functor
  31. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  32. def attempt[A](fa: F[A]): F[Either[Throwable, A]]

    Permalink
    Definition Classes
    ApplicativeError
  33. def attemptT[A](fa: F[A]): EitherT[F, Throwable, A]

    Permalink
    Definition Classes
    ApplicativeError
  34. def bracket[A, B](acquire: F[A])(use: (A) ⇒ F[B])(release: (A) ⇒ F[Unit]): F[B]

    Permalink

    Operation meant for specifying tasks with safe resource acquisition and release in the face of errors and interruption.

    Operation meant for specifying tasks with safe resource acquisition and release in the face of errors and interruption.

    This operation provides the equivalent of try/catch/finally statements in mainstream imperative languages for resource acquisition and release.

    acquire

    is an action that "acquires" some expensive resource, that needs to be used and then discarded

    use

    is the action that uses the newly allocated resource and that will provide the final result

    release

    is the action that's supposed to release the allocated resource after use is done, irregardless of its exit condition

    Definition Classes
    Bracket
  35. def catchNonFatal[A](a: ⇒ A)(implicit ev: <:<[Throwable, Throwable]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  36. def catchNonFatalEval[A](a: Eval[A])(implicit ev: <:<[Throwable, Throwable]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  37. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  38. def compose[G[_]](implicit arg0: Applicative[G]): Applicative[[α]F[G[α]]]

    Permalink
    Definition Classes
    Applicative
  39. def compose[G[_]](implicit arg0: Apply[G]): Apply[[α]F[G[α]]]

    Permalink
    Definition Classes
    Apply
  40. def compose[G[_]](implicit arg0: Functor[G]): Functor[[α]F[G[α]]]

    Permalink
    Definition Classes
    Functor
  41. def compose[G[_]](implicit arg0: Invariant[G]): Invariant[[α]F[G[α]]]

    Permalink
    Definition Classes
    Invariant
  42. def composeApply[G[_]](implicit arg0: Apply[G]): InvariantSemigroupal[[α]F[G[α]]]

    Permalink
    Definition Classes
    InvariantSemigroupal
  43. def composeContravariant[G[_]](implicit arg0: Contravariant[G]): Contravariant[[α]F[G[α]]]

    Permalink
    Definition Classes
    Functor → Invariant
  44. def composeContravariantMonoidal[G[_]](implicit arg0: ContravariantMonoidal[G]): ContravariantMonoidal[[α]F[G[α]]]

    Permalink
    Definition Classes
    Applicative
  45. def composeFunctor[G[_]](implicit arg0: Functor[G]): Invariant[[α]F[G[α]]]

    Permalink
    Definition Classes
    Invariant
  46. def delay[A](thunk: ⇒ A): F[A]

    Permalink

    Lifts any by-name parameter into the F context.

    Lifts any by-name parameter into the F context.

    Equivalent to Applicative.pure for pure expressions, the purpose of this function is to suspend side effects in F.

    Definition Classes
    Sync
  47. def ensure[A](fa: F[A])(error: ⇒ Throwable)(predicate: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    MonadError
  48. def ensureOr[A](fa: F[A])(error: (A) ⇒ Throwable)(predicate: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    MonadError
  49. final def eq(arg0: AnyRef): Boolean

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

    Permalink
    Definition Classes
    AnyRef → Any
  51. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  52. def flatTap[A, B](fa: F[A])(f: (A) ⇒ F[B]): F[A]

    Permalink
    Definition Classes
    FlatMap
  53. def flatten[A](ffa: F[F[A]]): F[A]

    Permalink
    Definition Classes
    FlatMap
  54. final def fmap[A, B](fa: F[A])(f: (A) ⇒ B): F[B]

    Permalink
    Definition Classes
    Functor
  55. def fproduct[A, B](fa: F[A])(f: (A) ⇒ B): F[(A, B)]

    Permalink
    Definition Classes
    Functor
  56. def fromEither[A](x: Either[Throwable, A]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  57. def fromTry[A](t: Try[A])(implicit ev: <:<[Throwable, Throwable]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  58. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  59. def handleError[A](fa: F[A])(f: (Throwable) ⇒ A): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  60. def hashCode(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  61. def ifM[B](fa: F[Boolean])(ifTrue: ⇒ F[B], ifFalse: ⇒ F[B]): F[B]

    Permalink
    Definition Classes
    FlatMap
  62. def imap[A, B](fa: F[A])(f: (A) ⇒ B)(g: (B) ⇒ A): F[B]

    Permalink
    Definition Classes
    Functor → Invariant
  63. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  64. def iterateUntil[A](f: F[A])(p: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    Monad
  65. def iterateUntilM[A](init: A)(f: (A) ⇒ F[A])(p: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    Monad
  66. def iterateWhile[A](f: F[A])(p: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    Monad
  67. def iterateWhileM[A](init: A)(f: (A) ⇒ F[A])(p: (A) ⇒ Boolean): F[A]

    Permalink
    Definition Classes
    Monad
  68. def lift[A, B](f: (A) ⇒ B): (F[A]) ⇒ F[B]

    Permalink
    Definition Classes
    Functor
  69. def liftIO[A](ioa: IO[A]): F[A]

    Permalink

    Inherited from LiftIO, defines a conversion from IO in terms of the Concurrent type class.

    Inherited from LiftIO, defines a conversion from IO in terms of the Concurrent type class.

    N.B. expressing this conversion in terms of Concurrent and its capabilities means that the resulting F is cancelable in case the source IO is.

    To access this implementation as a standalone function, you can use Concurrent.liftIO (on the object companion).

    Definition Classes
    ConcurrentAsyncLiftIO
  70. def map[A, B](fa: F[A])(f: (A) ⇒ B): F[B]

    Permalink
    Definition Classes
    Monad → Applicative → Functor
  71. def map10[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  72. def map11[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  73. def map12[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  74. def map13[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  75. def map14[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  76. def map15[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  77. def map16[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  78. def map17[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  79. def map18[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  80. def map19[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  81. def map2[A, B, Z](fa: F[A], fb: F[B])(f: (A, B) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    Apply
  82. def map20[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  83. def map21[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  84. def map22[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20], f21: F[A21])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  85. def map2Eval[A, B, Z](fa: F[A], fb: Eval[F[B]])(f: (A, B) ⇒ Z): Eval[F[Z]]

    Permalink
    Definition Classes
    Apply
  86. def map3[A0, A1, A2, Z](f0: F[A0], f1: F[A1], f2: F[A2])(f: (A0, A1, A2) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  87. def map4[A0, A1, A2, A3, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3])(f: (A0, A1, A2, A3) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  88. def map5[A0, A1, A2, A3, A4, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4])(f: (A0, A1, A2, A3, A4) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  89. def map6[A0, A1, A2, A3, A4, A5, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5])(f: (A0, A1, A2, A3, A4, A5) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  90. def map7[A0, A1, A2, A3, A4, A5, A6, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6])(f: (A0, A1, A2, A3, A4, A5, A6) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  91. def map8[A0, A1, A2, A3, A4, A5, A6, A7, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7])(f: (A0, A1, A2, A3, A4, A5, A6, A7) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  92. def map9[A0, A1, A2, A3, A4, A5, A6, A7, A8, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8])(f: (A0, A1, A2, A3, A4, A5, A6, A7, A8) ⇒ Z): F[Z]

    Permalink
    Definition Classes
    ApplyArityFunctions
  93. def mproduct[A, B](fa: F[A])(f: (A) ⇒ F[B]): F[(A, B)]

    Permalink
    Definition Classes
    FlatMap
  94. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  95. def never[A]: F[A]

    Permalink

    Returns a non-terminating F[_], that never completes with a result, being equivalent to async(_ => ())

    Returns a non-terminating F[_], that never completes with a result, being equivalent to async(_ => ())

    Definition Classes
    Async
  96. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  98. def onError[A](fa: F[A])(pf: PartialFunction[Throwable, F[Unit]]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  99. def point[A](a: A): F[A]

    Permalink
    Definition Classes
    InvariantMonoidal
  100. def product[A, B](fa: F[A], fb: F[B]): F[(A, B)]

    Permalink
    Definition Classes
    FlatMap → Apply → Semigroupal
  101. def productL[A, B](fa: F[A])(fb: F[B]): F[A]

    Permalink
    Definition Classes
    Apply
  102. def productLEval[A, B](fa: F[A])(fb: Eval[F[B]]): F[A]

    Permalink
    Definition Classes
    FlatMap
  103. def productR[A, B](fa: F[A])(fb: F[B]): F[B]

    Permalink
    Definition Classes
    Apply
  104. def productREval[A, B](fa: F[A])(fb: Eval[F[B]]): F[B]

    Permalink
    Definition Classes
    FlatMap
  105. def race[A, B](fa: F[A], fb: F[B]): F[Either[A, B]]

    Permalink

    Run two tasks concurrently and return the first to finish, either in success or error.

    Run two tasks concurrently and return the first to finish, either in success or error. The loser of the race is canceled.

    The two tasks are potentially executed in parallel, the winner being the first that signals a result.

    As an example see Concurrent.timeoutTo

    Also see racePair for a version that does not cancel the loser automatically on successful results.

  106. def recover[A](fa: F[A])(pf: PartialFunction[Throwable, A]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  107. def recoverWith[A](fa: F[A])(pf: PartialFunction[Throwable, F[A]]): F[A]

    Permalink
    Definition Classes
    ApplicativeError
  108. def replicateA[A](n: Int, fa: F[A]): F[List[A]]

    Permalink
    Definition Classes
    Applicative
  109. def rethrow[A](fa: F[Either[Throwable, A]]): F[A]

    Permalink
    Definition Classes
    MonadError
  110. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  111. def toString(): String

    Permalink
    Definition Classes
    AnyRef → Any
  112. def tuple10[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  113. def tuple11[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  114. def tuple12[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  115. def tuple13[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  116. def tuple14[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  117. def tuple15[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  118. def tuple16[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  119. def tuple17[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  120. def tuple18[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  121. def tuple19[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  122. def tuple2[A, B](f1: F[A], f2: F[B]): F[(A, B)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  123. def tuple20[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  124. def tuple21[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  125. def tuple22[A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8], f9: F[A9], f10: F[A10], f11: F[A11], f12: F[A12], f13: F[A13], f14: F[A14], f15: F[A15], f16: F[A16], f17: F[A17], f18: F[A18], f19: F[A19], f20: F[A20], f21: F[A21]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8, A9, A10, A11, A12, A13, A14, A15, A16, A17, A18, A19, A20, A21)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  126. def tuple3[A0, A1, A2, Z](f0: F[A0], f1: F[A1], f2: F[A2]): F[(A0, A1, A2)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  127. def tuple4[A0, A1, A2, A3, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3]): F[(A0, A1, A2, A3)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  128. def tuple5[A0, A1, A2, A3, A4, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4]): F[(A0, A1, A2, A3, A4)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  129. def tuple6[A0, A1, A2, A3, A4, A5, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5]): F[(A0, A1, A2, A3, A4, A5)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  130. def tuple7[A0, A1, A2, A3, A4, A5, A6, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6]): F[(A0, A1, A2, A3, A4, A5, A6)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  131. def tuple8[A0, A1, A2, A3, A4, A5, A6, A7, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7]): F[(A0, A1, A2, A3, A4, A5, A6, A7)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  132. def tuple9[A0, A1, A2, A3, A4, A5, A6, A7, A8, Z](f0: F[A0], f1: F[A1], f2: F[A2], f3: F[A3], f4: F[A4], f5: F[A5], f6: F[A6], f7: F[A7], f8: F[A8]): F[(A0, A1, A2, A3, A4, A5, A6, A7, A8)]

    Permalink
    Definition Classes
    ApplyArityFunctions
  133. def tupleLeft[A, B](fa: F[A], b: B): F[(B, A)]

    Permalink
    Definition Classes
    Functor
  134. def tupleRight[A, B](fa: F[A], b: B): F[(A, B)]

    Permalink
    Definition Classes
    Functor
  135. def unit: F[Unit]

    Permalink
    Definition Classes
    Applicative → InvariantMonoidal
  136. def unlessA[A](cond: Boolean)(f: ⇒ F[A]): F[Unit]

    Permalink
    Definition Classes
    Applicative
  137. def untilM[G[_], A](f: F[A])(cond: ⇒ F[Boolean])(implicit G: Alternative[G]): F[G[A]]

    Permalink
    Definition Classes
    Monad
  138. def untilM_[A](f: F[A])(cond: ⇒ F[Boolean]): F[Unit]

    Permalink
    Definition Classes
    Monad
  139. def void[A](fa: F[A]): F[Unit]

    Permalink
    Definition Classes
    Functor
  140. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  143. def whenA[A](cond: Boolean)(f: ⇒ F[A]): F[Unit]

    Permalink
    Definition Classes
    Applicative
  144. def whileM[G[_], A](p: F[Boolean])(body: ⇒ F[A])(implicit G: Alternative[G]): F[G[A]]

    Permalink
    Definition Classes
    Monad
  145. def whileM_[A](p: F[Boolean])(body: ⇒ F[A]): F[Unit]

    Permalink
    Definition Classes
    Monad
  146. def widen[A, B >: A](fa: F[A]): F[B]

    Permalink
    Definition Classes
    Functor

Deprecated Value Members

  1. final def followedBy[A, B](fa: F[A])(fb: F[B]): F[B]

    Permalink
    Definition Classes
    Apply
    Annotations
    @deprecated @inline()
    Deprecated

    (Since version 1.0.0-RC2) Use *> or productR instead.

  2. def followedByEval[A, B](fa: F[A])(fb: Eval[F[B]]): F[B]

    Permalink
    Definition Classes
    FlatMap
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0-RC2) Use productREval instead.

  3. final def forEffect[A, B](fa: F[A])(fb: F[B]): F[A]

    Permalink
    Definition Classes
    Apply
    Annotations
    @deprecated @inline()
    Deprecated

    (Since version 1.0.0-RC2) Use <* or productL instead.

  4. def forEffectEval[A, B](fa: F[A])(fb: Eval[F[B]]): F[A]

    Permalink
    Definition Classes
    FlatMap
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0-RC2) Use productLEval instead.

Inherited from Async[F]

Inherited from LiftIO[F]

Inherited from Sync[F]

Inherited from Bracket[F, Throwable]

Inherited from MonadError[F, Throwable]

Inherited from Monad[F]

Inherited from FlatMap[F]

Inherited from ApplicativeError[F, Throwable]

Inherited from Applicative[F]

Inherited from InvariantMonoidal[F]

Inherited from Apply[F]

Inherited from ApplyArityFunctions[F]

Inherited from InvariantSemigroupal[F]

Inherited from Semigroupal[F]

Inherited from Functor[F]

Inherited from Invariant[F]

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Ungrouped