Class/Object

org.apache.spark.sql.execution

SHAMapAccessor

Related Docs: object SHAMapAccessor | package execution

Permalink

case class SHAMapAccessor(session: SnappySession, ctx: CodegenContext, keyExprs: Seq[Expression], valueExprs: Seq[Expression], classPrefix: String, hashMapTerm: String, overflowHashMapsTerm: String, keyValSize: Int, valueOffsetTerm: String, numKeyBytesTerm: String, numValueBytes: Int, currentOffSetForMapLookupUpdt: String, valueDataTerm: String, vdBaseObjectTerm: String, vdBaseOffsetTerm: String, nullKeysBitsetTerm: String, numBytesForNullKeyBits: Int, allocatorTerm: String, numBytesForNullAggBits: Int, nullAggsBitsetTerm: String, sizeAndNumNotNullFuncForStringArr: String, keyBytesHolderVarTerm: String, baseKeyObject: String, baseKeyHolderOffset: String, keyExistedTerm: String, skipLenForAttribIndex: Int, codeForLenOfSkippedTerm: String, valueDataCapacityTerm: String, storedAggNullBitsTerm: Option[String], storedKeyNullBitsTerm: Option[String], aggregateBufferVars: Seq[String], keyHolderCapacityTerm: String, shaMapClassName: String, useCustomHashMap: Boolean, previousSingleKey_Position_LenTerm: Option[(String, String, String)], codeSplitFuncParamsSize: Int, splitAggCode: Boolean, splitGroupByKeyCode: Boolean) extends SparkPlan with CodegenSupport with Product with Serializable

Linear Supertypes
CodegenSupport, SparkPlan, Serializable, Serializable, internal.Logging, QueryPlan[SparkPlan], TreeNode[SparkPlan], Product, Equals, AnyRef, Any
Ordering
  1. Alphabetic
  2. By Inheritance
Inherited
  1. SHAMapAccessor
  2. CodegenSupport
  3. SparkPlan
  4. Serializable
  5. Serializable
  6. Logging
  7. QueryPlan
  8. TreeNode
  9. Product
  10. Equals
  11. AnyRef
  12. Any
  1. Hide All
  2. Show All
Visibility
  1. Public
  2. All

Instance Constructors

  1. new SHAMapAccessor(session: SnappySession, ctx: CodegenContext, keyExprs: Seq[Expression], valueExprs: Seq[Expression], classPrefix: String, hashMapTerm: String, overflowHashMapsTerm: String, keyValSize: Int, valueOffsetTerm: String, numKeyBytesTerm: String, numValueBytes: Int, currentOffSetForMapLookupUpdt: String, valueDataTerm: String, vdBaseObjectTerm: String, vdBaseOffsetTerm: String, nullKeysBitsetTerm: String, numBytesForNullKeyBits: Int, allocatorTerm: String, numBytesForNullAggBits: Int, nullAggsBitsetTerm: String, sizeAndNumNotNullFuncForStringArr: String, keyBytesHolderVarTerm: String, baseKeyObject: String, baseKeyHolderOffset: String, keyExistedTerm: String, skipLenForAttribIndex: Int, codeForLenOfSkippedTerm: String, valueDataCapacityTerm: String, storedAggNullBitsTerm: Option[String], storedKeyNullBitsTerm: Option[String], aggregateBufferVars: Seq[String], keyHolderCapacityTerm: String, shaMapClassName: String, useCustomHashMap: Boolean, previousSingleKey_Position_LenTerm: Option[(String, String, String)], codeSplitFuncParamsSize: Int, splitAggCode: Boolean, splitGroupByKeyCode: Boolean)

    Permalink

Value Members

  1. final def !=(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  2. final def ##(): Int

    Permalink
    Definition Classes
    AnyRef → Any
  3. final def ==(arg0: Any): Boolean

    Permalink
    Definition Classes
    AnyRef → Any
  4. val aggregateBufferVars: Seq[String]

    Permalink
  5. lazy val allAttributes: AttributeSeq

    Permalink
    Definition Classes
    QueryPlan
  6. val allocatorTerm: String

    Permalink
  7. def apply(number: Int): TreeNode[_]

    Permalink
    Definition Classes
    TreeNode
  8. def argString: String

    Permalink
    Definition Classes
    TreeNode
  9. def asCode: String

    Permalink
    Definition Classes
    TreeNode
  10. final def asInstanceOf[T0]: T0

    Permalink
    Definition Classes
    Any
  11. val baseKeyHolderOffset: String

    Permalink
  12. val baseKeyObject: String

    Permalink
  13. val bbDataClass: String

    Permalink
  14. val bigDecimalClass: String

    Permalink
  15. val bigDecimalObjectClass: String

    Permalink
  16. val bigIntegerClass: String

    Permalink
  17. val byteArrayEqualsClass: String

    Permalink
  18. val byteBufferClass: String

    Permalink
  19. lazy val canonicalized: SparkPlan

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  20. def children: Seq[SparkPlan]

    Permalink
    Definition Classes
    SHAMapAccessor → TreeNode
  21. val classPrefix: String

    Permalink
  22. lazy val cleanArgs: Seq[Any]

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  23. def cleanExpression(e: Expression): Expression

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  24. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  25. val codeForLenOfSkippedTerm: String

    Permalink
  26. def codeSplit(dataTypes: Seq[DataType], vars: Seq[ExprCode], baseMethod: String, nestingLevel: Int, methodFound: (String, Seq[(ExprCode, DataType)], Int, Boolean, Int) ⇒ String, methodNotFound: (String, Seq[(ExprCode, DataType)], Seq[(ExprCode, DataType)], Int, Boolean, Int) ⇒ (String, String), separator: String, prefix: String, suffix: String, isGroupByKeys: Boolean): String

    Permalink
  27. val codeSplitFuncParamsSize: Int

    Permalink
  28. def collect[B](pf: PartialFunction[SparkPlan, B]): Seq[B]

    Permalink
    Definition Classes
    TreeNode
  29. def collectFirst[B](pf: PartialFunction[SparkPlan, B]): Option[B]

    Permalink
    Definition Classes
    TreeNode
  30. def collectLeaves(): Seq[SparkPlan]

    Permalink
    Definition Classes
    TreeNode
  31. lazy val constraints: ExpressionSet

    Permalink
    Definition Classes
    QueryPlan
  32. final def consume(ctx: CodegenContext, outputVars: Seq[ExprCode], row: String): String

    Permalink
    Definition Classes
    CodegenSupport
  33. lazy val containsChild: Set[TreeNode[_]]

    Permalink
    Definition Classes
    TreeNode
  34. val ctx: CodegenContext

    Permalink
  35. val currentOffSetForMapLookupUpdt: String

    Permalink
  36. val decimalClass: String

    Permalink
  37. def declareNullVarsForAggBuffer(varNames: Seq[String]): String

    Permalink
  38. def doConsume(ctx: CodegenContext, input: Seq[ExprCode], row: ExprCode): String

    Permalink
    Definition Classes
    SHAMapAccessor → CodegenSupport
  39. def doExecute(): RDD[InternalRow]

    Permalink
    Attributes
    protected
    Definition Classes
    SHAMapAccessor → SparkPlan
  40. def doExecuteBroadcast[T](): Broadcast[T]

    Permalink
    Attributes
    protected[org.apache.spark.sql]
    Definition Classes
    SparkPlan
  41. def doPrepare(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  42. def doProduce(ctx: CodegenContext): String

    Permalink
    Attributes
    protected
    Definition Classes
    SHAMapAccessor → CodegenSupport
  43. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  44. def evaluateRequiredVariables(attributes: Seq[Attribute], variables: Seq[ExprCode], required: AttributeSet): String

    Permalink
    Attributes
    protected
    Definition Classes
    CodegenSupport
  45. def evaluateVariables(variables: Seq[ExprCode]): String

    Permalink
    Attributes
    protected
    Definition Classes
    CodegenSupport
  46. final def execute(): RDD[InternalRow]

    Permalink
    Definition Classes
    SparkPlan
  47. final def executeBroadcast[T](): Broadcast[T]

    Permalink
    Definition Classes
    SparkPlan
  48. def executeCollect(): Array[InternalRow]

    Permalink
    Definition Classes
    SparkPlan
  49. def executeCollectPublic(): Array[Row]

    Permalink
    Definition Classes
    SparkPlan
  50. final def executeQuery[T](query: ⇒ T): T

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  51. def executeTake(n: Int): Array[InternalRow]

    Permalink
    Definition Classes
    SparkPlan
  52. def executeToIterator(): Iterator[InternalRow]

    Permalink
    Definition Classes
    SparkPlan
  53. def explodeStruct(structVarName: String, structNullVarName: String, structType: StructType, nestingLevel: Int = 0): String

    Permalink
  54. final def expressions: Seq[Expression]

    Permalink
    Definition Classes
    QueryPlan
  55. def fastEquals(other: TreeNode[_]): Boolean

    Permalink
    Definition Classes
    TreeNode
  56. def finalize(): Unit

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  57. def find(f: (SparkPlan) ⇒ Boolean): Option[SparkPlan]

    Permalink
    Definition Classes
    TreeNode
  58. def flatMap[A](f: (SparkPlan) ⇒ TraversableOnce[A]): Seq[A]

    Permalink
    Definition Classes
    TreeNode
  59. def foreach(f: (SparkPlan) ⇒ Unit): Unit

    Permalink
    Definition Classes
    TreeNode
  60. def foreachUp(f: (SparkPlan) ⇒ Unit): Unit

    Permalink
    Definition Classes
    TreeNode
  61. def generateCustomSHAMapClass(className: String, keyDataType: DataType): String

    Permalink
  62. def generateHashCode(hashVar: Array[String], keyVars: Seq[ExprCode], keysDataType: Seq[DataType], skipDeclaration: Boolean = false, register: Boolean = true): String

    Permalink

    Generate code to calculate the hash code for given column variables that correspond to the key columns in this class.

  63. def generateKeyBytesHolderCodeOrEmptyString(numKeyBytesVar: String, numValueBytes: Int, keyVars: Seq[ExprCode], keysDataType: Seq[DataType], aggregatesDataType: Seq[DataType], valueInitVars: Seq[ExprCode]): String

    Permalink
  64. def generateKeySizeCode(keyVars: Seq[ExprCode], keysDataType: Seq[DataType], numBytesForNullBits: Int, nestingLevel: Int = 0): String

    Permalink
  65. def generateMapGetOrInsert(valueInitVars: Seq[ExprCode], valueInitCode: String, evaluatedInputCode: String, keyVars: Seq[ExprCode], keysDataType: Seq[DataType], aggregateDataTypes: Seq[DataType], dictionaryCode: Option[DictionaryCode], dictionaryArrayTerm: String, dictionaryArraySizeTerm: String, aggFuncDependentOnGroupByKey: Boolean): String

    Permalink

    Generate code to lookup the map or insert a new key, value if not found.

  66. def generateTreeString(depth: Int, lastChildren: Seq[Boolean], builder: StringBuilder, verbose: Boolean, prefix: String): StringBuilder

    Permalink
    Definition Classes
    TreeNode
  67. def generateUpdate(bufferVars: Seq[ExprCode], aggBufferDataType: Seq[DataType]): String

    Permalink
  68. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  69. def getExplodedExprCodeAndDataTypeForStruct(parentStructVarName: String, st: StructType, nestingLevel: Int): (Seq[ExprCode], Seq[DataType])

    Permalink
  70. def getRelevantConstraints(constraints: Set[Expression]): Set[Expression]

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  71. def hashCode(): Int

    Permalink
    Definition Classes
    TreeNode → AnyRef → Any
  72. val hashMapTerm: String

    Permalink
  73. def initKeyOrBufferVal(dataTypes: Seq[DataType], varNames: Seq[String]): String

    Permalink
  74. def initializeLogIfNecessary(isInterpreter: Boolean): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  75. def innerChildren: Seq[QueryPlan[_]]

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan → TreeNode
  76. def inputRDDs(): Seq[RDD[InternalRow]]

    Permalink
    Definition Classes
    SHAMapAccessor → CodegenSupport
  77. def inputSet: AttributeSet

    Permalink
    Definition Classes
    QueryPlan
  78. final def isInstanceOf[T0]: Boolean

    Permalink
    Definition Classes
    Any
  79. def isTraceEnabled(): Boolean

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  80. def jsonFields: List[JField]

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  81. val keyBytesHolderVarTerm: String

    Permalink
  82. val keyExistedTerm: String

    Permalink
  83. val keyExprs: Seq[Expression]

    Permalink
  84. val keyHolderCapacityTerm: String

    Permalink
  85. val keyValSize: Int

    Permalink
  86. def log: Logger

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  87. def logDebug(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  88. def logDebug(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  89. def logError(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  90. def logError(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  91. def logInfo(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  92. def logInfo(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  93. def logName: String

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  94. def logTrace(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  95. def logTrace(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  96. def logWarning(msg: ⇒ String, throwable: Throwable): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  97. def logWarning(msg: ⇒ String): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  98. def longMetric(name: String): SQLMetric

    Permalink
    Definition Classes
    SparkPlan
  99. def makeCopy(newArgs: Array[AnyRef]): SparkPlan

    Permalink
    Definition Classes
    SparkPlan → TreeNode
  100. def map[A](f: (SparkPlan) ⇒ A): Seq[A]

    Permalink
    Definition Classes
    TreeNode
  101. def mapChildren(f: (SparkPlan) ⇒ SparkPlan): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  102. def mapExpressions(f: (Expression) ⇒ Expression): SHAMapAccessor.this.type

    Permalink
    Definition Classes
    QueryPlan
  103. def mapProductIterator[B](f: (Any) ⇒ B)(implicit arg0: ClassTag[B]): Array[B]

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  104. def metadata: Map[String, String]

    Permalink
    Definition Classes
    SparkPlan
  105. def metricTerm(ctx: CodegenContext, name: String): String

    Permalink
    Definition Classes
    CodegenSupport
  106. def metrics: Map[String, SQLMetric]

    Permalink
    Definition Classes
    SparkPlan
  107. def missingInput: AttributeSet

    Permalink
    Definition Classes
    QueryPlan
  108. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  109. def newMutableProjection(expressions: Seq[Expression], inputSchema: Seq[Attribute], useSubexprElimination: Boolean): MutableProjection

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  110. def newNaturalAscendingOrdering(dataTypes: Seq[DataType]): Ordering[InternalRow]

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  111. def newOrdering(order: Seq[SortOrder], inputSchema: Seq[Attribute]): Ordering[InternalRow]

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  112. def newPredicate(expression: Expression, inputSchema: Seq[Attribute]): Predicate

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  113. def nodeName: String

    Permalink
    Definition Classes
    TreeNode
  114. final def notify(): Unit

    Permalink
    Definition Classes
    AnyRef
  115. final def notifyAll(): Unit

    Permalink
    Definition Classes
    AnyRef
  116. val nullAggsBitsetTerm: String

    Permalink
  117. val nullKeysBitsetTerm: String

    Permalink
  118. val numBytesForNullAggBits: Int

    Permalink
  119. val numBytesForNullKeyBits: Int

    Permalink
  120. val numKeyBytesTerm: String

    Permalink
  121. val numValueBytes: Int

    Permalink
  122. def numberedTreeString: String

    Permalink
    Definition Classes
    TreeNode
  123. val origin: Origin

    Permalink
    Definition Classes
    TreeNode
  124. def otherCopyArgs: Seq[AnyRef]

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  125. def output: Seq[Attribute]

    Permalink
    Definition Classes
    SHAMapAccessor → QueryPlan
  126. def outputOrdering: Seq[SortOrder]

    Permalink
    Definition Classes
    SparkPlan
  127. def outputPartitioning: Partitioning

    Permalink
    Definition Classes
    SparkPlan
  128. def outputSet: AttributeSet

    Permalink
    Definition Classes
    QueryPlan
  129. val overflowHashMapsTerm: String

    Permalink
  130. def p(number: Int): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  131. var parent: CodegenSupport

    Permalink
    Attributes
    protected
    Definition Classes
    CodegenSupport
  132. val platformClass: String

    Permalink
  133. final def prepare(): Unit

    Permalink
    Definition Classes
    SparkPlan
  134. def prepareSubqueries(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  135. def prettyJson: String

    Permalink
    Definition Classes
    TreeNode
  136. val previousSingleKey_Position_LenTerm: Option[(String, String, String)]

    Permalink
  137. def printSchema(): Unit

    Permalink
    Definition Classes
    QueryPlan
  138. final def produce(ctx: CodegenContext, parent: CodegenSupport): String

    Permalink
    Definition Classes
    CodegenSupport
  139. def producedAttributes: AttributeSet

    Permalink
    Definition Classes
    QueryPlan
  140. def readNullBitsCode(currentValueOffsetTerm: String, nullBitsetTerm: String, numBytesForNullBits: Int): String

    Permalink
  141. def readVarsFromBBMap(dataTypes: Seq[DataType], varNames: Seq[String], currentValueOffsetTerm: String, isKey: Boolean, nullBitTerm: String, numBytesForNullBits: Int, skipNullBitsCode: Boolean, splitCode: Boolean, useTheseNullVarsForAggBuffer: Option[Seq[String]], castVarToDataType: Boolean = false): (Option[String], Seq[ExprCode])

    Permalink
  142. def references: AttributeSet

    Permalink
    Definition Classes
    QueryPlan
  143. def requiredChildDistribution: Seq[Distribution]

    Permalink
    Definition Classes
    SparkPlan
  144. def requiredChildOrdering: Seq[Seq[SortOrder]]

    Permalink
    Definition Classes
    SparkPlan
  145. def resetMetrics(): Unit

    Permalink
    Definition Classes
    SparkPlan
  146. def sameResult(plan: SparkPlan): Boolean

    Permalink
    Definition Classes
    QueryPlan
  147. lazy val schema: StructType

    Permalink
    Definition Classes
    QueryPlan
  148. def schemaString: String

    Permalink
    Definition Classes
    QueryPlan
  149. val session: SnappySession

    Permalink
  150. val shaMapClassName: String

    Permalink
  151. def simpleString: String

    Permalink
    Definition Classes
    QueryPlan → TreeNode
  152. val sizeAndNumNotNullFuncForStringArr: String

    Permalink
  153. val skipLenForAttribIndex: Int

    Permalink
  154. def sparkContext: SparkContext

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  155. val splitAggCode: Boolean

    Permalink
  156. val splitGroupByKeyCode: Boolean

    Permalink
  157. final val sqlContext: SQLContext

    Permalink
    Definition Classes
    SparkPlan
  158. def statePrefix: String

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  159. val storedAggNullBitsTerm: Option[String]

    Permalink
  160. val storedKeyNullBitsTerm: Option[String]

    Permalink
  161. def stringArgs: Iterator[Any]

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  162. val subexpressionEliminationEnabled: Boolean

    Permalink
    Definition Classes
    SparkPlan
  163. def subqueries: Seq[SparkPlan]

    Permalink
    Definition Classes
    QueryPlan
  164. def supportCodegen: Boolean

    Permalink
    Definition Classes
    CodegenSupport
  165. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  166. def toJSON: String

    Permalink
    Definition Classes
    TreeNode
  167. def toString(): String

    Permalink
    Definition Classes
    TreeNode → AnyRef → Any
  168. def transform(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  169. def transformAllExpressions(rule: PartialFunction[Expression, Expression]): SHAMapAccessor.this.type

    Permalink
    Definition Classes
    QueryPlan
  170. def transformDown(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  171. def transformExpressions(rule: PartialFunction[Expression, Expression]): SHAMapAccessor.this.type

    Permalink
    Definition Classes
    QueryPlan
  172. def transformExpressionsDown(rule: PartialFunction[Expression, Expression]): SHAMapAccessor.this.type

    Permalink
    Definition Classes
    QueryPlan
  173. def transformExpressionsUp(rule: PartialFunction[Expression, Expression]): SHAMapAccessor.this.type

    Permalink
    Definition Classes
    QueryPlan
  174. def transformUp(rule: PartialFunction[SparkPlan, SparkPlan]): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  175. def treeString(verbose: Boolean): String

    Permalink
    Definition Classes
    TreeNode
  176. def treeString: String

    Permalink
    Definition Classes
    TreeNode
  177. val typeUtiltiesObjectClass: String

    Permalink
  178. val unsafeArrayClass: String

    Permalink
  179. val unsafeClass: String

    Permalink
  180. val unsafeRowClass: String

    Permalink
  181. val useCustomHashMap: Boolean

    Permalink
  182. def usedInputs: AttributeSet

    Permalink
    Definition Classes
    CodegenSupport
  183. def validConstraints: Set[Expression]

    Permalink
    Attributes
    protected
    Definition Classes
    QueryPlan
  184. val valueDataCapacityTerm: String

    Permalink
  185. val valueDataTerm: String

    Permalink
  186. val valueExprs: Seq[Expression]

    Permalink
  187. val valueOffsetTerm: String

    Permalink
  188. val vdBaseObjectTerm: String

    Permalink
  189. val vdBaseOffsetTerm: String

    Permalink
  190. def verboseString: String

    Permalink
    Definition Classes
    QueryPlan → TreeNode
  191. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  194. def waitForSubqueries(): Unit

    Permalink
    Attributes
    protected
    Definition Classes
    SparkPlan
  195. def withNewChildren(newChildren: Seq[SparkPlan]): SparkPlan

    Permalink
    Definition Classes
    TreeNode
  196. def writeKeyOrValue(baseObjectTerm: String, offsetTerm: String, dataTypes: Seq[DataType], varsToWrite: Seq[ExprCode], nullBitsTerm: String, numBytesForNullBits: Int, isKey: Boolean, skipNullEvalCode: Boolean, nestingLevel: Int = 0): String

    Permalink
  197. def writeNullBitsAt(baseObjectTerm: String, offsetToWriteTerm: String, nullBitsTerm: String, numBytesForNullBits: Int): String

    Permalink

Inherited from CodegenSupport

Inherited from SparkPlan

Inherited from Serializable

Inherited from Serializable

Inherited from internal.Logging

Inherited from QueryPlan[SparkPlan]

Inherited from TreeNode[SparkPlan]

Inherited from Product

Inherited from Equals

Inherited from AnyRef

Inherited from Any

Ungrouped