case class CassandraDirectJoinExec(leftKeys: Seq[Expression], rightKeys: Seq[Expression], joinType: JoinType, cassandraSide: BuildSide, condition: Option[Expression], child: SparkPlan, aliasMap: Map[String, ExprId], cassandraPlan: BatchScanExec) extends SparkPlan with UnaryExecNode with Product with Serializable
A physical plan for performing a join against a CassandraTable given a set of keys.
          
            Linear Supertypes
          
          
        
          
          
            
          
          
        
        
            Ordering
            
          - Alphabetic
- By Inheritance
                  Inherited
                  
                  
- CassandraDirectJoinExec
- UnaryExecNode
- UnaryLike
- SparkPlan
- Serializable
- Serializable
- Logging
- QueryPlan
- SQLConfHelper
- TreeNode
- WithOrigin
- TreePatternBits
- Product
- Equals
- AnyRef
- Any
- Hide All
- Show All
              Visibility
              
        - Public
- All
Instance Constructors
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
 
-  val aliasMap: Map[String, ExprId]
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        allAttributes: AttributeSeq
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        apply(number: Int): TreeNode[_]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        argString(maxFields: Int): String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        asCode: String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        asInstanceOf[T0]: T0
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        final 
        lazy val
      
      
        canonicalized: SparkPlan
      
      
      - Definition Classes
- QueryPlan
- Annotations
- @transient()
 
-  val cassandraPlan: BatchScanExec
-  def cassandraScan: CassandraScan
-  val cassandraSchema: StructType
-  val cassandraSide: BuildSide
- 
      
      
      
        
      
    
      
        
        val
      
      
        child: SparkPlan
      
      
      - Definition Classes
- CassandraDirectJoinExec → UnaryLike
 
- 
      
      
      
        
      
    
      
        final 
        lazy val
      
      
        children: Seq[SparkPlan]
      
      
      - Definition Classes
- UnaryLike
- Annotations
- @transient()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        cleanupResources(): Unit
      
      
      - Attributes
- protected[sql]
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        clone(): SparkPlan
      
      
      - Definition Classes
- TreeNode → AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        collect[B](pf: PartialFunction[SparkPlan, B]): Seq[B]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        collectFirst[B](pf: PartialFunction[SparkPlan, B]): Option[B]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        collectLeaves(): Seq[SparkPlan]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        collectWithSubqueries[B](f: PartialFunction[SparkPlan, B]): Seq[B]
      
      
      - Definition Classes
- QueryPlan
 
-  val condition: Option[Expression]
- 
      
      
      
        
      
    
      
        
        def
      
      
        conf: SQLConf
      
      
      - Definition Classes
- SparkPlan → SQLConfHelper
 
-  val connector: CassandraConnector
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        containsAllPatterns(patterns: TreePattern*): Boolean
      
      
      - Definition Classes
- TreePatternBits
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        containsAnyPattern(patterns: TreePattern*): Boolean
      
      
      - Definition Classes
- TreePatternBits
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        containsChild: Set[TreeNode[_]]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        containsPattern(t: TreePattern): Boolean
      
      
      - Definition Classes
- TreePatternBits
- Annotations
- @inline()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        copyTagsFrom(other: SparkPlan): Unit
      
      
      - Definition Classes
- TreeNode
 
-  val cqlQueryParts: CqlQueryParts
- 
      
      
      
        
      
    
      
        
        def
      
      
        createResultProjection(): (InternalRow) ⇒ InternalRow
      
      
      - Attributes
- protected
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        deterministic: Boolean
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doCanonicalize(): SparkPlan
      
      
      - Attributes
- protected
- Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doExecute(): RDD[InternalRow]
      
      
      Join type do the correct JoinWithCassandraTable Operation Join type do the correct JoinWithCassandraTable Operation - Attributes
- protected
- Definition Classes
- CassandraDirectJoinExec → SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doExecuteBroadcast[T](): Broadcast[T]
      
      
      - Attributes
- protected[sql]
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doExecuteColumnar(): RDD[ColumnarBatch]
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doExecuteWrite(writeFilesSpec: WriteFilesSpec): RDD[WriterCommitMessage]
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        doPrepare(): Unit
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        eq(arg0: AnyRef): Boolean
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        execute(): RDD[InternalRow]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        executeBroadcast[T](): Broadcast[T]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeCollect(): Array[InternalRow]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeCollectPublic(): Array[Row]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        executeColumnar(): RDD[ColumnarBatch]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        executeQuery[T](query: ⇒ T): T
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeTail(n: Int): Array[InternalRow]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeTake(n: Int): Array[InternalRow]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeToIterator(): Iterator[InternalRow]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        executeWrite(writeFilesSpec: WriteFilesSpec): RDD[WriterCommitMessage]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        exists(f: (SparkPlan) ⇒ Boolean): Boolean
      
      
      - Definition Classes
- TreeNode
 
-  val exprIdToCassandra: Map[ExprId, String]
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        expressions: Seq[Expression]
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        fastEquals(other: TreeNode[_]): Boolean
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        find(f: (SparkPlan) ⇒ Boolean): Option[SparkPlan]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        flatMap[A](f: (SparkPlan) ⇒ TraversableOnce[A]): Seq[A]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        foreach(f: (SparkPlan) ⇒ Unit): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        foreachUp(f: (SparkPlan) ⇒ Unit): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        formattedNodeName: String
      
      
      - Attributes
- protected
- Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        generateTreeString(depth: Int, lastChildren: ArrayList[Boolean], append: (String) ⇒ Unit, verbose: Boolean, prefix: String, addSuffix: Boolean, maxFields: Int, printNodeId: Boolean, indent: Int): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        getClass(): Class[_]
      
      
      - Definition Classes
- AnyRef → Any
- Annotations
- @native() @HotSpotIntrinsicCandidate()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        getDefaultTreePatternBits: BitSet
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        getTagValue[T](tag: TreeNodeTag[T]): Option[T]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        hashCode(): Int
      
      
      - Definition Classes
- TreeNode → AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        id: Int
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean, silent: Boolean): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        initializeLogIfNecessary(isInterpreter: Boolean): Unit
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        innerChildren: Seq[QueryPlan[_]]
      
      
      - Definition Classes
- QueryPlan → TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        inputSet: AttributeSet
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        isCanonicalizedPlan: Boolean
      
      
      - Attributes
- protected
- Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        isInstanceOf[T0]: Boolean
      
      
      - Definition Classes
- Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        isRuleIneffective(ruleId: RuleId): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        isTraceEnabled(): Boolean
      
      
      - Attributes
- protected
- Definition Classes
- Logging
 
-  val joinColumns: Seq[com.datastax.spark.connector.ColumnName]
-  val joinExpressions: Seq[Expression]
-  val joinType: JoinType
- 
      
      
      
        
      
    
      
        
        def
      
      
        jsonFields: List[JField]
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
-  val keySource: SparkPlan
-  val keyspace: String
-  val left: SparkPlan
-  val leftJoinCouplets: Seq[(Expression, Expression)]
-  val leftKeys: Seq[Expression]
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        legacyWithNewChildren(newChildren: Seq[SparkPlan]): SparkPlan
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        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
      
      
        logicalLink: Option[LogicalPlan]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        longMetric(name: String): SQLMetric
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        makeCopy(newArgs: Array[AnyRef]): SparkPlan
      
      
      - Definition Classes
- SparkPlan → TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        map[A](f: (SparkPlan) ⇒ A): Seq[A]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        mapChildren(f: (SparkPlan) ⇒ SparkPlan): SparkPlan
      
      
      - Definition Classes
- UnaryLike
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        mapExpressions(f: (Expression) ⇒ Expression): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        mapProductIterator[B](f: (Any) ⇒ B)(implicit arg0: ClassTag[B]): Array[B]
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        markRuleAsIneffective(ruleId: RuleId): Unit
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        metrics: Map[String, SQLMetric]
      
      
      - Definition Classes
- CassandraDirectJoinExec → SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        missingInput: AttributeSet
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        multiTransformDown(rule: PartialFunction[SparkPlan, Seq[SparkPlan]]): Stream[SparkPlan]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        multiTransformDownWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[SparkPlan, Seq[SparkPlan]]): Stream[SparkPlan]
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        ne(arg0: AnyRef): Boolean
      
      
      - Definition Classes
- AnyRef
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        nodeName: String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        nodePatterns: Seq[TreePattern]
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notify(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native() @HotSpotIntrinsicCandidate()
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        notifyAll(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @native() @HotSpotIntrinsicCandidate()
 
-  val numOutputRows: SQLMetric
- 
      
      
      
        
      
    
      
        
        def
      
      
        numberedTreeString: String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        val
      
      
        origin: Origin
      
      
      - Definition Classes
- TreeNode → WithOrigin
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        otherCopyArgs: Seq[AnyRef]
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
-  val otherJoinCouplets: Seq[(Expression, Expression)]
- 
      
      
      
        
      
    
      
        
        def
      
      
        output: Seq[Attribute]
      
      
      - Definition Classes
- CassandraDirectJoinExec → QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        outputOrdering: Seq[SortOrder]
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        outputPartitioning: Partitioning
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        outputSet: AttributeSet
      
      
      - Definition Classes
- QueryPlan
- Annotations
- @transient()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        p(number: Int): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
-  val pkJoinCoulplets: Seq[(Expression, Expression)]
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        prepare(): Unit
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        prepareSubqueries(): Unit
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        prettyJson: String
      
      
      - Definition Classes
- TreeNode
 
-  val primaryKeys: IndexedSeq[String]
- 
      
      
      
        
      
    
      
        
        def
      
      
        printSchema(): Unit
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        producedAttributes: AttributeSet
      
      
      - Definition Classes
- QueryPlan
 
-  val readConf: ReadConf
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        references: AttributeSet
      
      
      - Definition Classes
- QueryPlan
- Annotations
- @transient()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        requiredChildDistribution: Seq[Distribution]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        requiredChildOrdering: Seq[Seq[SortOrder]]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        resetMetrics(): Unit
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        rewriteAttrs(attrMap: AttributeMap[Attribute]): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
-  val right: SparkPlan
-  val rightKeys: Seq[Expression]
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        sameResult(other: SparkPlan): Boolean
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        schema: StructType
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        schemaString: String
      
      
      - Definition Classes
- QueryPlan
 
-  val selectedColumns: IndexedSeq[ColumnRef]
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        semanticHash(): Int
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        final 
        val
      
      
        session: SparkSession
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        setLogicalLink(logicalPlan: LogicalPlan): Unit
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        setTagValue[T](tag: TreeNodeTag[T], value: T): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        simpleString(maxFields: Int): String
      
      
      - Definition Classes
- CassandraDirectJoinExec → QueryPlan → TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        simpleStringWithNodeId(): String
      
      
      - Definition Classes
- QueryPlan → TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        sparkContext: SparkContext
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        statePrefix: String
      
      
      - Attributes
- protected
- Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        stringArgs: Iterator[Any]
      
      
      - Attributes
- protected
- Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        subqueries: Seq[SparkPlan]
      
      
      - Definition Classes
- QueryPlan
- Annotations
- @transient()
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        subqueriesAll: Seq[SparkPlan]
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        supportsColumnar: Boolean
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        supportsRowBased: Boolean
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        synchronized[T0](arg0: ⇒ T0): T0
      
      
      - Definition Classes
- AnyRef
 
-  val table: String
- 
      
      
      
        
      
    
      
        
        def
      
      
        toJSON: String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toRowBased: SparkPlan
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        toString(): String
      
      
      - Definition Classes
- TreeNode → AnyRef → Any
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transform(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformAllExpressions(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformAllExpressionsWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformAllExpressionsWithSubqueries(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformDown(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformDownWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformDownWithSubqueries(f: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformDownWithSubqueriesAndPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(f: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressions(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressionsDown(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressionsDownWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressionsUp(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressionsUpWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformExpressionsWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[Expression, Expression]): CassandraDirectJoinExec.this.type
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformUp(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformUpWithBeforeAndAfterRuleOnChildren(cond: (SparkPlan) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[(SparkPlan, SparkPlan), SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformUpWithNewOutput(rule: PartialFunction[SparkPlan, (SparkPlan, Seq[(Attribute, Attribute)])], skipCond: (SparkPlan) ⇒ Boolean, canGetOutput: (SparkPlan) ⇒ Boolean): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformUpWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformUpWithSubqueries(f: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformWithPruning(cond: (TreePatternBits) ⇒ Boolean, ruleId: RuleId)(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        transformWithSubqueries(f: PartialFunction[SparkPlan, SparkPlan]): SparkPlan
      
      
      - Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        lazy val
      
      
        treePatternBits: BitSet
      
      
      - Definition Classes
- QueryPlan → TreeNode → TreePatternBits
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        treeString(append: (String) ⇒ Unit, verbose: Boolean, addSuffix: Boolean, maxFields: Int, printOperatorId: Boolean): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        treeString(verbose: Boolean, addSuffix: Boolean, maxFields: Int, printOperatorId: Boolean): String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        treeString: String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        unsetTagValue[T](tag: TreeNodeTag[T]): Unit
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        updateOuterReferencesInSubquery(plan: SparkPlan, attrMap: AttributeMap[Attribute]): SparkPlan
      
      
      - Attributes
- protected
- Definition Classes
- QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        vectorTypes: Option[Seq[String]]
      
      
      - Definition Classes
- SparkPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        verboseString(maxFields: Int): String
      
      
      - Definition Classes
- QueryPlan → TreeNode
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        verboseStringWithOperatorId(): String
      
      
      - Definition Classes
- UnaryExecNode → QueryPlan
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        verboseStringWithSuffix(maxFields: Int): String
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        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()
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        wait(): Unit
      
      
      - Definition Classes
- AnyRef
- Annotations
- @throws( ... )
 
- 
      
      
      
        
      
    
      
        
        def
      
      
        waitForSubqueries(): Unit
      
      
      - Attributes
- protected
- Definition Classes
- SparkPlan
 
-  val whereClause: CqlWhereClause
- 
      
      
      
        
      
    
      
        
        def
      
      
        withNewChildInternal(newChild: SparkPlan): CassandraDirectJoinExec
      
      
      - Attributes
- protected
- Definition Classes
- CassandraDirectJoinExec → UnaryLike
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        withNewChildren(newChildren: Seq[SparkPlan]): SparkPlan
      
      
      - Definition Classes
- TreeNode
 
- 
      
      
      
        
      
    
      
        final 
        def
      
      
        withNewChildrenInternal(newChildren: IndexedSeq[SparkPlan]): SparkPlan
      
      
      - Definition Classes
- UnaryLike
 
Deprecated Value Members
- 
      
      
      
        
      
    
      
        
        def
      
      
        finalize(): Unit
      
      
      - Attributes
- protected[lang]
- Definition Classes
- AnyRef
- Annotations
- @throws( classOf[java.lang.Throwable] ) @Deprecated @deprecated
- Deprecated
- (Since version ) see corresponding Javadoc for more information.