public class PartitionPruningRDD<T> extends RDD<T>
Constructor and Description |
---|
PartitionPruningRDD(RDD<T> prev,
scala.Function1<java.lang.Object,java.lang.Object> partitionFilterFunc,
scala.reflect.ClassTag<T> evidence$1) |
Modifier and Type | Method and Description |
---|---|
scala.collection.Iterator<T> |
compute(Partition split,
TaskContext context)
:: DeveloperApi ::
Implemented by subclasses to compute a given partition.
|
static <T> PartitionPruningRDD<T> |
create(RDD<T> rdd,
scala.Function1<java.lang.Object,java.lang.Object> partitionFilterFunc)
Create a PartitionPruningRDD.
|
protected Partition[] |
getPartitions()
Implemented by subclasses to return the set of partitions in this RDD.
|
aggregate, cache, cartesian, checkpoint, checkpointData, clearDependencies, coalesce, collect, collect, context, count, countApprox, countApproxDistinct, countApproxDistinct, countByValue, countByValueApprox, creationSite, dependencies, distinct, distinct, doubleRDDToDoubleRDDFunctions, filter, filterWith, first, firstParent, flatMap, flatMapWith, fold, foreach, foreachPartition, foreachWith, getCheckpointFile, getDependencies, getNumPartitions, getPreferredLocations, getStorageLevel, glom, groupBy, groupBy, groupBy, id, intersection, intersection, intersection, isCheckpointed, isEmpty, iterator, keyBy, localCheckpoint, map, mapPartitions, mapPartitionsWithContext, mapPartitionsWithIndex, mapPartitionsWithSplit, mapWith, max, min, name, numericRDDToDoubleRDDFunctions, parent, partitioner, partitions, persist, persist, pipe, pipe, pipe, preferredLocations, randomSplit, rddToAsyncRDDActions, rddToOrderedRDDFunctions, rddToPairRDDFunctions, rddToSequenceFileRDDFunctions, reduce, repartition, sample, saveAsObjectFile, saveAsTextFile, saveAsTextFile, scope, setName, sortBy, sparkContext, subtract, subtract, subtract, take, takeOrdered, takeSample, toArray, toDebugString, toJavaRDD, toLocalIterator, top, toString, treeAggregate, treeReduce, union, unpersist, zip, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipPartitions, zipWithIndex, zipWithUniqueId
clone, equals, finalize, getClass, hashCode, notify, notifyAll, wait, wait, wait
initializeIfNecessary, initializeLogging, isTraceEnabled, log_, log, logDebug, logDebug, logError, logError, logInfo, logInfo, logName, logTrace, logTrace, logWarning, logWarning
public static <T> PartitionPruningRDD<T> create(RDD<T> rdd, scala.Function1<java.lang.Object,java.lang.Object> partitionFilterFunc)
rdd
- (undocumented)partitionFilterFunc
- (undocumented)public scala.collection.Iterator<T> compute(Partition split, TaskContext context)
RDD
protected Partition[] getPartitions()
RDD
getPartitions
in class RDD<T>