Class AsyncRDDActions<T>

Object
org.apache.spark.rdd.AsyncRDDActions<T>
All Implemented Interfaces:
Serializable, org.apache.spark.internal.Logging, scala.Serializable

public class AsyncRDDActions<T> extends Object implements scala.Serializable, org.apache.spark.internal.Logging
A set of asynchronous RDD actions available through an implicit conversion.
See Also:
  • Nested Class Summary

    Nested classes/interfaces inherited from interface org.apache.spark.internal.Logging

    org.apache.spark.internal.Logging.SparkShellLoggingFilter
  • Constructor Summary

    Constructors
    Constructor
    Description
    AsyncRDDActions(RDD<T> self, scala.reflect.ClassTag<T> evidence$1)
     
  • Method Summary

    Modifier and Type
    Method
    Description
    FutureAction<scala.collection.Seq<T>>
    Returns a future for retrieving all elements of this RDD.
    Returns a future for counting the number of elements in the RDD.
    FutureAction<scala.runtime.BoxedUnit>
    foreachAsync(scala.Function1<T,scala.runtime.BoxedUnit> f)
    Applies a function f to all elements of this RDD.
    FutureAction<scala.runtime.BoxedUnit>
    foreachPartitionAsync(scala.Function1<scala.collection.Iterator<T>,scala.runtime.BoxedUnit> f)
    Applies a function f to each partition of this RDD.
    static scala.concurrent.ExecutionContextExecutorService
     
    FutureAction<scala.collection.Seq<T>>
    takeAsync(int num)
    Returns a future for retrieving the first num elements of the RDD.

    Methods inherited from class java.lang.Object

    equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait

    Methods inherited from interface org.apache.spark.internal.Logging

    initializeForcefully, initializeLogIfNecessary, initializeLogIfNecessary, initializeLogIfNecessary$default$2, isTraceEnabled, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning, org$apache$spark$internal$Logging$$log_, org$apache$spark$internal$Logging$$log__$eq
  • Constructor Details

    • AsyncRDDActions

      public AsyncRDDActions(RDD<T> self, scala.reflect.ClassTag<T> evidence$1)
  • Method Details

    • futureExecutionContext

      public static scala.concurrent.ExecutionContextExecutorService futureExecutionContext()
    • countAsync

      public FutureAction<Object> countAsync()
      Returns a future for counting the number of elements in the RDD.
      Returns:
      (undocumented)
    • collectAsync

      public FutureAction<scala.collection.Seq<T>> collectAsync()
      Returns a future for retrieving all elements of this RDD.
      Returns:
      (undocumented)
    • takeAsync

      public FutureAction<scala.collection.Seq<T>> takeAsync(int num)
      Returns a future for retrieving the first num elements of the RDD.
      Parameters:
      num - (undocumented)
      Returns:
      (undocumented)
    • foreachAsync

      public FutureAction<scala.runtime.BoxedUnit> foreachAsync(scala.Function1<T,scala.runtime.BoxedUnit> f)
      Applies a function f to all elements of this RDD.
      Parameters:
      f - (undocumented)
      Returns:
      (undocumented)
    • foreachPartitionAsync

      public FutureAction<scala.runtime.BoxedUnit> foreachPartitionAsync(scala.Function1<scala.collection.Iterator<T>,scala.runtime.BoxedUnit> f)
      Applies a function f to each partition of this RDD.
      Parameters:
      f - (undocumented)
      Returns:
      (undocumented)