com.datastax.spark.connector.japi.rdd

CassandraJavaRDD

class CassandraJavaRDD[R] extends JavaRDD[R]

Linear Supertypes
JavaRDD[R], AbstractJavaRDDLike[R, JavaRDD[R]], JavaRDDLike[R, JavaRDD[R]], Serializable, Serializable, AnyRef, Any
Known Subclasses
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. CassandraJavaRDD
  2. JavaRDD
  3. AbstractJavaRDDLike
  4. JavaRDDLike
  5. Serializable
  6. Serializable
  7. AnyRef
  8. Any
Implicitly
  1. by toRDD
  2. by any2stringadd
  3. by any2stringfmt
  4. by any2ArrowAssoc
  5. by any2Ensuring
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new CassandraJavaRDD(rdd: CassandraRDD[R], classTag: ClassTag[R])

  2. new CassandraJavaRDD(rdd: CassandraRDD[R], clazz: Class[R])

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. def +(other: String): String

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to StringAdd performed by method any2stringadd in scala.Predef.
    Definition Classes
    StringAdd
  5. def ++(other: RDD[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  6. def ->[B](y: B): (CassandraJavaRDD[R], B)

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to ArrowAssoc[CassandraJavaRDD[R]] performed by method any2ArrowAssoc in scala.Predef.
    Definition Classes
    ArrowAssoc
    Annotations
    @inline()
  7. final def ==(arg0: AnyRef): Boolean

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

    Definition Classes
    Any
  9. def aggregate[U](zeroValue: U)(seqOp: Function2[U, R, U], combOp: Function2[U, U, U]): U

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

    Definition Classes
    Any
  11. def cache(): JavaRDD[R]

    Definition Classes
    JavaRDD
  12. def cartesian[U](other: JavaRDDLike[U, _]): JavaPairRDD[R, U]

    Definition Classes
    JavaRDDLike
  13. def cassandraCount(): Long

  14. def checkpoint(): Unit

    Definition Classes
    JavaRDDLike
  15. implicit val classTag: ClassTag[R]

    Definition Classes
    JavaRDD → JavaRDDLike
  16. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  17. def coalesce(numPartitions: Int, shuffle: Boolean): JavaRDD[R]

    Definition Classes
    JavaRDD
  18. def coalesce(numPartitions: Int): JavaRDD[R]

    Definition Classes
    JavaRDD
  19. def collect(): List[R]

    Definition Classes
    JavaRDDLike
  20. def collectAsync(): JavaFutureAction[List[R]]

    Definition Classes
    JavaRDDLike
  21. def collectPartitions(partitionIds: Array[Int]): Array[List[R]]

    Definition Classes
    JavaRDDLike
  22. def compute(split: Partition, context: TaskContext): Iterator[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @DeveloperApi()
  23. def context: SparkContext

    Definition Classes
    JavaRDDLike
  24. def count(): Long

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

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

    Definition Classes
    JavaRDDLike
    Annotations
    @Experimental()
  27. def countApproxDistinct(relativeSD: Double): Long

    Definition Classes
    JavaRDDLike
  28. def countAsync(): JavaFutureAction[Long]

    Definition Classes
    JavaRDDLike
  29. def countByValue(): Map[R, Long]

    Definition Classes
    JavaRDDLike
  30. def countByValueApprox(timeout: Long): PartialResult[Map[R, BoundedDouble]]

    Definition Classes
    JavaRDDLike
  31. def countByValueApprox(timeout: Long, confidence: Double): PartialResult[Map[R, BoundedDouble]]

    Definition Classes
    JavaRDDLike
  32. final def dependencies: Seq[Dependency[_]]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  33. def distinct(numPartitions: Int): JavaRDD[R]

    Definition Classes
    JavaRDD
  34. def distinct(): JavaRDD[R]

    Definition Classes
    JavaRDD
  35. def ensuring(cond: (CassandraJavaRDD[R]) ⇒ Boolean, msg: ⇒ Any): CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]] performed by method any2Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  36. def ensuring(cond: (CassandraJavaRDD[R]) ⇒ Boolean): CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]] performed by method any2Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  37. def ensuring(cond: Boolean, msg: ⇒ Any): CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]] performed by method any2Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  38. def ensuring(cond: Boolean): CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]] performed by method any2Ensuring in scala.Predef.
    Definition Classes
    Ensuring
  39. final def eq(arg0: AnyRef): Boolean

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

    Definition Classes
    AnyRef → Any
  41. def filter(f: Function[R, Boolean]): JavaRDD[R]

    Definition Classes
    JavaRDD
  42. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  43. def first(): R

    Definition Classes
    JavaRDDLike
  44. def flatMap[U](f: FlatMapFunction[R, U]): JavaRDD[U]

    Definition Classes
    JavaRDDLike
  45. def flatMapToDouble(f: DoubleFlatMapFunction[R]): JavaDoubleRDD

    Definition Classes
    JavaRDDLike
  46. def flatMapToPair[K2, V2](f: PairFlatMapFunction[R, K2, V2]): JavaPairRDD[K2, V2]

    Definition Classes
    JavaRDDLike
  47. def fold(zeroValue: R)(f: Function2[R, R, R]): R

    Definition Classes
    JavaRDDLike
  48. def foreach(f: VoidFunction[R]): Unit

    Definition Classes
    JavaRDDLike
  49. def foreachAsync(f: VoidFunction[R]): JavaFutureAction[Void]

    Definition Classes
    JavaRDDLike
  50. def foreachPartition(f: VoidFunction[Iterator[R]]): Unit

    Definition Classes
    JavaRDDLike
  51. def foreachPartitionAsync(f: VoidFunction[Iterator[R]]): JavaFutureAction[Void]

    Definition Classes
    JavaRDDLike
  52. def formatted(fmtstr: String): String

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to StringFormat performed by method any2stringfmt in scala.Predef.
    Definition Classes
    StringFormat
    Annotations
    @inline()
  53. def getCheckpointFile(): Optional[String]

    Definition Classes
    JavaRDDLike
  54. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  55. def getStorageLevel: StorageLevel

    Definition Classes
    JavaRDDLike
  56. def glom(): JavaRDD[List[R]]

    Definition Classes
    JavaRDDLike
  57. def groupBy[U](f: Function[R, U], numPartitions: Int): JavaPairRDD[U, Iterable[R]]

    Definition Classes
    JavaRDDLike
  58. def groupBy[U](f: Function[R, U]): JavaPairRDD[U, Iterable[R]]

    Definition Classes
    JavaRDDLike
  59. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  60. def id: Int

    Definition Classes
    JavaRDDLike
  61. def intersection(other: JavaRDD[R]): JavaRDD[R]

    Definition Classes
    JavaRDD
  62. def isCheckpointed: Boolean

    Definition Classes
    JavaRDDLike
  63. def isEmpty(): Boolean

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

    Definition Classes
    Any
  65. def iterator(split: Partition, taskContext: TaskContext): Iterator[R]

    Definition Classes
    JavaRDDLike
  66. def keyBy[U](f: Function[R, U]): JavaPairRDD[U, R]

    Definition Classes
    JavaRDDLike
  67. def limit(rowsNumber: Long): CassandraJavaRDD[R]

  68. def map[R](f: Function[R, R]): JavaRDD[R]

    Definition Classes
    JavaRDDLike
  69. def mapPartitions[U](f: FlatMapFunction[Iterator[R], U], preservesPartitioning: Boolean): JavaRDD[U]

    Definition Classes
    JavaRDDLike
  70. def mapPartitions[U](f: FlatMapFunction[Iterator[R], U]): JavaRDD[U]

    Definition Classes
    JavaRDDLike
  71. def mapPartitionsToDouble(f: DoubleFlatMapFunction[Iterator[R]], preservesPartitioning: Boolean): JavaDoubleRDD

    Definition Classes
    JavaRDDLike
  72. def mapPartitionsToDouble(f: DoubleFlatMapFunction[Iterator[R]]): JavaDoubleRDD

    Definition Classes
    JavaRDDLike
  73. def mapPartitionsToPair[K2, V2](f: PairFlatMapFunction[Iterator[R], K2, V2], preservesPartitioning: Boolean): JavaPairRDD[K2, V2]

    Definition Classes
    JavaRDDLike
  74. def mapPartitionsToPair[K2, V2](f: PairFlatMapFunction[Iterator[R], K2, V2]): JavaPairRDD[K2, V2]

    Definition Classes
    JavaRDDLike
  75. def mapPartitionsWithIndex[R](f: Function2[Integer, Iterator[R], Iterator[R]], preservesPartitioning: Boolean): JavaRDD[R]

    Definition Classes
    JavaRDDLike
  76. def mapToDouble[R](f: DoubleFunction[R]): JavaDoubleRDD

    Definition Classes
    JavaRDDLike
  77. def mapToPair[K2, V2](f: PairFunction[R, K2, V2]): JavaPairRDD[K2, V2]

    Definition Classes
    JavaRDDLike
  78. def max(comp: Comparator[R]): R

    Definition Classes
    JavaRDDLike
  79. def min(comp: Comparator[R]): R

    Definition Classes
    JavaRDDLike
  80. def name(): String

    Definition Classes
    JavaRDDLike
  81. final def ne(arg0: AnyRef): Boolean

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

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

    Definition Classes
    AnyRef
  84. val partitioner: Option[Partitioner]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  85. def partitions: List[Partition]

    Definition Classes
    JavaRDDLike
  86. def persist(newLevel: StorageLevel): JavaRDD[R]

    Definition Classes
    JavaRDD
  87. def pipe(command: List[String], env: Map[String, String]): JavaRDD[String]

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

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

    Definition Classes
    JavaRDDLike
  90. final def preferredLocations(split: Partition): Seq[String]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  91. def randomSplit(weights: Array[Double], seed: Long): Array[JavaRDD[R]]

    Definition Classes
    JavaRDD
  92. def randomSplit(weights: Array[Double]): Array[JavaRDD[R]]

    Definition Classes
    JavaRDD
  93. def rdd(): CassandraRDD[R]

    Definition Classes
    CassandraJavaRDD → JavaRDD → JavaRDDLike
  94. def reduce(f: Function2[R, R, R]): R

    Definition Classes
    JavaRDDLike
  95. def repartition(numPartitions: Int): JavaRDD[R]

    Definition Classes
    JavaRDD
  96. def sample(withReplacement: Boolean, fraction: Double, seed: Long): JavaRDD[R]

    Definition Classes
    JavaRDD
  97. def sample(withReplacement: Boolean, fraction: Double): JavaRDD[R]

    Definition Classes
    JavaRDD
  98. def saveAsObjectFile(path: String): Unit

    Definition Classes
    JavaRDDLike
  99. def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit

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

    Definition Classes
    JavaRDDLike
  101. def select(columns: <repeated...>[ColumnRef]): CassandraJavaRDD[R]

  102. def select(columnNames: <repeated...>[String]): CassandraJavaRDD[R]

  103. def selectedColumnNames(): Array[String]

  104. def selectedColumnRefs(): Array[ColumnRef]

  105. def setName(name: String): JavaRDD[R]

    Definition Classes
    JavaRDD
  106. def sortBy[S](f: Function[R, S], ascending: Boolean, numPartitions: Int): JavaRDD[R]

    Definition Classes
    JavaRDD
  107. def spanBy[K](f: Function[R, K], keyClass: Class[K]): JavaPairRDD[K, Iterable[R]]

  108. def spanBy[K](f: Function[R, K], keyClassTag: ClassTag[K]): JavaPairRDD[K, Iterable[R]]

  109. def sparkContext: SparkContext

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  110. def subtract(other: JavaRDD[R], p: Partitioner): JavaRDD[R]

    Definition Classes
    JavaRDD
  111. def subtract(other: JavaRDD[R], numPartitions: Int): JavaRDD[R]

    Definition Classes
    JavaRDD
  112. def subtract(other: JavaRDD[R]): JavaRDD[R]

    Definition Classes
    JavaRDD
  113. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  114. def take(num: Int): List[R]

    Definition Classes
    JavaRDDLike
  115. def takeAsync(num: Int): JavaFutureAction[List[R]]

    Definition Classes
    JavaRDDLike
  116. def takeOrdered(num: Int): List[R]

    Definition Classes
    JavaRDDLike
  117. def takeOrdered(num: Int, comp: Comparator[R]): List[R]

    Definition Classes
    JavaRDDLike
  118. def takeSample(withReplacement: Boolean, num: Int, seed: Long): List[R]

    Definition Classes
    JavaRDDLike
  119. def takeSample(withReplacement: Boolean, num: Int): List[R]

    Definition Classes
    JavaRDDLike
  120. def toArray(): List[R]

    Definition Classes
    JavaRDDLike
    Annotations
    @Deprecated
  121. def toDebugString(): String

    Definition Classes
    JavaRDDLike
  122. def toEmptyCassandraRDD(): CassandraJavaRDD[R]

  123. def toJavaRDD(): JavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
  124. def toLocalIterator(): Iterator[R]

    Definition Classes
    JavaRDDLike
  125. def toString(): String

    Definition Classes
    JavaRDD → AnyRef → Any
  126. def top(num: Int): List[R]

    Definition Classes
    JavaRDDLike
  127. def top(num: Int, comp: Comparator[R]): List[R]

    Definition Classes
    JavaRDDLike
  128. def treeAggregate[U](zeroValue: U, seqOp: Function2[U, R, U], combOp: Function2[U, U, U]): U

    Definition Classes
    JavaRDDLike
  129. def treeAggregate[U](zeroValue: U, seqOp: Function2[U, R, U], combOp: Function2[U, U, U], depth: Int): U

    Definition Classes
    JavaRDDLike
  130. def treeReduce(f: Function2[R, R, R]): R

    Definition Classes
    JavaRDDLike
  131. def treeReduce(f: Function2[R, R, R], depth: Int): R

    Definition Classes
    JavaRDDLike
  132. def union(other: JavaRDD[R]): JavaRDD[R]

    Definition Classes
    JavaRDD
  133. def unpersist(blocking: Boolean): JavaRDD[R]

    Definition Classes
    JavaRDD
  134. def unpersist(): JavaRDD[R]

    Definition Classes
    JavaRDD
  135. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  138. def where(cqlWhereClause: String, args: <repeated...>[AnyRef]): CassandraJavaRDD[R]

  139. def withAscOrder(): CassandraJavaRDD[R]

  140. def withConnector(connector: CassandraConnector): CassandraJavaRDD[R]

  141. def withDescOrder(): CassandraJavaRDD[R]

  142. def withReadConf(config: ReadConf): CassandraJavaRDD[R]

  143. def wrap(newRDD: CassandraRDD[R]): CassandraJavaRDD[R]

  144. def wrapRDD(rdd: RDD[R]): JavaRDD[R]

    Definition Classes
    JavaRDD → JavaRDDLike
  145. def zip[U](other: JavaRDDLike[U, _]): JavaPairRDD[R, U]

    Definition Classes
    JavaRDDLike
  146. def zipPartitions[U, V](other: JavaRDDLike[U, _], f: FlatMapFunction2[Iterator[R], Iterator[U], V]): JavaRDD[V]

    Definition Classes
    JavaRDDLike
  147. def zipWithIndex(): JavaPairRDD[R, Long]

    Definition Classes
    JavaRDDLike
  148. def zipWithUniqueId(): JavaPairRDD[R, Long]

    Definition Classes
    JavaRDDLike
  149. def [B](y: B): (CassandraJavaRDD[R], B)

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to ArrowAssoc[CassandraJavaRDD[R]] performed by method any2ArrowAssoc in scala.Predef.
    Definition Classes
    ArrowAssoc

Shadowed Implicit Value Members

  1. def aggregate[U](zeroValue: U)(seqOp: (U, R) ⇒ U, combOp: (U, U) ⇒ U)(implicit arg0: ClassTag[U]): U

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).aggregate(zeroValue)(seqOp, combOp)(arg0)
    Definition Classes
    RDD
  2. def cache(): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).cache()
    Definition Classes
    RDD
  3. def cartesian[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(R, U)]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).cartesian(other)(arg0)
    Definition Classes
    RDD
  4. def checkpoint(): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).checkpoint()
    Definition Classes
    RDD
  5. def coalesce(numPartitions: Int, shuffle: Boolean)(implicit ord: Ordering[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).coalesce(numPartitions, shuffle)(ord)
    Definition Classes
    RDD
  6. def collect[U](f: PartialFunction[R, U])(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).collect(f)(arg0)
    Definition Classes
    RDD
  7. def collect(): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).collect()
    Definition Classes
    RDD
  8. def context: SparkContext

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).context
    Definition Classes
    RDD
  9. def count(): Long

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).count()
    Definition Classes
    RDD
  10. def countApprox(timeout: Long, confidence: Double): PartialResult[BoundedDouble]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).countApprox(timeout, confidence)
    Definition Classes
    RDD
    Annotations
    @Experimental()
  11. def countApproxDistinct(relativeSD: Double): Long

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).countApproxDistinct(relativeSD)
    Definition Classes
    RDD
  12. def countApproxDistinct(p: Int, sp: Int): Long

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).countApproxDistinct(p, sp)
    Definition Classes
    RDD
    Annotations
    @Experimental()
  13. def countByValue()(implicit ord: Ordering[R]): Map[R, Long]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).countByValue()(ord)
    Definition Classes
    RDD
  14. def countByValueApprox(timeout: Long, confidence: Double)(implicit ord: Ordering[R]): PartialResult[Map[R, BoundedDouble]]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).countByValueApprox(timeout, confidence)(ord)
    Definition Classes
    RDD
    Annotations
    @Experimental()
  15. def distinct(): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).distinct()
    Definition Classes
    RDD
  16. def distinct(numPartitions: Int)(implicit ord: Ordering[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).distinct(numPartitions)(ord)
    Definition Classes
    RDD
  17. def filter(f: (R) ⇒ Boolean): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).filter(f)
    Definition Classes
    RDD
  18. def first(): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).first()
    Definition Classes
    RDD
  19. def flatMap[U](f: (R) ⇒ TraversableOnce[U])(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).flatMap(f)(arg0)
    Definition Classes
    RDD
  20. def fold(zeroValue: R)(op: (R, R) ⇒ R): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).fold(zeroValue)(op)
    Definition Classes
    RDD
  21. def foreach(f: (R) ⇒ Unit): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).foreach(f)
    Definition Classes
    RDD
  22. def foreachPartition(f: (Iterator[R]) ⇒ Unit): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).foreachPartition(f)
    Definition Classes
    RDD
  23. def getCheckpointFile: Option[String]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).getCheckpointFile
    Definition Classes
    RDD
  24. def getStorageLevel: StorageLevel

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).getStorageLevel
    Definition Classes
    RDD
  25. def glom(): RDD[Array[R]]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).glom()
    Definition Classes
    RDD
  26. def groupBy[K](f: (R) ⇒ K, p: Partitioner)(implicit kt: ClassTag[K], ord: Ordering[K]): RDD[(K, Iterable[R])]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).groupBy(f, p)(kt, ord)
    Definition Classes
    RDD
  27. def groupBy[K](f: (R) ⇒ K, numPartitions: Int)(implicit kt: ClassTag[K]): RDD[(K, Iterable[R])]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).groupBy(f, numPartitions)(kt)
    Definition Classes
    RDD
  28. def groupBy[K](f: (R) ⇒ K)(implicit kt: ClassTag[K]): RDD[(K, Iterable[R])]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).groupBy(f)(kt)
    Definition Classes
    RDD
  29. val id: Int

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).id
    Definition Classes
    RDD
  30. def intersection(other: RDD[R], numPartitions: Int): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).intersection(other, numPartitions)
    Definition Classes
    RDD
  31. def intersection(other: RDD[R], partitioner: Partitioner)(implicit ord: Ordering[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).intersection(other, partitioner)(ord)
    Definition Classes
    RDD
  32. def intersection(other: RDD[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).intersection(other)
    Definition Classes
    RDD
  33. def isCheckpointed: Boolean

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).isCheckpointed
    Definition Classes
    RDD
  34. def isEmpty(): Boolean

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).isEmpty()
    Definition Classes
    RDD
  35. final def iterator(split: Partition, context: TaskContext): Iterator[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).iterator(split, context)
    Definition Classes
    RDD
  36. def keyBy[K](f: (R) ⇒ K): RDD[(K, R)]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).keyBy(f)
    Definition Classes
    RDD
  37. def map[U](f: (R) ⇒ U)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).map(f)(arg0)
    Definition Classes
    RDD
  38. def mapPartitions[U](f: (Iterator[R]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).mapPartitions(f, preservesPartitioning)(arg0)
    Definition Classes
    RDD
  39. def mapPartitionsWithIndex[U](f: (Int, Iterator[R]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).mapPartitionsWithIndex(f, preservesPartitioning)(arg0)
    Definition Classes
    RDD
  40. def max()(implicit ord: Ordering[R]): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).max()(ord)
    Definition Classes
    RDD
  41. def min()(implicit ord: Ordering[R]): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).min()(ord)
    Definition Classes
    RDD
  42. var name: String

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).name
    Definition Classes
    RDD
  43. final def partitions: Array[Partition]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).partitions
    Definition Classes
    RDD
  44. def persist(): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).persist()
    Definition Classes
    RDD
  45. def persist(newLevel: StorageLevel): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).persist(newLevel)
    Definition Classes
    RDD
  46. def pipe(command: Seq[String], env: Map[String, String], printPipeContext: ((String) ⇒ Unit) ⇒ Unit, printRDDElement: (R, (String) ⇒ Unit) ⇒ Unit, separateWorkingDir: Boolean): RDD[String]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).pipe(command, env, printPipeContext, printRDDElement, separateWorkingDir)
    Definition Classes
    RDD
  47. def pipe(command: String, env: Map[String, String]): RDD[String]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).pipe(command, env)
    Definition Classes
    RDD
  48. def pipe(command: String): RDD[String]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).pipe(command)
    Definition Classes
    RDD
  49. def randomSplit(weights: Array[Double], seed: Long): Array[RDD[R]]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).randomSplit(weights, seed)
    Definition Classes
    RDD
  50. def reduce(f: (R, R) ⇒ R): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).reduce(f)
    Definition Classes
    RDD
  51. def repartition(numPartitions: Int)(implicit ord: Ordering[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).repartition(numPartitions)(ord)
    Definition Classes
    RDD
  52. def sample(withReplacement: Boolean, fraction: Double, seed: Long): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).sample(withReplacement, fraction, seed)
    Definition Classes
    RDD
  53. def saveAsObjectFile(path: String): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).saveAsObjectFile(path)
    Definition Classes
    RDD
  54. def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).saveAsTextFile(path, codec)
    Definition Classes
    RDD
  55. def saveAsTextFile(path: String): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).saveAsTextFile(path)
    Definition Classes
    RDD
  56. val self: Any

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to StringAdd performed by method any2stringadd in scala.Predef.
    Shadowing
    This implicitly inherited member is ambiguous. One or more implicitly inherited members have similar signatures, so calling this member may produce an ambiguous implicit conversion compiler error.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: StringAdd).self
    Definition Classes
    StringAdd
  57. val self: Any

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to StringFormat performed by method any2stringfmt in scala.Predef.
    Shadowing
    This implicitly inherited member is ambiguous. One or more implicitly inherited members have similar signatures, so calling this member may produce an ambiguous implicit conversion compiler error.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: StringFormat).self
    Definition Classes
    StringFormat
  58. def setName(_name: String): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).setName(_name)
    Definition Classes
    RDD
  59. def sortBy[K](f: (R) ⇒ K, ascending: Boolean, numPartitions: Int)(implicit ord: Ordering[K], ctag: ClassTag[K]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).sortBy(f, ascending, numPartitions)(ord, ctag)
    Definition Classes
    RDD
  60. def subtract(other: RDD[R], p: Partitioner)(implicit ord: Ordering[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).subtract(other, p)(ord)
    Definition Classes
    RDD
  61. def subtract(other: RDD[R], numPartitions: Int): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).subtract(other, numPartitions)
    Definition Classes
    RDD
  62. def subtract(other: RDD[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).subtract(other)
    Definition Classes
    RDD
  63. def take(num: Int): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).take(num)
    Definition Classes
    RDD
  64. def takeOrdered(num: Int)(implicit ord: Ordering[R]): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).takeOrdered(num)(ord)
    Definition Classes
    RDD
  65. def takeSample(withReplacement: Boolean, num: Int, seed: Long): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).takeSample(withReplacement, num, seed)
    Definition Classes
    RDD
  66. def toDebugString: String

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).toDebugString
    Definition Classes
    RDD
  67. def toLocalIterator: Iterator[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).toLocalIterator
    Definition Classes
    RDD
  68. def toString(): String

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).toString()
    Definition Classes
    RDD → AnyRef → Any
  69. def top(num: Int)(implicit ord: Ordering[R]): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).top(num)(ord)
    Definition Classes
    RDD
  70. def treeAggregate[U](zeroValue: U)(seqOp: (U, R) ⇒ U, combOp: (U, U) ⇒ U, depth: Int)(implicit arg0: ClassTag[U]): U

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).treeAggregate(zeroValue)(seqOp, combOp, depth)(arg0)
    Definition Classes
    RDD
  71. def treeReduce(f: (R, R) ⇒ R, depth: Int): R

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).treeReduce(f, depth)
    Definition Classes
    RDD
  72. def union(other: RDD[R]): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).union(other)
    Definition Classes
    RDD
  73. def unpersist(blocking: Boolean): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).unpersist(blocking)
    Definition Classes
    RDD
  74. def zip[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[(R, U)]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zip(other)(arg0)
    Definition Classes
    RDD
  75. def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D])(f: (Iterator[R], Iterator[B], Iterator[C], Iterator[D]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2, rdd3, rdd4)(f)(arg0, arg1, arg2, arg3)
    Definition Classes
    RDD
  76. def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D], preservesPartitioning: Boolean)(f: (Iterator[R], Iterator[B], Iterator[C], Iterator[D]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2, rdd3, rdd4, preservesPartitioning)(f)(arg0, arg1, arg2, arg3)
    Definition Classes
    RDD
  77. def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C])(f: (Iterator[R], Iterator[B], Iterator[C]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2, rdd3)(f)(arg0, arg1, arg2)
    Definition Classes
    RDD
  78. def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C], preservesPartitioning: Boolean)(f: (Iterator[R], Iterator[B], Iterator[C]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2, rdd3, preservesPartitioning)(f)(arg0, arg1, arg2)
    Definition Classes
    RDD
  79. def zipPartitions[B, V](rdd2: RDD[B])(f: (Iterator[R], Iterator[B]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2)(f)(arg0, arg1)
    Definition Classes
    RDD
  80. def zipPartitions[B, V](rdd2: RDD[B], preservesPartitioning: Boolean)(f: (Iterator[R], Iterator[B]) ⇒ Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipPartitions(rdd2, preservesPartitioning)(f)(arg0, arg1)
    Definition Classes
    RDD
  81. def zipWithIndex(): RDD[(R, Long)]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipWithIndex()
    Definition Classes
    RDD
  82. def zipWithUniqueId(): RDD[(R, Long)]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).zipWithUniqueId()
    Definition Classes
    RDD

Deprecated Value Members

  1. def filterWith[A](constructA: (Int) ⇒ A)(p: (R, A) ⇒ Boolean): RDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0) use mapPartitionsWithIndex and filter

  2. def flatMapWith[A, U](constructA: (Int) ⇒ A, preservesPartitioning: Boolean)(f: (R, A) ⇒ Seq[U])(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0) use mapPartitionsWithIndex and flatMap

  3. def foreachWith[A](constructA: (Int) ⇒ A)(f: (R, A) ⇒ Unit): Unit

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0) use mapPartitionsWithIndex and foreach

  4. def mapPartitionsWithContext[U](f: (TaskContext, Iterator[R]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @DeveloperApi() @deprecated
    Deprecated

    (Since version 1.2.0) use TaskContext.get

  5. def mapPartitionsWithSplit[U](f: (Int, Iterator[R]) ⇒ Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 0.7.0) use mapPartitionsWithIndex

  6. def mapWith[A, U](constructA: (Int) ⇒ A, preservesPartitioning: Boolean)(f: (R, A) ⇒ U)(implicit arg0: ClassTag[U]): RDD[U]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0) use mapPartitionsWithIndex

  7. def splits: List[Partition]

    Definition Classes
    JavaRDDLike
    Annotations
    @deprecated
    Deprecated

    (Since version 1.1.0) Use partitions() instead.

  8. def toArray(): Array[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to RDD[R] performed by method toRDD in org.apache.spark.api.java.JavaRDD.
    Shadowing
    This implicitly inherited member is shadowed by one or more members in this class.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: RDD[R]).toArray()
    Definition Classes
    RDD
    Annotations
    @deprecated
    Deprecated

    (Since version 1.0.0) use collect

  9. def x: CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to ArrowAssoc[CassandraJavaRDD[R]] performed by method any2ArrowAssoc in scala.Predef.
    Shadowing
    This implicitly inherited member is ambiguous. One or more implicitly inherited members have similar signatures, so calling this member may produce an ambiguous implicit conversion compiler error.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: ArrowAssoc[CassandraJavaRDD[R]]).x
    Definition Classes
    ArrowAssoc
    Annotations
    @deprecated
    Deprecated

    (Since version 2.10.0) Use leftOfArrow instead

  10. def x: CassandraJavaRDD[R]

    Implicit information
    This member is added by an implicit conversion from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]] performed by method any2Ensuring in scala.Predef.
    Shadowing
    This implicitly inherited member is ambiguous. One or more implicitly inherited members have similar signatures, so calling this member may produce an ambiguous implicit conversion compiler error.
    To access this member you can use a type ascription:
    (cassandraJavaRDD: Ensuring[CassandraJavaRDD[R]]).x
    Definition Classes
    Ensuring
    Annotations
    @deprecated
    Deprecated

    (Since version 2.10.0) Use resultOfEnsuring instead

Inherited from JavaRDD[R]

Inherited from AbstractJavaRDDLike[R, JavaRDD[R]]

Inherited from JavaRDDLike[R, JavaRDD[R]]

Inherited from Serializable

Inherited from Serializable

Inherited from AnyRef

Inherited from Any

Inherited by implicit conversion toRDD from CassandraJavaRDD[R] to RDD[R]

Inherited by implicit conversion any2stringadd from CassandraJavaRDD[R] to StringAdd

Inherited by implicit conversion any2stringfmt from CassandraJavaRDD[R] to StringFormat

Inherited by implicit conversion any2ArrowAssoc from CassandraJavaRDD[R] to ArrowAssoc[CassandraJavaRDD[R]]

Inherited by implicit conversion any2Ensuring from CassandraJavaRDD[R] to Ensuring[CassandraJavaRDD[R]]

Ungrouped