spark.api.java

JavaPairRDD

class JavaPairRDD[K, V] extends PairFlatMapWorkaround[(K, V)] with JavaRDDLike[(K, V), JavaPairRDD[K, V]]

Linear Supertypes
JavaRDDLike[(K, V), JavaPairRDD[K, V]], PairFlatMapWorkaround[(K, V)], Serializable, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. Hide All
  2. Show all
  1. JavaPairRDD
  2. JavaRDDLike
  3. PairFlatMapWorkaround
  4. Serializable
  5. AnyRef
  6. Any
Visibility
  1. Public
  2. All

Instance Constructors

  1. new JavaPairRDD(rdd: RDD[(K, V)])(implicit kManifest: ClassManifest[K], vManifest: ClassManifest[V])

Value Members

  1. final def !=(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

    Definition Classes
    AnyRef → Any
  4. final def ==(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. def aggregate[U](zeroValue: U)(seqOp: Function2[U, (K, V), U], combOp: Function2[U, U, U]): U

    Aggregate the elements of each partition, and then the results for all the partitions, using given combine functions and a neutral "zero value".

    Aggregate the elements of each partition, and then the results for all the partitions, using given combine functions and a neutral "zero value". This function can return a different result type, U, than the type of this RDD, T. Thus, we need one operation for merging a T into an U and one operation for merging two U's, as in scala.TraversableOnce. Both of these functions are allowed to modify and return their first argument instead of creating a new U to avoid memory allocation.

    Definition Classes
    JavaRDDLike
  7. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  8. def cache(): JavaPairRDD[K, V]

    Persist this RDD with the default storage level (MEMORY_ONLY).

  9. def cartesian[U](other: spark.api.java.JavaRDDLike[U, _]): JavaPairRDD[(K, V), U]

    Return the Cartesian product of this RDD and another one, that is, the RDD of all pairs of elements (a, b) where a is in this and b is in other.

    Return the Cartesian product of this RDD and another one, that is, the RDD of all pairs of elements (a, b) where a is in this and b is in other.

    Definition Classes
    JavaRDDLike
  10. val classManifest: ClassManifest[(K, V)]

    Definition Classes
    JavaPairRDDJavaRDDLike
  11. def clone(): AnyRef

    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws()
  12. def cogroup[W1, W2](other1: JavaPairRDD[K, W1], other2: JavaPairRDD[K, W2], numSplits: Int): JavaPairRDD[K, (List[V], List[W1], List[W2])]

    For each key k in this or other1 or other2, return a resulting RDD that contains a tuple with the list of values for that key in this, other1 and other2.

  13. def cogroup[W](other: JavaPairRDD[K, W], numSplits: Int): JavaPairRDD[K, (List[V], List[W])]

    For each key k in this or other, return a resulting RDD that contains a tuple with the list of values for that key in this as well as other.

  14. def cogroup[W1, W2](other1: JavaPairRDD[K, W1], other2: JavaPairRDD[K, W2]): JavaPairRDD[K, (List[V], List[W1], List[W2])]

    For each key k in this or other1 or other2, return a resulting RDD that contains a tuple with the list of values for that key in this, other1 and other2.

  15. def cogroup[W](other: JavaPairRDD[K, W]): JavaPairRDD[K, (List[V], List[W])]

    For each key k in this or other, return a resulting RDD that contains a tuple with the list of values for that key in this as well as other.

  16. def cogroup[W1, W2](other1: JavaPairRDD[K, W1], other2: JavaPairRDD[K, W2], partitioner: Partitioner): JavaPairRDD[K, (List[V], List[W1], List[W2])]

    For each key k in this or other1 or other2, return a resulting RDD that contains a tuple with the list of values for that key in this, other1 and other2.

  17. def cogroup[W](other: JavaPairRDD[K, W], partitioner: Partitioner): JavaPairRDD[K, (List[V], List[W])]

    For each key k in this or other, return a resulting RDD that contains a tuple with the list of values for that key in this as well as other.

  18. def collect(): List[(K, V)]

    Return an array that contains all of the elements in this RDD.

    Return an array that contains all of the elements in this RDD.

    Definition Classes
    JavaRDDLike
  19. def collectAsMap(): Map[K, V]

    Return the key-value pairs in this RDD to the master as a Map.

  20. def combineByKey[C](createCombiner: Function[V, C], mergeValue: Function2[C, V, C], mergeCombiners: Function2[C, C, C]): JavaPairRDD[K, C]

    Simplified version of combineByKey that hash-partitions the resulting RDD using the default parallelism level.

  21. def combineByKey[C](createCombiner: Function[V, C], mergeValue: Function2[C, V, C], mergeCombiners: Function2[C, C, C], numSplits: Int): JavaPairRDD[K, C]

    Simplified version of combineByKey that hash-partitions the output RDD.

  22. def combineByKey[C](createCombiner: (V) ⇒ C, mergeValue: Function2[C, V, C], mergeCombiners: Function2[C, C, C], partitioner: Partitioner): JavaPairRDD[K, C]

    Generic function to combine the elements for each key using a custom set of aggregation functions.

    Generic function to combine the elements for each key using a custom set of aggregation functions. Turns a JavaPairRDD[(K, V)] into a result of type JavaPairRDD[(K, C)], for a "combined type" C * Note that V and C can be different -- for example, one might group an RDD of type (Int, Int) into an RDD of type (Int, List[Int]). Users provide three functions:

    - createCombiner, which turns a V into a C (e.g., creates a one-element list) - mergeValue, to merge a V into a C (e.g., adds it to the end of a list) - mergeCombiners, to combine two C's into a single one.

    In addition, users can control the partitioning of the output RDD, and whether to perform map-side aggregation (if a mapper can produce multiple items with the same key).

  23. def context: SparkContext

    The SparkContext that this RDD was created on.

    The SparkContext that this RDD was created on.

    Definition Classes
    JavaRDDLike
  24. def count(): Long

    Return the number of elements in the RDD.

    Return the number of elements in the RDD.

    Definition Classes
    JavaRDDLike
  25. def countApprox(timeout: Long): PartialResult[BoundedDouble]

    (Experimental) Approximate version of count() that returns a potentially incomplete result within a timeout, even if not all tasks have finished.

    (Experimental) Approximate version of count() that returns a potentially incomplete result within a timeout, even if not all tasks have finished.

    Definition Classes
    JavaRDDLike
  26. def countApprox(timeout: Long, confidence: Double): PartialResult[BoundedDouble]

    (Experimental) Approximate version of count() that returns a potentially incomplete result within a timeout, even if not all tasks have finished.

    (Experimental) Approximate version of count() that returns a potentially incomplete result within a timeout, even if not all tasks have finished.

    Definition Classes
    JavaRDDLike
  27. def countByKey(): Map[K, Long]

    Count the number of elements for each key, and return the result to the master as a Map.

  28. def countByKeyApprox(timeout: Long, confidence: Double = 0.95): PartialResult[Map[K, BoundedDouble]]

    (Experimental) Approximate version of countByKey that can return a partial result if it does not finish within a timeout.

  29. def countByKeyApprox(timeout: Long): PartialResult[Map[K, BoundedDouble]]

    (Experimental) Approximate version of countByKey that can return a partial result if it does not finish within a timeout.

  30. def countByValue(): Map[(K, V), Long]

    Return the count of each unique value in this RDD as a map of (value, count) pairs.

    Return the count of each unique value in this RDD as a map of (value, count) pairs. The final combine step happens locally on the master, equivalent to running a single reduce task.

    Definition Classes
    JavaRDDLike
  31. def countByValueApprox(timeout: Long): PartialResult[Map[(K, V), BoundedDouble]]

    (Experimental) Approximate version of countByValue().

    (Experimental) Approximate version of countByValue().

    Definition Classes
    JavaRDDLike
  32. def countByValueApprox(timeout: Long, confidence: Double): PartialResult[Map[(K, V), BoundedDouble]]

    (Experimental) Approximate version of countByValue().

    (Experimental) Approximate version of countByValue().

    Definition Classes
    JavaRDDLike
  33. def distinct(numSplits: Int): JavaPairRDD[K, V]

    Return a new RDD containing the distinct elements in this RDD.

  34. def distinct(): JavaPairRDD[K, V]

    Return a new RDD containing the distinct elements in this RDD.

  35. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  36. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  37. def filter(f: ((K, V)) ⇒ Boolean): JavaPairRDD[K, V]

    Return a new RDD containing only the elements that satisfy a predicate.

  38. def finalize(): Unit

    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws()
  39. def first(): (K, V)

    Return the first element in this RDD.

    Return the first element in this RDD.

    Definition Classes
    JavaPairRDDJavaRDDLike
  40. def flatMap(f: DoubleFlatMapFunction[(K, V)]): JavaDoubleRDD

    Return a new RDD by first applying a function to all elements of this RDD, and then flattening the results.

    Return a new RDD by first applying a function to all elements of this RDD, and then flattening the results.

    Definition Classes
    JavaRDDLike
  41. def flatMap[U](f: FlatMapFunction[(K, V), U]): JavaRDD[U]

    Return a new RDD by first applying a function to all elements of this RDD, and then flattening the results.

    Return a new RDD by first applying a function to all elements of this RDD, and then flattening the results.

    Definition Classes
    JavaRDDLike
  42. def flatMap[K, V](f: PairFlatMapFunction[(K, V), K, V]): JavaPairRDD[K, V]

    Definition Classes
    PairFlatMapWorkaround
  43. def flatMapValues[U](f: Function[V, Iterable[U]]): JavaPairRDD[K, U]

    Pass each value in the key-value pair RDD through a flatMap function without changing the keys; this also retains the original RDD's partitioning.

  44. def fold(zeroValue: (K, V))(f: Function2[(K, V), (K, V), (K, V)]): (K, V)

    Aggregate the elements of each partition, and then the results for all the partitions, using a given associative function and a neutral "zero value".

    Aggregate the elements of each partition, and then the results for all the partitions, using a given associative function and a neutral "zero value". The function op(t1, t2) is allowed to modify t1 and return it as its result value to avoid object allocation; however, it should not modify t2.

    Definition Classes
    JavaRDDLike
  45. def foreach(f: VoidFunction[(K, V)]): Unit

    Applies a function f to all elements of this RDD.

    Applies a function f to all elements of this RDD.

    Definition Classes
    JavaRDDLike
  46. final def getClass(): java.lang.Class[_]

    Definition Classes
    AnyRef → Any
  47. def getStorageLevel: StorageLevel

    Get the RDD's current storage level, or StorageLevel.

    Get the RDD's current storage level, or StorageLevel.NONE if none is set.

    Definition Classes
    JavaRDDLike
  48. def glom(): JavaRDD[List[(K, V)]]

    Return an RDD created by coalescing all elements within each partition into an array.

    Return an RDD created by coalescing all elements within each partition into an array.

    Definition Classes
    JavaRDDLike
  49. def groupBy[K](f: Function[(K, V), K], numSplits: Int): JavaPairRDD[K, List[(K, V)]]

    Return an RDD of grouped elements.

    Return an RDD of grouped elements. Each group consists of a key and a sequence of elements mapping to that key.

    Definition Classes
    JavaRDDLike
  50. def groupBy[K](f: Function[(K, V), K]): JavaPairRDD[K, List[(K, V)]]

    Return an RDD of grouped elements.

    Return an RDD of grouped elements. Each group consists of a key and a sequence of elements mapping to that key.

    Definition Classes
    JavaRDDLike
  51. def groupByKey(): JavaPairRDD[K, List[V]]

    Group the values for each key in the RDD into a single sequence.

    Group the values for each key in the RDD into a single sequence. Hash-partitions the resulting RDD with the default parallelism level.

  52. def groupByKey(numSplits: Int): JavaPairRDD[K, List[V]]

    Group the values for each key in the RDD into a single sequence.

    Group the values for each key in the RDD into a single sequence. Hash-partitions the resulting RDD with into numSplits partitions.

  53. def groupByKey(partitioner: Partitioner): JavaPairRDD[K, List[V]]

    Group the values for each key in the RDD into a single sequence.

    Group the values for each key in the RDD into a single sequence. Allows controlling the partitioning of the resulting key-value pair RDD by passing a Partitioner.

  54. def groupWith[W1, W2](other1: JavaPairRDD[K, W1], other2: JavaPairRDD[K, W2]): JavaPairRDD[K, (List[V], List[W1], List[W2])]

    Alias for cogroup.

  55. def groupWith[W](other: JavaPairRDD[K, W]): JavaPairRDD[K, (List[V], List[W])]

    Alias for cogroup.

  56. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  57. def id: Int

    A unique ID for this RDD (within its SparkContext).

    A unique ID for this RDD (within its SparkContext).

    Definition Classes
    JavaRDDLike
  58. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  59. def iterator(split: Split): Iterator[(K, V)]

    Internal method to this RDD; will read from cache if applicable, or otherwise compute it.

    Internal method to this RDD; will read from cache if applicable, or otherwise compute it. This should not be called by users directly, but is available for implementors of custom subclasses of RDD.

    Definition Classes
    JavaRDDLike
  60. def join[W](other: JavaPairRDD[K, W], numSplits: Int): JavaPairRDD[K, (V, W)]

    Return an RDD containing all pairs of elements with matching keys in this and other.

    Return an RDD containing all pairs of elements with matching keys in this and other. Each pair of elements will be returned as a (k, (v1, v2)) tuple, where (k, v1) is in this and (k, v2) is in other. Performs a hash join across the cluster.

  61. def join[W](other: JavaPairRDD[K, W]): JavaPairRDD[K, (V, W)]

    Return an RDD containing all pairs of elements with matching keys in this and other.

    Return an RDD containing all pairs of elements with matching keys in this and other. Each pair of elements will be returned as a (k, (v1, v2)) tuple, where (k, v1) is in this and (k, v2) is in other. Performs a hash join across the cluster.

  62. def join[W](other: JavaPairRDD[K, W], partitioner: Partitioner): JavaPairRDD[K, (V, W)]

    Merge the values for each key using an associative reduce function.

    Merge the values for each key using an associative reduce function. This will also perform the merging locally on each mapper before sending results to a reducer, similarly to a "combiner" in MapReduce.

  63. implicit val kManifest: ClassManifest[K]

  64. def leftOuterJoin[W](other: JavaPairRDD[K, W], numSplits: Int): JavaPairRDD[K, (V, Option[W])]

    Perform a left outer join of this and other.

    Perform a left outer join of this and other. For each element (k, v) in this, the resulting RDD will either contain all pairs (k, (v, Some(w))) for w in other, or the pair (k, (v, None)) if no elements in other have key k. Hash-partitions the output into numSplits partitions.

  65. def leftOuterJoin[W](other: JavaPairRDD[K, W]): JavaPairRDD[K, (V, Option[W])]

    Perform a left outer join of this and other.

    Perform a left outer join of this and other. For each element (k, v) in this, the resulting RDD will either contain all pairs (k, (v, Some(w))) for w in other, or the pair (k, (v, None)) if no elements in other have key k. Hash-partitions the output using the default level of parallelism.

  66. def leftOuterJoin[W](other: JavaPairRDD[K, W], partitioner: Partitioner): JavaPairRDD[K, (V, Option[W])]

    Perform a left outer join of this and other.

    Perform a left outer join of this and other. For each element (k, v) in this, the resulting RDD will either contain all pairs (k, (v, Some(w))) for w in other, or the pair (k, (v, None)) if no elements in other have key k. Uses the given Partitioner to partition the output RDD.

  67. def lookup(key: K): List[V]

    Return the list of values in the RDD for key key.

    Return the list of values in the RDD for key key. This operation is done efficiently if the RDD has a known partitioner by only searching the partition that the key maps to.

  68. def map[K2, V2](f: PairFunction[(K, V), K2, V2]): JavaPairRDD[K2, V2]

    Return a new RDD by applying a function to all elements of this RDD.

    Return a new RDD by applying a function to all elements of this RDD.

    Definition Classes
    JavaRDDLike
  69. def map[R](f: DoubleFunction[(K, V)]): JavaDoubleRDD

    Return a new RDD by applying a function to all elements of this RDD.

    Return a new RDD by applying a function to all elements of this RDD.

    Definition Classes
    JavaRDDLike
  70. def map[R](f: Function[(K, V), R]): JavaRDD[R]

    Return a new RDD by applying a function to all elements of this RDD.

    Return a new RDD by applying a function to all elements of this RDD.

    Definition Classes
    JavaRDDLike
  71. def mapPartitions[K, V](f: PairFlatMapFunction[Iterator[(K, V)], K, V]): JavaPairRDD[K, V]

    Return a new RDD by applying a function to each partition of this RDD.

    Return a new RDD by applying a function to each partition of this RDD.

    Definition Classes
    JavaRDDLike
  72. def mapPartitions(f: DoubleFlatMapFunction[Iterator[(K, V)]]): JavaDoubleRDD

    Return a new RDD by applying a function to each partition of this RDD.

    Return a new RDD by applying a function to each partition of this RDD.

    Definition Classes
    JavaRDDLike
  73. def mapPartitions[U](f: FlatMapFunction[Iterator[(K, V)], U]): JavaRDD[U]

    Return a new RDD by applying a function to each partition of this RDD.

    Return a new RDD by applying a function to each partition of this RDD.

    Definition Classes
    JavaRDDLike
  74. def mapValues[U](f: (V) ⇒ U): JavaPairRDD[K, U]

    Pass each value in the key-value pair RDD through a map function without changing the keys; this also retains the original RDD's partitioning.

  75. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  76. final def notify(): Unit

    Definition Classes
    AnyRef
  77. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  78. def partitionBy(partitioner: Partitioner): JavaPairRDD[K, V]

    Return a copy of the RDD partitioned using the specified partitioner.

    Return a copy of the RDD partitioned using the specified partitioner. If mapSideCombine is true, Spark will group values of the same key together on the map side before the repartitioning, to only send each key over the network once. If a large number of duplicated keys are expected, and the size of the keys are large, mapSideCombine should be set to true.

  79. def persist(newLevel: StorageLevel): JavaPairRDD[K, V]

    Set this RDD's storage level to persist its values across operations after the first time it is computed.

    Set this RDD's storage level to persist its values across operations after the first time it is computed. Can only be called once on each RDD.

  80. def pipe(command: List[String], env: Map[String, String]): JavaRDD[String]

    Return an RDD created by piping elements to a forked external process.

    Return an RDD created by piping elements to a forked external process.

    Definition Classes
    JavaRDDLike
  81. def pipe(command: List[String]): JavaRDD[String]

    Return an RDD created by piping elements to a forked external process.

    Return an RDD created by piping elements to a forked external process.

    Definition Classes
    JavaRDDLike
  82. def pipe(command: String): JavaRDD[String]

    Return an RDD created by piping elements to a forked external process.

    Return an RDD created by piping elements to a forked external process.

    Definition Classes
    JavaRDDLike
  83. val rdd: RDD[(K, V)]

    Definition Classes
    JavaPairRDDJavaRDDLike
  84. def reduce(f: Function2[(K, V), (K, V), (K, V)]): (K, V)

    Reduces the elements of this RDD using the specified associative binary operator.

    Reduces the elements of this RDD using the specified associative binary operator.

    Definition Classes
    JavaRDDLike
  85. def reduceByKey(func: Function2[V, V, V]): JavaPairRDD[K, V]

    Merge the values for each key using an associative reduce function.

    Merge the values for each key using an associative reduce function. This will also perform the merging locally on each mapper before sending results to a reducer, similarly to a "combiner" in MapReduce. Output will be hash-partitioned with the default parallelism level.

  86. def reduceByKey(func: Function2[V, V, V], numSplits: Int): JavaPairRDD[K, V]

    Merge the values for each key using an associative reduce function.

    Merge the values for each key using an associative reduce function. This will also perform the merging locally on each mapper before sending results to a reducer, similarly to a "combiner" in MapReduce. Output will be hash-partitioned with numSplits splits.

  87. def reduceByKey(partitioner: Partitioner, func: Function2[V, V, V]): JavaPairRDD[K, V]

    Merge the values for each key using an associative reduce function.

    Merge the values for each key using an associative reduce function. This will also perform the merging locally on each mapper before sending results to a reducer, similarly to a "combiner" in MapReduce.

  88. def reduceByKeyLocally(func: Function2[V, V, V]): Map[K, V]

    Merge the values for each key using an associative reduce function, but return the results immediately to the master as a Map.

    Merge the values for each key using an associative reduce function, but return the results immediately to the master as a Map. This will also perform the merging locally on each mapper before sending results to a reducer, similarly to a "combiner" in MapReduce.

  89. def rightOuterJoin[W](other: JavaPairRDD[K, W], numSplits: Int): JavaPairRDD[K, (Option[V], W)]

    Perform a right outer join of this and other.

    Perform a right outer join of this and other. For each element (k, w) in other, the resulting RDD will either contain all pairs (k, (Some(v), w)) for v in this, or the pair (k, (None, w)) if no elements in this have key k. Hash-partitions the resulting RDD into the given number of partitions.

  90. def rightOuterJoin[W](other: JavaPairRDD[K, W]): JavaPairRDD[K, (Option[V], W)]

    Perform a right outer join of this and other.

    Perform a right outer join of this and other. For each element (k, w) in other, the resulting RDD will either contain all pairs (k, (Some(v), w)) for v in this, or the pair (k, (None, w)) if no elements in this have key k. Hash-partitions the resulting RDD using the default parallelism level.

  91. def rightOuterJoin[W](other: JavaPairRDD[K, W], partitioner: Partitioner): JavaPairRDD[K, (Option[V], W)]

    Perform a right outer join of this and other.

    Perform a right outer join of this and other. For each element (k, w) in other, the resulting RDD will either contain all pairs (k, (Some(v), w)) for v in this, or the pair (k, (None, w)) if no elements in this have key k. Uses the given Partitioner to partition the output RDD.

  92. def sample(withReplacement: Boolean, fraction: Double, seed: Int): JavaPairRDD[K, V]

    Return a sampled subset of this RDD.

  93. def saveAsHadoopDataset(conf: JobConf): Unit

    Output the RDD to any Hadoop-supported storage system, using a Hadoop JobConf object for that storage system.

    Output the RDD to any Hadoop-supported storage system, using a Hadoop JobConf object for that storage system. The JobConf should set an OutputFormat and any output paths required (e.g. a table name to write to) in the same way as it would be configured for a Hadoop MapReduce job.

  94. def saveAsHadoopFile[F <: org.apache.hadoop.mapred.OutputFormat[_, _]](path: String, keyClass: Class[_], valueClass: Class[_], outputFormatClass: Class[F]): Unit

    Output the RDD to any Hadoop-supported file system.

  95. def saveAsHadoopFile[F <: org.apache.hadoop.mapred.OutputFormat[_, _]](path: String, keyClass: Class[_], valueClass: Class[_], outputFormatClass: Class[F], conf: JobConf): Unit

    Output the RDD to any Hadoop-supported file system.

  96. def saveAsNewAPIHadoopFile[F <: org.apache.hadoop.mapreduce.OutputFormat[_, _]](path: String, keyClass: Class[_], valueClass: Class[_], outputFormatClass: Class[F]): Unit

    Output the RDD to any Hadoop-supported file system.

  97. def saveAsNewAPIHadoopFile[F <: org.apache.hadoop.mapreduce.OutputFormat[_, _]](path: String, keyClass: Class[_], valueClass: Class[_], outputFormatClass: Class[F], conf: Configuration): Unit

    Output the RDD to any Hadoop-supported file system.

  98. def saveAsObjectFile(path: String): Unit

    Save this RDD as a SequenceFile of serialized objects.

    Save this RDD as a SequenceFile of serialized objects.

    Definition Classes
    JavaRDDLike
  99. def saveAsTextFile(path: String): Unit

    Save this RDD as a text file, using string representations of elements.

    Save this RDD as a text file, using string representations of elements.

    Definition Classes
    JavaRDDLike
  100. def sortByKey(comp: Comparator[K], ascending: Boolean): JavaPairRDD[K, V]

    Sort the RDD by key, so that each partition contains a sorted range of the elements.

    Sort the RDD by key, so that each partition contains a sorted range of the elements. Calling collect or save on the resulting RDD will return or output an ordered list of records (in the save case, they will be written to multiple part-X files in the filesystem, in order of the keys).

  101. def sortByKey(comp: Comparator[K]): JavaPairRDD[K, V]

    Sort the RDD by key, so that each partition contains a sorted range of the elements.

    Sort the RDD by key, so that each partition contains a sorted range of the elements. Calling collect or save on the resulting RDD will return or output an ordered list of records (in the save case, they will be written to multiple part-X files in the filesystem, in order of the keys).

  102. def sortByKey(ascending: Boolean): JavaPairRDD[K, V]

    Sort the RDD by key, so that each partition contains a sorted range of the elements.

    Sort the RDD by key, so that each partition contains a sorted range of the elements. Calling collect or save on the resulting RDD will return or output an ordered list of records (in the save case, they will be written to multiple part-X files in the filesystem, in order of the keys).

  103. def sortByKey(): JavaPairRDD[K, V]

    Sort the RDD by key, so that each partition contains a sorted range of the elements in ascending order.

    Sort the RDD by key, so that each partition contains a sorted range of the elements in ascending order. Calling collect or save on the resulting RDD will return or output an ordered list of records (in the save case, they will be written to multiple part-X files in the filesystem, in order of the keys).

  104. def splits: List[Split]

    Set of partitions in this RDD.

    Set of partitions in this RDD.

    Definition Classes
    JavaRDDLike
  105. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  106. def take(num: Int): List[(K, V)]

    Take the first num elements of the RDD.

    Take the first num elements of the RDD. This currently scans the partitions *one by one*, so it will be slow if a lot of partitions are required. In that case, use collect() to get the whole RDD instead.

    Definition Classes
    JavaRDDLike
  107. def takeSample(withReplacement: Boolean, num: Int, seed: Int): List[(K, V)]

    Definition Classes
    JavaRDDLike
  108. def toString(): String

    Definition Classes
    AnyRef → Any
  109. def union(other: JavaPairRDD[K, V]): JavaPairRDD[K, V]

    Return the union of this RDD and another one.

    Return the union of this RDD and another one. Any identical elements will appear multiple times (use .distinct() to eliminate them).

  110. implicit val vManifest: ClassManifest[V]

  111. final def wait(): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws()
  112. final def wait(arg0: Long, arg1: Int): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws()
  113. final def wait(arg0: Long): Unit

    Definition Classes
    AnyRef
    Annotations
    @throws()
  114. def wrapRDD(rdd: RDD[(K, V)]): JavaPairRDD[K, V]

    Definition Classes
    JavaPairRDDJavaRDDLike

Inherited from JavaRDDLike[(K, V), JavaPairRDD[K, V]]

Inherited from PairFlatMapWorkaround[(K, V)]

Inherited from Serializable

Inherited from AnyRef

Inherited from Any