Class BaseRRDD<T,U>

Object
org.apache.spark.rdd.RDD<U>
org.apache.spark.api.r.BaseRRDD<T,U>
All Implemented Interfaces:
Serializable, org.apache.spark.internal.Logging, scala.Serializable
Direct Known Subclasses:
PairwiseRRDD, RRDD, StringRRDD

public abstract class BaseRRDD<T,U> extends RDD<U> implements org.apache.spark.internal.Logging
See Also:
  • Constructor Details

    • BaseRRDD

      public BaseRRDD(RDD<T> parent, int numPartitions, byte[] func, String deserializer, String serializer, byte[] packageNames, Broadcast<Object>[] broadcastVars, scala.reflect.ClassTag<T> evidence$1, scala.reflect.ClassTag<U> evidence$2)
  • Method Details

    • compute

      public scala.collection.Iterator<U> compute(Partition partition, TaskContext context)
      Description copied from class: RDD
      :: DeveloperApi :: Implemented by subclasses to compute a given partition.
      Specified by:
      compute in class RDD<U>
      Parameters:
      partition - (undocumented)
      context - (undocumented)
      Returns:
      (undocumented)
    • getPartitions

      public Partition[] getPartitions()