org.apache.spark

rdd

package rdd

Visibility
  1. Public
  2. All

Type Members

  1. class AsyncRDDActions[T] extends Serializable with Logging

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

  2. class CoGroupedRDD[K] extends RDD[(K, Seq[Seq[_]])]

    A RDD that cogroups its parents.

  3. class CoalescedRDD[T] extends RDD[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

  4. case class CoalescedRDDPartition(index: Int, rdd: RDD[_], parentsIndices: Array[Int], preferredLocation: String = "") extends Partition with Product with Serializable

    Class that captures a coalesced RDD by essentially keeping track of parent partitions

  5. class DoubleRDDFunctions extends Logging with Serializable

    Extra functions available on RDDs of Doubles through an implicit conversion.

  6. class EmptyRDD[T] extends RDD[T]

    An RDD that is empty, i.

  7. class HadoopRDD[K, V] extends RDD[(K, V)] with Logging

    An RDD that provides core functionality for reading data stored in Hadoop (e.

  8. class JdbcRDD[T] extends RDD[T] with Logging

    An RDD that executes an SQL query on a JDBC connection and reads results.

  9. class NewHadoopRDD[K, V] extends RDD[(K, V)] with SparkHadoopMapReduceUtil with Logging

    An RDD that provides core functionality for reading data stored in Hadoop (e.

  10. class OrderedRDDFunctions[K, V, P <: Product2[K, V]] extends Logging with Serializable

    Extra functions available on RDDs of (key, value) pairs where the key is sortable through an implicit conversion.

  11. class PairRDDFunctions[K, V] extends Logging with SparkHadoopMapReduceUtil with Serializable

    Extra functions available on RDDs of (key, value) pairs through an implicit conversion.

  12. class PartitionPruningRDD[T] extends RDD[T]

    A RDD used to prune RDD partitions/partitions so we can avoid launching tasks on all partitions.

  13. class PartitionPruningRDDPartition extends Partition

  14. class PipedRDD[T] extends RDD[String]

    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.

  15. class PruneDependency[T] extends NarrowDependency[T]

    Represents a dependency between the PartitionPruningRDD and its parent.

  16. abstract class RDD[T] extends Serializable with Logging

    A Resilient Distributed Dataset (RDD), the basic abstraction in Spark.

  17. class SampledRDD[T] extends RDD[T]

  18. class SequenceFileRDDFunctions[K, V] extends Logging with Serializable

    Extra functions available on RDDs of (key, value) pairs to create a Hadoop SequenceFile, through an implicit conversion.

  19. class ShuffledRDD[K, V, P <: Product2[K, V]] extends RDD[P]

    The resulting RDD from a shuffle (e.

  20. class UnionRDD[T] extends RDD[T]

  21. abstract class ZippedPartitionsBaseRDD[V] extends RDD[V]

  22. class ZippedPartitionsRDD2[A, B, V] extends ZippedPartitionsBaseRDD[V]

  23. class ZippedPartitionsRDD3[A, B, C, V] extends ZippedPartitionsBaseRDD[V]

  24. class ZippedPartitionsRDD4[A, B, C, D, V] extends ZippedPartitionsBaseRDD[V]

  25. class ZippedRDD[T, U] extends RDD[(T, U)]

Value Members

  1. object JdbcRDD extends Serializable

  2. object PartitionPruningRDD extends Serializable

Ungrouped