org.apache.spark.rdd
Class AsyncRDDActions<T>

Object
  extended by org.apache.spark.rdd.AsyncRDDActions<T>
All Implemented Interfaces:
java.io.Serializable, Logging

public class AsyncRDDActions<T>
extends Object
implements scala.Serializable, Logging

A set of asynchronous RDD actions available through an implicit conversion.

See Also:
Serialized Form

Constructor Summary
AsyncRDDActions(RDD<T> self, scala.reflect.ClassTag<T> evidence$1)
           
 
Method Summary
 FutureAction<scala.collection.Seq<T>> collectAsync()
          Returns a future for retrieving all elements of this RDD.
 FutureAction<Object> countAsync()
          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 futureExecutionContext()
           
 FutureAction<scala.collection.Seq<T>> takeAsync(int num)
          Returns a future for retrieving the first num elements of the RDD.
 
Methods inherited from class Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 
Methods inherited from interface org.apache.spark.Logging
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
 

Constructor Detail

AsyncRDDActions

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

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)