org.apache.hadoop.hive.ql.exec

GroupByPostShuffleOperator

class GroupByPostShuffleOperator extends GroupByPreShuffleOperator with ReduceSinkTableDesc

Linear Supertypes
ReduceSinkTableDesc, GroupByPreShuffleOperator, UnaryOperator[GroupByDesc], shark.execution.Operator[GroupByDesc], Serializable, Serializable, LogHelper, Logging, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. GroupByPostShuffleOperator
  2. ReduceSinkTableDesc
  3. GroupByPreShuffleOperator
  4. UnaryOperator
  5. Operator
  6. Serializable
  7. Serializable
  8. LogHelper
  9. Logging
  10. AnyRef
  11. Any
  1. Hide All
  2. Show all
Learn more about member selection
Visibility
  1. Public
  2. All

Instance Constructors

  1. new GroupByPostShuffleOperator()

Value Members

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

    Definition Classes
    AnyRef
  2. final def !=(arg0: Any): Boolean

    Definition Classes
    Any
  3. final def ##(): Int

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

    Definition Classes
    AnyRef
  5. final def ==(arg0: Any): Boolean

    Definition Classes
    Any
  6. def addChild(child: shark.execution.Operator[_ <: HiveDesc]): Unit

    Definition Classes
    Operator
  7. def addParent(parent: shark.execution.Operator[_ <: HiveDesc]): Unit

    Definition Classes
    Operator
  8. final def aggregateExistingKey(row: AnyRef, aggregations: Array[AggregationBuffer]): Unit

    Attributes
    protected
    Definition Classes
    GroupByPreShuffleOperator
    Annotations
    @inline()
  9. final def aggregateNewKey(row: AnyRef, aggregations: Array[AggregationBuffer]): Unit

    Attributes
    protected
    Definition Classes
    GroupByPreShuffleOperator
    Annotations
    @inline()
  10. var aggregationEvals: Array[GenericUDAFEvaluator]

    Definition Classes
    GroupByPreShuffleOperator
  11. var aggregationIsDistinct: Array[Boolean]

    Definition Classes
    GroupByPreShuffleOperator
  12. var aggregationObjectInspectors: Array[ObjectInspector]

    Definition Classes
    GroupByPreShuffleOperator
  13. var aggregationParameterFields: Array[Array[ExprNodeEvaluator]]

    Definition Classes
    GroupByPreShuffleOperator
  14. var aggregationParameterObjectInspectors: Array[Array[ObjectInspector]]

    Definition Classes
    GroupByPreShuffleOperator
  15. var aggregationParameterStandardObjectInspectors: Array[Array[ObjectInspector]]

    Definition Classes
    GroupByPreShuffleOperator
  16. final def asInstanceOf[T0]: T0

    Definition Classes
    Any
  17. def childOperators: ArrayBuffer[shark.execution.Operator[_ <: HiveDesc]]

    Definition Classes
    Operator
  18. def clone(): AnyRef

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. var cloneNewKeysArray: Array[AnyRef]

    Definition Classes
    GroupByPreShuffleOperator
  20. var conf: GroupByDesc

    Definition Classes
    GroupByPreShuffleOperator
  21. def createLocals(): Unit

  22. def createRemotes(): Unit

  23. var currentKeyObjectInspectors: Array[ObjectInspector]

    Definition Classes
    GroupByPreShuffleOperator
  24. def desc: GroupByDesc

    Definition Classes
    Operator
  25. val distinctHashSets: HashMap[Int, ArrayList[HashSet[KeyWrapper]]]

  26. val distinctKeyAggrs: HashMap[Int, Set[Integer]]

  27. val distinctKeyWrapperFactories: HashMap[Int, ArrayList[KeyWrapperFactory]]

  28. final def eq(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  29. def equals(arg0: Any): Boolean

    Definition Classes
    AnyRef → Any
  30. def errStream(): PrintStream

    Definition Classes
    LogHelper
  31. def execute(): RDD[_]

    Execute the operator.

    Execute the operator. This should recursively execute parent operators.

    Definition Classes
    GroupByPostShuffleOperatorUnaryOperatorOperator
  32. def executeParents(): Seq[(Int, RDD[_])]

    Attributes
    protected
    Definition Classes
    Operator
  33. def finalize(): Unit

    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( classOf[java.lang.Throwable] )
  34. final def getClass(): Class[_]

    Definition Classes
    AnyRef → Any
  35. def getConf(): GroupByDesc

    Definition Classes
    GroupByPreShuffleOperator
  36. def getKeyTableDesc(): TableDesc

  37. def getMinReductionHashAggr(): Float

    Definition Classes
    GroupByPreShuffleOperator
  38. final def getNewKeysIterator(newKeysArray: Array[AnyRef]): Iterator[Unit]

    Attributes
    protected
    Definition Classes
    GroupByPreShuffleOperator
  39. def getNumRowsCompareHashAggr(): Int

    Definition Classes
    GroupByPreShuffleOperator
  40. def getTag: Int

    Return the join tag.

    Return the join tag. This is usually just 0. ReduceSink might set it to something else.

    Definition Classes
    Operator
  41. def getValueTableDesc(): TableDesc

  42. var groupingSets: List[Integer]

    Definition Classes
    GroupByPreShuffleOperator
  43. var groupingSetsBitSet: Array[BitSet1]

    Definition Classes
    GroupByPreShuffleOperator
  44. var groupingSetsPosition: Int

    Definition Classes
    GroupByPreShuffleOperator
  45. var groupingSetsPresent: Boolean

    Definition Classes
    GroupByPreShuffleOperator
  46. def hashAggregate(iter: Iterator[_]): Iterator[Array[AnyRef]]

  47. def hashCode(): Int

    Definition Classes
    AnyRef → Any
  48. def hconf: HiveConf

    Definition Classes
    Operator
  49. def initEvaluators(evals: Array[ExprNodeEvaluator], start: Int, length: Int, rowInspector: ObjectInspector): Array[ObjectInspector]

    Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.

    Initialize an array of ExprNodeEvaluator from start, for specified length and return the result ObjectInspectors.

    Attributes
    protected
    Definition Classes
    Operator
  50. def initEvaluators(evals: Array[ExprNodeEvaluator], rowInspector: ObjectInspector): Array[ObjectInspector]

    Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.

    Initialize an array of ExprNodeEvaluator and return the result ObjectInspectors.

    Attributes
    protected
    Definition Classes
    Operator
  51. def initEvaluatorsAndReturnStruct(evals: Array[ExprNodeEvaluator], outputColName: List[String], rowInspector: ObjectInspector): StructObjectInspector

    Initialize an array of ExprNodeEvaluator and put the return values into a StructObjectInspector with integer field names.

    Initialize an array of ExprNodeEvaluator and put the return values into a StructObjectInspector with integer field names.

    Attributes
    protected
    Definition Classes
    Operator
  52. def initEvaluatorsAndReturnStruct(evals: Array[ExprNodeEvaluator], fieldObjectInspectors: Array[ObjectInspector], distinctColIndices: List[List[Integer]], outputColNames: List[String], length: Int, rowInspector: ObjectInspector): StructObjectInspector

    Copy from the org.

    Copy from the org.apache.hadoop.hive.ql.exec.ReduceSinkOperator Initializes array of ExprNodeEvaluator. Adds Union field for distinct column indices for group by. Puts the return values into a StructObjectInspector with output column names.

    If distinctColIndices is empty, the object inspector is same as Operator#initEvaluatorsAndReturnStruct(ExprNodeEvaluator[], List, ObjectInspector)

    Attributes
    protected
    Definition Classes
    Operator
  53. def initEvaluatorsAndReturnStruct(evals: Array[ExprNodeEvaluator], distinctColIndices: List[List[Integer]], outputColNames: List[String], length: Int, rowInspector: ObjectInspector): StructObjectInspector

    Copy from the org.

    Copy from the org.apache.hadoop.hive.ql.exec.ReduceSinkOperator Initializes array of ExprNodeEvaluator. Adds Union field for distinct column indices for group by. Puts the return values into a StructObjectInspector with output column names.

    If distinctColIndices is empty, the object inspector is same as Operator#initEvaluatorsAndReturnStruct(ExprNodeEvaluator[], List, ObjectInspector)

    Attributes
    protected
    Definition Classes
    Operator
  54. def initializeMasterOnAll(): Unit

    Recursively calls initializeOnMaster() for the entire query plan.

    Recursively calls initializeOnMaster() for the entire query plan. Parent operators are called before children.

    Definition Classes
    Operator
  55. def initializeOnMaster(): Unit

    Initialize the operator on master node.

    Initialize the operator on master node. This can have dependency on other nodes. When an operator's initializeOnMaster() is invoked, all its parents' initializeOnMaster() have been invoked.

    Definition Classes
    GroupByPreShuffleOperatorOperator
  56. def initializeOnSlave(): Unit

    Initialize the operator on slave nodes.

    Initialize the operator on slave nodes. This method should have no dependency on parents or children. Everything that is not used in this method should be marked @transient.

    Definition Classes
    GroupByPreShuffleOperatorOperator
  57. def inputObjectInspectors(): Seq[ObjectInspector]

    Attributes
    protected
    Definition Classes
    Operator
  58. final def isInstanceOf[T0]: Boolean

    Definition Classes
    Any
  59. def isTraceEnabled(): Boolean

    Attributes
    protected
    Definition Classes
    Logging
  60. var keyFactory: KeyWrapperFactory

    Definition Classes
    GroupByPreShuffleOperator
  61. var keyFields: Array[ExprNodeEvaluator]

    Definition Classes
    GroupByPreShuffleOperator
  62. var keyObjectInspector: StructObjectInspector

    Definition Classes
    GroupByPreShuffleOperator
  63. var keySer: Deserializer

  64. var keySer1: Deserializer

  65. var keyTableDesc: TableDesc

  66. def keyValueDescs(): Seq[(Int, (TableDesc, TableDesc))]

    Definition Classes
    ReduceSinkTableDesc
  67. def log: Logger

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

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

    Attributes
    protected
    Definition Classes
    Logging
  70. def logError(msg: String, exception: Throwable): Unit

    Definition Classes
    LogHelper
  71. def logError(msg: String, detail: String): Unit

    Definition Classes
    LogHelper
  72. def logError(msg: ⇒ String): Unit

    Definition Classes
    LogHelper → Logging
  73. def logError(msg: ⇒ String, throwable: Throwable): Unit

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

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

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

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

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

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

    Attributes
    protected
    Definition Classes
    Logging
  80. var minReductionHashAggr: Float

    Definition Classes
    GroupByPreShuffleOperator
  81. final def ne(arg0: AnyRef): Boolean

    Definition Classes
    AnyRef
  82. def newAggregations(): Array[AggregationBuffer]

    Attributes
    protected
    Definition Classes
    GroupByPreShuffleOperator
  83. var newKeysGroupingSets: Array[AnyRef]

    Definition Classes
    GroupByPreShuffleOperator
  84. val nonDistinctAggrs: ArrayList[Int]

  85. val nonDistinctKeyAggrs: HashMap[Int, Set[Integer]]

  86. final def notify(): Unit

    Definition Classes
    AnyRef
  87. final def notifyAll(): Unit

    Definition Classes
    AnyRef
  88. var numRowsCompareHashAggr: Int

    Definition Classes
    GroupByPreShuffleOperator
  89. def objectInspector: ObjectInspector

    Definition Classes
    UnaryOperator
  90. var objectInspectors: Seq[ObjectInspector]

    Definition Classes
    Operator
  91. def outStream(): PrintStream

    Definition Classes
    LogHelper
  92. def outputObjectInspector(): StandardStructObjectInspector

    Definition Classes
    GroupByPreShuffleOperatorOperator
  93. def parentOperator: shark.execution.Operator[HiveDesc]

    Definition Classes
    UnaryOperator
  94. def parentOperators: ArrayBuffer[shark.execution.Operator[_ <: HiveDesc]]

    Definition Classes
    Operator
  95. def parentOperatorsAsJavaList: List[shark.execution.Operator[_ <: HiveDesc]]

    Return the parent operators as a Java List.

    Return the parent operators as a Java List. This is for interoperability with Java. We use this in explain's Java code.

    Definition Classes
    Operator
  96. def postprocessRdd(rdd: RDD[_]): RDD[_]

    Called on master.

    Called on master.

    Definition Classes
    UnaryOperator
  97. def preprocessRdd(rdd: RDD[_]): RDD[_]

    Called on master.

    Called on master.

    Definition Classes
    UnaryOperator
  98. def processPartition(split: Int, iter: Iterator[_]): Iterator[Array[AnyRef]]

    Process a partition.

    Process a partition. Called on slaves.

    Definition Classes
    GroupByPreShuffleOperatorUnaryOperatorOperator
  99. def returnTerminalOperators(): Seq[shark.execution.Operator[_ <: HiveDesc]]

    Definition Classes
    Operator
  100. def returnTopOperators(): Seq[shark.execution.Operator[_]]

    Definition Classes
    Operator
  101. var rowInspector: ObjectInspector

    Definition Classes
    GroupByPreShuffleOperator
  102. def setConf(arg0: GroupByDesc): Unit

    Definition Classes
    GroupByPreShuffleOperator
  103. def setDesc[B >: GroupByDesc](d: B): Unit

    Definition Classes
    Operator
  104. def setKeyTableDesc(arg0: TableDesc): Unit

  105. def setMinReductionHashAggr(arg0: Float): Unit

    Definition Classes
    GroupByPreShuffleOperator
  106. def setNumRowsCompareHashAggr(arg0: Int): Unit

    Definition Classes
    GroupByPreShuffleOperator
  107. def setValueTableDesc(arg0: TableDesc): Unit

  108. def sortAggregate(iter: Iterator[_]): Iterator[Array[AnyRef]]

  109. final def synchronized[T0](arg0: ⇒ T0): T0

    Definition Classes
    AnyRef
  110. def toString(): String

    Definition Classes
    AnyRef → Any
  111. var unionExprEvaluator: ExprNodeEvaluator

  112. var valueSer: Deserializer

  113. var valueSer1: Deserializer

  114. var valueTableDesc: TableDesc

  115. final def wait(): Unit

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

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

    Definition Classes
    AnyRef
    Annotations
    @throws( ... )

Inherited from ReduceSinkTableDesc

Inherited from GroupByPreShuffleOperator

Inherited from UnaryOperator[GroupByDesc]

Inherited from shark.execution.Operator[GroupByDesc]

Inherited from Serializable

Inherited from Serializable

Inherited from LogHelper

Inherited from Logging

Inherited from AnyRef

Inherited from Any

Ungrouped