org.apache.spark.sql.sedona_sql.strategy.join
TraitKNNJoinQueryExec 
            Companion object TraitKNNJoinQueryExec
          
      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
- Alphabetic
- By Inheritance
- TraitKNNJoinQueryExec
- TraitJoinQueryExec
- TraitJoinQueryBase
- AnyRef
- Any
- Hide All
- Show All
- Public
- All
Abstract Value Members
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        extraCondition: Option[Expression]
      
      
      - Definition Classes
- TraitJoinQueryExec
 
-  abstract def getKNNJoinParams: JoinParams
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        left: SparkPlan
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        leftShape: Expression
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        right: SparkPlan
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        rightShape: Expression
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        abstract 
        val
      
      
        spatialPredicate: SpatialPredicate
      
      
      - Definition Classes
- TraitJoinQueryExec
 
Concrete Value Members
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        !=(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ##(): Int
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ==(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        asInstanceOf[T0]: T0
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        broadcastJoin: Boolean
      
      
      - Attributes
- protected
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        clone(): AnyRef
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doExecute(): RDD[InternalRow]
      
      
      - Attributes
- protected
- Definition Classes
- TraitKNNJoinQueryExec → TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doSpatialPartitioning(dominantShapes: SpatialRDD[Geometry], followerShapes: SpatialRDD[Geometry], numPartitions: Integer, sedonaConf: SedonaConf): Unit
      
      
      - Definition Classes
- TraitJoinQueryBase
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        eq(arg0: AnyRef): Boolean
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        equals(arg0: Any): Boolean
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        finalize(): Unit
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        getClass(): Class[_]
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        hashCode(): Int
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native()
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        isInstanceOf[T0]: Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        joinPartitionNumOptimizer(dominantSidePartNum: Int, followerSidePartNum: Int, dominantSideCount: Long): Int
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        
        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
 
-  def knnJoinPartitionNumOptimizer(objectSidePartNum: Int, querySidePartNum: Int, objectSideCount: Long, numNeighbor: Int): Int
-  lazy val metrics: Map[String, SQLMetric]
- 
      
      
      
        
      
    
      
        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()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        output: Seq[Attribute]
      
      
      - Definition Classes
- TraitJoinQueryExec
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        querySide: JoinSide
      
      
      - Attributes
- protected
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        synchronized[T0](arg0: ⇒ T0): T0
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toExpandedEnvelopeRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression, boundRadius: Expression, isGeography: Boolean): SpatialRDD[Geometry]
      
      
      - Definition Classes
- TraitJoinQueryBase
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toSpatialRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression): SpatialRDD[Geometry]
      
      
      - Definition Classes
- TraitJoinQueryBase
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toSpatialRddPair(leftRdd: RDD[UnsafeRow], leftShapeExpr: Expression, rightRdd: RDD[UnsafeRow], rightShapeExpr: Expression): (SpatialRDD[Geometry], SpatialRDD[Geometry])
      
      
      - Definition Classes
- TraitJoinQueryBase
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toString(): String
      
      
      - Definition Classes
- AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toWGS84EnvelopeRDD(rdd: RDD[UnsafeRow], shapeExpression: Expression): SpatialRDD[Geometry]
      
      
      - Definition Classes
- TraitJoinQueryBase
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(arg0: Long, arg1: Int): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... )
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(arg0: Long): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... ) @native()