Interface | Description |
---|---|
CoGroupSplitDep | |
JdbcRDD.ConnectionFactory |
Class | Description |
---|---|
AsyncRDDActions<T> |
A set of asynchronous RDD actions available through an implicit conversion.
|
BinaryFileRDD<T> | |
BlockRDD<T> | |
BlockRDDPartition | |
CartesianPartition | |
CartesianRDD<T,U> | |
CheckpointRDD<T> |
This RDD represents a RDD checkpoint file (similar to HadoopRDD).
|
CheckpointRDDPartition | |
CheckpointState |
Enumeration to manage state transitions of an RDD through checkpointing
[ Initialized --> marked for checkpointing --> checkpointing in progress --> checkpointed ]
|
CoalescedRDD<T> |
Represents a coalesced RDD that has fewer partitions than its parent RDD
This class uses the PartitionCoalescer class to find a good partitioning of the parent RDD
so that each new partition has roughly the same number of parent partitions and that
the preferred location of each new partition overlaps with as many preferred locations of its
parent partitions
|
CoalescedRDDPartition |
Class that captures a coalesced RDD by essentially keeping track of parent partitions
|
CoGroupedRDD<K> |
:: DeveloperApi ::
A RDD that cogroups its parents.
|
CoGroupPartition | |
DoubleRDDFunctions |
Extra functions available on RDDs of Doubles through an implicit conversion.
|
EmptyRDD<T> |
An RDD that has no partitions and no elements.
|
HadoopPartition |
A Spark split class that wraps around a Hadoop InputSplit.
|
HadoopRDD<K,V> |
:: DeveloperApi ::
An RDD that provides core functionality for reading data stored in Hadoop (e.g., files in HDFS,
sources in HBase, or S3), using the older MapReduce API (
org.apache.hadoop.mapred ). |
HadoopRDD.HadoopMapPartitionsWithSplitRDD<U,T> |
Analogous to
MapPartitionsRDD , but passes in an InputSplit to
the given function rather than the index of the partition. |
HadoopRDD.HadoopMapPartitionsWithSplitRDD$ | |
HadoopRDD.SplitInfoReflections | |
JdbcPartition | |
JdbcRDD<T> |
An RDD that executes an SQL query on a JDBC connection and reads results.
|
MapPartitionsRDD<U,T> | |
NarrowCoGroupSplitDep | |
NewHadoopPartition | |
NewHadoopRDD<K,V> |
:: DeveloperApi ::
An RDD that provides core functionality for reading data stored in Hadoop (e.g., files in HDFS,
sources in HBase, or S3), using the new MapReduce API (
org.apache.hadoop.mapreduce ). |
NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD<U,T> |
Analogous to
MapPartitionsRDD , but passes in an InputSplit to
the given function rather than the index of the partition. |
NewHadoopRDD.NewHadoopMapPartitionsWithSplitRDD$ | |
OrderedRDDFunctions<K,V,P extends scala.Product2<K,V>> |
Extra functions available on RDDs of (key, value) pairs where the key is sortable through
an implicit conversion.
|
PairRDDFunctions<K,V> |
Extra functions available on RDDs of (key, value) pairs through an implicit conversion.
|
ParallelCollectionPartition<T> | |
ParallelCollectionRDD<T> | |
PartitionCoalescer |
Coalesce the partitions of a parent RDD (
prev ) into fewer partitions, so that each partition of
this RDD computes one or more of the parent ones. |
PartitionerAwareUnionRDD<T> |
Class representing an RDD that can take multiple RDDs partitioned by the same partitioner and
unify them into a single RDD while preserving the partitioner.
|
PartitionerAwareUnionRDDPartition |
Class representing partitions of PartitionerAwareUnionRDD, which maintains the list of
corresponding partitions of parent RDDs.
|
PartitionGroup | |
PartitionPruningRDD<T> |
:: DeveloperApi ::
A RDD used to prune RDD partitions/partitions so we can avoid launching tasks on
all partitions.
|
PartitionPruningRDDPartition | |
PartitionwiseSampledRDD<T,U> |
A RDD sampled from its parent RDD partition-wise.
|
PartitionwiseSampledRDDPartition | |
PipedRDD<T> |
An RDD that pipes the contents of each parent partition through an external command
(printing them one per line) and returns the output as a collection of strings.
|
PruneDependency<T> |
Represents a dependency between the PartitionPruningRDD and its parent.
|
RDD<T> |
A Resilient Distributed Dataset (RDD), the basic abstraction in Spark.
|
RDDCheckpointData<T> |
This class contains all the information related to RDD checkpointing.
|
SampledRDD<T> | |
SampledRDDPartition | |
SequenceFileRDDFunctions<K,V> |
Extra functions available on RDDs of (key, value) pairs to create a Hadoop SequenceFile,
through an implicit conversion.
|
ShuffleCoGroupSplitDep | |
ShuffledRDD<K,V,C> |
:: DeveloperApi ::
The resulting RDD from a shuffle (e.g.
|
ShuffledRDDPartition | |
SubtractedRDD<K,V,W> |
An optimized version of cogroup for set difference/subtraction.
|
UnionPartition<T> |
Partition for UnionRDD.
|
UnionRDD<T> | |
WholeTextFileRDD |
Analogous to
MapPartitionsRDD , but passes in an InputSplit to
the given function rather than the index of the partition. |
ZippedPartitionsBaseRDD<V> | |
ZippedPartitionsPartition | |
ZippedPartitionsRDD2<A,B,V> | |
ZippedPartitionsRDD3<A,B,C,V> | |
ZippedPartitionsRDD4<A,B,C,D,V> | |
ZippedWithIndexRDD<T> |
Represents a RDD zipped with its element indices.
|
ZippedWithIndexRDDPartition |