trait TraitKNNJoinQueryExec extends TraitJoinQueryExec

TraitKNNJoinQueryExec is a trait that extends the TraitJoinQueryExec trait and provides the necessary functionality to execute a KNN join operation.

It is used by the KNNJoinExec class to execute a KNN join operation. The KNN join operation is a k-nearest neighbors join that finds the k-nearest neighbors of each object in the right dataset for each query in the left dataset.

Self Type
TraitKNNJoinQueryExec with SparkPlan
Linear Supertypes
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. TraitKNNJoinQueryExec
  2. TraitJoinQueryExec
  3. TraitJoinQueryBase
  4. AnyRef
  5. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Abstract Value Members

  1. abstract val extraCondition: Option[Expression]
    Definition Classes
    TraitJoinQueryExec
  2. abstract def getKNNJoinParams: JoinParams
  3. abstract val left: SparkPlan
    Definition Classes
    TraitJoinQueryExec
  4. abstract val leftShape: Expression
    Definition Classes
    TraitJoinQueryExec
  5. abstract val right: SparkPlan
    Definition Classes
    TraitJoinQueryExec
  6. abstract val rightShape: Expression
    Definition Classes
    TraitJoinQueryExec
  7. abstract val spatialPredicate: SpatialPredicate
    Definition Classes
    TraitJoinQueryExec

Concrete Value Members

  1. final def !=(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  4. final def asInstanceOf[T0]: T0
    Definition Classes
    Any
  5. val broadcastJoin: Boolean
    Attributes
    protected
  6. def clone(): AnyRef
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()
  7. def doExecute(): RDD[InternalRow]
    Attributes
    protected
    Definition Classes
    TraitKNNJoinQueryExecTraitJoinQueryExec
  8. def doSpatialPartitioning(dominantShapes: SpatialRDD[Geometry], followerShapes: SpatialRDD[Geometry], numPartitions: Integer, sedonaConf: SedonaConf): Unit
    Definition Classes
    TraitJoinQueryBase
  9. final def eq(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  10. def equals(arg0: Any): Boolean
    Definition Classes
    AnyRef → Any
  11. def finalize(): Unit
    Attributes
    protected[lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  12. final def getClass(): Class[_]
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  13. def hashCode(): Int
    Definition Classes
    AnyRef → Any
    Annotations
    @native()
  14. final def isInstanceOf[T0]: Boolean
    Definition Classes
    Any
  15. def joinPartitionNumOptimizer(dominantSidePartNum: Int, followerSidePartNum: Int, dominantSideCount: Long): Int
    Definition Classes
    TraitJoinQueryExec
  16. def joinedRddToRowRdd(joinedRdd: RDD[(Geometry, Geometry)], swapped: Boolean): RDD[InternalRow]

    Converts the joined RDD of geometries to an RDD of InternalRows.

    Converts the joined RDD of geometries to an RDD of InternalRows.

    This method maps over the partitions of the joined RDD, creating an UnsafeRow joiner that combines the left and right rows based on the given schemas.

    Each geometry's user data is expected to be an UnsafeRow, and the joiner is used to produce joined rows from the left and right geometry pairs.

    joinedRdd

    The RDD containing pairs of joined geometries.

    returns

    RDD[InternalRow] The resulting RDD of joined InternalRows.

    Attributes
    protected
  17. def knnJoinPartitionNumOptimizer(objectSidePartNum: Int, querySidePartNum: Int, objectSideCount: Long, numNeighbor: Int): Int
  18. lazy val metrics: Map[String, SQLMetric]
  19. final def ne(arg0: AnyRef): Boolean
    Definition Classes
    AnyRef
  20. final def notify(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  21. final def notifyAll(): Unit
    Definition Classes
    AnyRef
    Annotations
    @native()
  22. def output: Seq[Attribute]
    Definition Classes
    TraitJoinQueryExec
  23. val querySide: JoinSide
    Attributes
    protected
  24. final def synchronized[T0](arg0: ⇒ T0): T0
    Definition Classes
    AnyRef
  25. def toExpandedEnvelopeRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression, boundRadius: Expression, isGeography: Boolean): SpatialRDD[Geometry]
    Definition Classes
    TraitJoinQueryBase
  26. def toSpatialRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression): SpatialRDD[Geometry]
    Definition Classes
    TraitJoinQueryBase
  27. def toSpatialRddPair(leftRdd: RDD[UnsafeRow], leftShapeExpr: Expression, rightRdd: RDD[UnsafeRow], rightShapeExpr: Expression): (SpatialRDD[Geometry], SpatialRDD[Geometry])
    Definition Classes
    TraitJoinQueryBase
  28. def toString(): String
    Definition Classes
    AnyRef → Any
  29. def toWGS84EnvelopeRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression): SpatialRDD[Geometry]
    Definition Classes
    TraitJoinQueryBase
  30. final def wait(): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  31. final def wait(arg0: Long, arg1: Int): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  32. final def wait(arg0: Long): Unit
    Definition Classes
    AnyRef
    Annotations
    @throws( ... ) @native()

Inherited from TraitJoinQueryExec

Inherited from TraitJoinQueryBase

Inherited from AnyRef

Inherited from Any

Ungrouped