org.apache.spark

rdd

package rdd

Provides several RDD implementations. See org.apache.spark.rdd.RDD.

Source
package.scala
Linear Supertypes
AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. rdd
  2. AnyRef
  3. Any
  1. Hide All
  2. Show all
Learn more about member selection
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, Array[Iterable[_]])]

    :: DeveloperApi :: A RDD that cogroups its parents.

  3. class DoubleRDDFunctions extends Logging with Serializable

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

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

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

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

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

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

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

  7. 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.

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

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

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

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

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

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

  11. 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.

  12. class ShuffledRDD[K, V, C] extends RDD[(K, C)]

    :: DeveloperApi :: The resulting RDD from a shuffle (e.

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

    Annotations
    @DeveloperApi()

Value Members

  1. object JdbcRDD extends Serializable

  2. object PartitionPruningRDD extends Serializable

    Annotations
    @DeveloperApi()
  3. object RDD extends Serializable

    Defines implicit functions that provide extra functionalities on RDDs of specific types.

Inherited from AnyRef

Inherited from Any

Ungrouped