class UnsafeCartesianRDD extends CartesianRDD[UnsafeRow, UnsafeRow]
An optimized CartesianRDD for UnsafeRow, which will cache the rows from second child RDD, will be much faster than building the right partition for every row in left RDD, it also materialize the right RDD (in case of the right RDD is nondeterministic).
Linear Supertypes
Ordering
- Alphabetic
- By Inheritance
Inherited
- UnsafeCartesianRDD
- CartesianRDD
- RDD
- Logging
- Serializable
- AnyRef
- Any
- Hide All
- Show All
Visibility
- Public
- Protected
Instance Constructors
- new UnsafeCartesianRDD(left: RDD[UnsafeRow], right: RDD[UnsafeRow], inMemoryBufferThreshold: Int, spillThreshold: Int)
Value Members
- final def !=(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- final def ##: Int
- Definition Classes
- AnyRef → Any
- def ++(other: RDD[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- final def ==(arg0: Any): Boolean
- Definition Classes
- AnyRef → Any
- def aggregate[U](zeroValue: U)(seqOp: (U, (UnsafeRow, UnsafeRow)) => U, combOp: (U, U) => U)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- final def asInstanceOf[T0]: T0
- Definition Classes
- Any
- def barrier(): RDDBarrier[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("2.4.0")
- def cache(): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- def cartesian[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[((UnsafeRow, UnsafeRow), U)]
- Definition Classes
- RDD
- def checkpoint(): Unit
- Definition Classes
- RDD
- def cleanShuffleDependencies(blocking: Boolean): Unit
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.1.0")
- def clearDependencies(): Unit
- Definition Classes
- CartesianRDD → RDD
- def clone(): AnyRef
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.CloneNotSupportedException]) @native()
- def coalesce(numPartitions: Int, shuffle: Boolean, partitionCoalescer: Option[PartitionCoalescer])(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def collect[U](f: PartialFunction[(UnsafeRow, UnsafeRow), U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def collect(): Array[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def compute(split: Partition, context: TaskContext): Iterator[(UnsafeRow, UnsafeRow)]
- Definition Classes
- UnsafeCartesianRDD → CartesianRDD → RDD
- def context: SparkContext
- Definition Classes
- RDD
- def count(): Long
- Definition Classes
- RDD
- def countApprox(timeout: Long, confidence: Double): PartialResult[BoundedDouble]
- Definition Classes
- RDD
- def countApproxDistinct(relativeSD: Double): Long
- Definition Classes
- RDD
- def countApproxDistinct(p: Int, sp: Int): Long
- Definition Classes
- RDD
- def countByValue()(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): Map[(UnsafeRow, UnsafeRow), Long]
- Definition Classes
- RDD
- def countByValueApprox(timeout: Long, confidence: Double)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): PartialResult[Map[(UnsafeRow, UnsafeRow), BoundedDouble]]
- Definition Classes
- RDD
- final def dependencies: Seq[Dependency[_]]
- Definition Classes
- RDD
- def distinct(): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def distinct(numPartitions: Int)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- final def eq(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- def equals(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef → Any
- def filter(f: ((UnsafeRow, UnsafeRow)) => Boolean): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def finalize(): Unit
- Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.Throwable])
- def first(): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- def firstParent[U](implicit arg0: ClassTag[U]): RDD[U]
- Attributes
- protected[spark]
- Definition Classes
- RDD
- def flatMap[U](f: ((UnsafeRow, UnsafeRow)) => TraversableOnce[U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def fold(zeroValue: (UnsafeRow, UnsafeRow))(op: ((UnsafeRow, UnsafeRow), (UnsafeRow, UnsafeRow)) => (UnsafeRow, UnsafeRow)): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- def foreach(f: ((UnsafeRow, UnsafeRow)) => Unit): Unit
- Definition Classes
- RDD
- def foreachPartition(f: (Iterator[(UnsafeRow, UnsafeRow)]) => Unit): Unit
- Definition Classes
- RDD
- def getCheckpointFile: Option[String]
- Definition Classes
- RDD
- final def getClass(): Class[_ <: AnyRef]
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- def getDependencies: Seq[Dependency[_]]
- Definition Classes
- CartesianRDD → RDD
- final def getNumPartitions: Int
- Definition Classes
- RDD
- Annotations
- @Since("1.6.0")
- def getOutputDeterministicLevel: rdd.DeterministicLevel.Value
- Attributes
- protected
- Definition Classes
- RDD
- Annotations
- @DeveloperApi()
- def getPartitions: Array[Partition]
- Definition Classes
- CartesianRDD → RDD
- def getPreferredLocations(split: Partition): Seq[String]
- Definition Classes
- CartesianRDD → RDD
- def getResourceProfile(): ResourceProfile
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("3.1.0")
- def getStorageLevel: StorageLevel
- Definition Classes
- RDD
- def glom(): RDD[Array[(UnsafeRow, UnsafeRow)]]
- Definition Classes
- RDD
- def groupBy[K](f: ((UnsafeRow, UnsafeRow)) => K, p: Partitioner)(implicit kt: ClassTag[K], ord: Ordering[K]): RDD[(K, Iterable[(UnsafeRow, UnsafeRow)])]
- Definition Classes
- RDD
- def groupBy[K](f: ((UnsafeRow, UnsafeRow)) => K, numPartitions: Int)(implicit kt: ClassTag[K]): RDD[(K, Iterable[(UnsafeRow, UnsafeRow)])]
- Definition Classes
- RDD
- def groupBy[K](f: ((UnsafeRow, UnsafeRow)) => K)(implicit kt: ClassTag[K]): RDD[(K, Iterable[(UnsafeRow, UnsafeRow)])]
- Definition Classes
- RDD
- def hashCode(): Int
- Definition Classes
- AnyRef → Any
- Annotations
- @native()
- val id: Int
- Definition Classes
- RDD
- def initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- def initializeLogIfNecessary(isInterpreter: Boolean): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def intersection(other: RDD[(UnsafeRow, UnsafeRow)], numPartitions: Int): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def intersection(other: RDD[(UnsafeRow, UnsafeRow)], partitioner: Partitioner)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def intersection(other: RDD[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- lazy val isBarrier_: Boolean
- Attributes
- protected
- Definition Classes
- RDD
- Annotations
- @transient()
- def isCheckpointed: Boolean
- Definition Classes
- RDD
- def isEmpty(): Boolean
- Definition Classes
- RDD
- final def isInstanceOf[T0]: Boolean
- Definition Classes
- Any
- def isTraceEnabled(): Boolean
- Attributes
- protected
- Definition Classes
- Logging
- final def iterator(split: Partition, context: TaskContext): Iterator[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def keyBy[K](f: ((UnsafeRow, UnsafeRow)) => K): RDD[(K, (UnsafeRow, UnsafeRow))]
- Definition Classes
- RDD
- def localCheckpoint(): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- def log: Logger
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logDebug(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logError(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logInfo(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logName: String
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logTrace(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String, throwable: Throwable): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def logWarning(msg: => String): Unit
- Attributes
- protected
- Definition Classes
- Logging
- def map[U](f: ((UnsafeRow, UnsafeRow)) => U)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def mapPartitions[U](f: (Iterator[(UnsafeRow, UnsafeRow)]) => Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def mapPartitionsWithEvaluator[U](evaluatorFactory: PartitionEvaluatorFactory[(UnsafeRow, UnsafeRow), U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.5.0")
- def mapPartitionsWithIndex[U](f: (Int, Iterator[(UnsafeRow, UnsafeRow)]) => Iterator[U], preservesPartitioning: Boolean)(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- def max()(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- def min()(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- var name: String
- Definition Classes
- RDD
- final def ne(arg0: AnyRef): Boolean
- Definition Classes
- AnyRef
- final def notify(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- final def notifyAll(): Unit
- Definition Classes
- AnyRef
- Annotations
- @native()
- val numPartitionsInRdd2: Int
- Definition Classes
- CartesianRDD
- def parent[U](j: Int)(implicit arg0: ClassTag[U]): RDD[U]
- Attributes
- protected[spark]
- Definition Classes
- RDD
- val partitioner: Option[Partitioner]
- Definition Classes
- RDD
- final def partitions: Array[Partition]
- Definition Classes
- RDD
- def persist(): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- def persist(newLevel: StorageLevel): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- def pipe(command: Seq[String], env: Map[String, String], printPipeContext: ((String) => Unit) => Unit, printRDDElement: ((UnsafeRow, UnsafeRow), (String) => Unit) => Unit, separateWorkingDir: Boolean, bufferSize: Int, encoding: String): RDD[String]
- Definition Classes
- RDD
- def pipe(command: String, env: Map[String, String]): RDD[String]
- Definition Classes
- RDD
- def pipe(command: String): RDD[String]
- Definition Classes
- RDD
- final def preferredLocations(split: Partition): Seq[String]
- Definition Classes
- RDD
- def randomSplit(weights: Array[Double], seed: Long): Array[RDD[(UnsafeRow, UnsafeRow)]]
- Definition Classes
- RDD
- var rdd1: RDD[UnsafeRow]
- Definition Classes
- CartesianRDD
- var rdd2: RDD[UnsafeRow]
- Definition Classes
- CartesianRDD
- def reduce(f: ((UnsafeRow, UnsafeRow), (UnsafeRow, UnsafeRow)) => (UnsafeRow, UnsafeRow)): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- def repartition(numPartitions: Int)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def sample(withReplacement: Boolean, fraction: Double, seed: Long): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def saveAsObjectFile(path: String): Unit
- Definition Classes
- RDD
- def saveAsTextFile(path: String, codec: Class[_ <: CompressionCodec]): Unit
- Definition Classes
- RDD
- def saveAsTextFile(path: String): Unit
- Definition Classes
- RDD
- def setName(_name: String): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- def sortBy[K](f: ((UnsafeRow, UnsafeRow)) => K, ascending: Boolean, numPartitions: Int)(implicit ord: Ordering[K], ctag: ClassTag[K]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def sparkContext: SparkContext
- Definition Classes
- RDD
- def subtract(other: RDD[(UnsafeRow, UnsafeRow)], p: Partitioner)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def subtract(other: RDD[(UnsafeRow, UnsafeRow)], numPartitions: Int): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def subtract(other: RDD[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- final def synchronized[T0](arg0: => T0): T0
- Definition Classes
- AnyRef
- def take(num: Int): Array[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def takeOrdered(num: Int)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): Array[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def takeSample(withReplacement: Boolean, num: Int, seed: Long): Array[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def toDebugString: String
- Definition Classes
- RDD
- def toJavaRDD(): JavaRDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def toLocalIterator: Iterator[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def toString(): String
- Definition Classes
- RDD → AnyRef → Any
- def top(num: Int)(implicit ord: Ordering[(UnsafeRow, UnsafeRow)]): Array[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def treeAggregate[U](zeroValue: U, seqOp: (U, (UnsafeRow, UnsafeRow)) => U, combOp: (U, U) => U, depth: Int, finalAggregateOnExecutor: Boolean)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- def treeAggregate[U](zeroValue: U)(seqOp: (U, (UnsafeRow, UnsafeRow)) => U, combOp: (U, U) => U, depth: Int)(implicit arg0: ClassTag[U]): U
- Definition Classes
- RDD
- def treeReduce(f: ((UnsafeRow, UnsafeRow), (UnsafeRow, UnsafeRow)) => (UnsafeRow, UnsafeRow), depth: Int): (UnsafeRow, UnsafeRow)
- Definition Classes
- RDD
- def union(other: RDD[(UnsafeRow, UnsafeRow)]): RDD[(UnsafeRow, UnsafeRow)]
- Definition Classes
- RDD
- def unpersist(blocking: Boolean): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- final def wait(): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long, arg1: Int): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException])
- final def wait(arg0: Long): Unit
- Definition Classes
- AnyRef
- Annotations
- @throws(classOf[java.lang.InterruptedException]) @native()
- def withResources(rp: ResourceProfile): UnsafeCartesianRDD.this.type
- Definition Classes
- RDD
- Annotations
- @Experimental() @Since("3.1.0")
- def zip[U](other: RDD[U])(implicit arg0: ClassTag[U]): RDD[((UnsafeRow, UnsafeRow), U)]
- Definition Classes
- RDD
- def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D])(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B], Iterator[C], Iterator[D]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, D, V](rdd2: RDD[B], rdd3: RDD[C], rdd4: RDD[D], preservesPartitioning: Boolean)(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B], Iterator[C], Iterator[D]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[D], arg3: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C])(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B], Iterator[C]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, C, V](rdd2: RDD[B], rdd3: RDD[C], preservesPartitioning: Boolean)(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B], Iterator[C]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[C], arg2: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, V](rdd2: RDD[B])(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitions[B, V](rdd2: RDD[B], preservesPartitioning: Boolean)(f: (Iterator[(UnsafeRow, UnsafeRow)], Iterator[B]) => Iterator[V])(implicit arg0: ClassTag[B], arg1: ClassTag[V]): RDD[V]
- Definition Classes
- RDD
- def zipPartitionsWithEvaluator[U](rdd2: RDD[(UnsafeRow, UnsafeRow)], evaluatorFactory: PartitionEvaluatorFactory[(UnsafeRow, UnsafeRow), U])(implicit arg0: ClassTag[U]): RDD[U]
- Definition Classes
- RDD
- Annotations
- @DeveloperApi() @Since("3.5.0")
- def zipWithIndex(): RDD[((UnsafeRow, UnsafeRow), Long)]
- Definition Classes
- RDD
- def zipWithUniqueId(): RDD[((UnsafeRow, UnsafeRow), Long)]
- Definition Classes
- RDD