Spark 3.5.5 ScalaDoc - org.apache.spark.FutureAction (original) (raw)

trait FutureAction[T] extends Future[T]

Ordering

  1. Alphabetic
  2. By Inheritance

Inherited

  1. FutureAction

  2. Future

  3. Awaitable

  4. AnyRef

  5. Any

  6. Hide All

  7. Show All

Abstract Value Members

  1. abstract def cancel(): Unit
  2. abstract def isCancelled: Boolean
  3. abstract def isCompleted: Boolean
  4. abstract def jobIds: Seq[Int]
  5. abstract def onComplete[U](func: (Try[T]) ⇒ U)(implicit executor: ExecutionContext): Unit
  6. abstract def ready(atMost: Duration)(implicit permit: CanAwait): FutureAction.this.type
  7. abstract def result(atMost: Duration)(implicit permit: CanAwait): T
  8. abstract def transform[S](f: (Try[T]) ⇒ Try[S])(implicit executor: ExecutionContext): Future[S]
  9. abstract def transformWith[S](f: (Try[T]) ⇒ Future[S])(implicit executor: ExecutionContext): Future[S]
  10. abstract def value: Option[Try[T]]

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
  2. final def ##(): Int
  3. final def ==(arg0: Any): Boolean
  4. def andThen[U](pf: PartialFunction[Try[T], U])(implicit executor: ExecutionContext): Future[T]
  5. final def asInstanceOf[T0]: T0
  6. def clone(): AnyRef
  7. def collect[S](pf: PartialFunction[T, S])(implicit executor: ExecutionContext): Future[S]
  8. final def eq(arg0: AnyRef): Boolean
  9. def equals(arg0: Any): Boolean
  10. def failed: Future[Throwable]
  11. def fallbackTo[U >: T](that: Future[U]): Future[U]
  12. def filter(p: (T) ⇒ Boolean)(implicit executor: ExecutionContext): Future[T]
  13. def finalize(): Unit
  14. def flatMap[S](f: (T) ⇒ Future[S])(implicit executor: ExecutionContext): Future[S]
  15. def flatten[S](implicit ev: <:<[T, Future[S]]): Future[S]
  16. def foreach[U](f: (T) ⇒ U)(implicit executor: ExecutionContext): Unit
  17. def get(): T
  18. final def getClass(): Class[_]
  19. def hashCode(): Int
  20. final def isInstanceOf[T0]: Boolean
  21. def map[S](f: (T) ⇒ S)(implicit executor: ExecutionContext): Future[S]
  22. def mapTo[S](implicit tag: ClassTag[S]): Future[S]
  23. final def ne(arg0: AnyRef): Boolean
  24. final def notify(): Unit
  25. final def notifyAll(): Unit
  26. def recover[U >: T](pf: PartialFunction[Throwable, U])(implicit executor: ExecutionContext): Future[U]
  27. def recoverWith[U >: T](pf: PartialFunction[Throwable, Future[U]])(implicit executor: ExecutionContext): Future[U]
  28. final def synchronized[T0](arg0: ⇒ T0): T0
  29. def toString(): String
  30. def transform[S](s: (T) ⇒ S, f: (Throwable) ⇒ Throwable)(implicit executor: ExecutionContext): Future[S]
  31. final def wait(): Unit
  32. final def wait(arg0: Long, arg1: Int): Unit
  33. final def wait(arg0: Long): Unit
  34. final def withFilter(p: (T) ⇒ Boolean)(implicit executor: ExecutionContext): Future[T]
  35. def zip[U](that: Future[U]): Future[(T, U)]
  36. def zipWith[U, R](that: Future[U])(f: (T, U) ⇒ R)(implicit executor: ExecutionContext): Future[R]

Deprecated Value Members

  1. def onFailure[U](pf: PartialFunction[Throwable, U])(implicit executor: ExecutionContext): Unit
  2. def onSuccess[U](pf: PartialFunction[T, U])(implicit executor: ExecutionContext): Unit

Inherited from Future[T]

Inherited from Awaitable[T]

Inherited from AnyRef

Inherited from Any

Ungrouped