Class/Object

org.apache.spark.sql.execution.aggregate

TypedAggregateExpression

Related Docs: object TypedAggregateExpression | package aggregate

Permalink

case class TypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], aEncoder: Option[ExpressionEncoder[Any]], unresolvedBEncoder: ExpressionEncoder[Any], cEncoder: ExpressionEncoder[Any], children: Seq[Attribute], mutableAggBufferOffset: Int, inputAggBufferOffset: Int) extends ImperativeAggregate with Logging with Product with Serializable

This class is a rough sketch of how to hook Aggregator into the Aggregation system. It has the following limitations:

Linear Supertypes
Serializable, Serializable, Logging, ImperativeAggregate, AggregateFunction, ImplicitCastInputTypes, ExpectsInputTypes, Expression, TreeNode[Expression], Product, Equals, AnyRef, Any
Ordering
  1. Alphabetic
  2. By inheritance
Inherited
  1. TypedAggregateExpression
  2. Serializable
  3. Serializable
  4. Logging
  5. ImperativeAggregate
  6. AggregateFunction
  7. ImplicitCastInputTypes
  8. ExpectsInputTypes
  9. Expression
  10. TreeNode
  11. Product
  12. Equals
  13. AnyRef
  14. Any
  1. Hide All
  2. Show all
Visibility
  1. Public
  2. All

Instance Constructors

  1. new TypedAggregateExpression(aggregator: expressions.Aggregator[Any, Any, Any], aEncoder: Option[ExpressionEncoder[Any]], unresolvedBEncoder: ExpressionEncoder[Any], cEncoder: ExpressionEncoder[Any], children: Seq[Attribute], mutableAggBufferOffset: Int, inputAggBufferOffset: Int)

    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 aEncoder: Option[ExpressionEncoder[Any]]

    Permalink
  5. val aggBufferAttributes: Seq[AttributeReference]

    Permalink
    Definition Classes
    TypedAggregateExpression → AggregateFunction
  6. val aggBufferSchema: StructType

    Permalink
    Definition Classes
    TypedAggregateExpression → AggregateFunction
  7. val aggregator: expressions.Aggregator[Any, Any, Any]

    Permalink
  8. def apply(number: Int): Expression

    Permalink
    Definition Classes
    TreeNode
  9. def argString: String

    Permalink
    Definition Classes
    TreeNode
  10. def asCode: String

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

    Permalink
    Definition Classes
    Any
  12. val bEncoder: ExpressionEncoder[Any]

    Permalink
  13. lazy val boundA: ExpressionEncoder[Any]

    Permalink
  14. val cEncoder: ExpressionEncoder[Any]

    Permalink
  15. def checkInputDataTypes(): TypeCheckResult

    Permalink
    Definition Classes
    ExpectsInputTypes → Expression
  16. val children: Seq[Attribute]

    Permalink
    Definition Classes
    TypedAggregateExpression → TreeNode
  17. def childrenResolved: Boolean

    Permalink
    Definition Classes
    Expression
  18. def clone(): AnyRef

    Permalink
    Attributes
    protected[java.lang]
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  19. def collect[B](pf: PartialFunction[Expression, B]): Seq[B]

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

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

    Permalink
    Definition Classes
    TreeNode
  22. def dataType: DataType

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression
  23. def defaultResult: Option[Literal]

    Permalink
    Definition Classes
    AggregateFunction
  24. def deterministic: Boolean

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression
  25. final def eq(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  26. def eval(buffer: InternalRow): Any

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression
  27. def fastEquals(other: TreeNode[_]): Boolean

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

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

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

    Permalink
    Definition Classes
    TreeNode
  31. final def foldable: Boolean

    Permalink
    Definition Classes
    AggregateFunction → Expression
  32. def foreach(f: (Expression) ⇒ Unit): Unit

    Permalink
    Definition Classes
    TreeNode
  33. def foreachUp(f: (Expression) ⇒ Unit): Unit

    Permalink
    Definition Classes
    TreeNode
  34. def gen(ctx: CodeGenContext): GeneratedExpressionCode

    Permalink
    Definition Classes
    Expression
  35. def genCode(ctx: CodeGenContext, ev: GeneratedExpressionCode): String

    Permalink
    Attributes
    protected
    Definition Classes
    AggregateFunction → Expression
  36. def generateTreeString(depth: Int, lastChildren: Seq[Boolean], builder: StringBuilder): StringBuilder

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  37. final def getClass(): Class[_]

    Permalink
    Definition Classes
    AnyRef → Any
  38. def getNodeNumbered(number: MutableInt): Expression

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  39. def initialize(buffer: MutableRow): Unit

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  40. val inputAggBufferAttributes: Seq[AttributeReference]

    Permalink
    Definition Classes
    TypedAggregateExpression → AggregateFunction
  41. val inputAggBufferOffset: Int

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  42. lazy val inputTypes: Seq[DataType]

    Permalink
    Definition Classes
    TypedAggregateExpression → ExpectsInputTypes
  43. final def isInstanceOf[T0]: Boolean

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  45. def log: Logger

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

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

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

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

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

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

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

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

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

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

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

    Permalink
    Attributes
    protected
    Definition Classes
    Logging
  57. def makeCopy(newArgs: Array[AnyRef]): Expression

    Permalink
    Definition Classes
    TreeNode
  58. def map[A](f: (Expression) ⇒ A): Seq[A]

    Permalink
    Definition Classes
    TreeNode
  59. def mapChildren(f: (Expression) ⇒ Expression): Expression

    Permalink
    Definition Classes
    TreeNode
  60. def merge(buffer1: MutableRow, buffer2: InternalRow): Unit

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  61. val mutableAggBufferOffset: Int

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  62. final def ne(arg0: AnyRef): Boolean

    Permalink
    Definition Classes
    AnyRef
  63. def nodeName: String

    Permalink
    Definition Classes
    TypedAggregateExpression → TreeNode
  64. final def notify(): Unit

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

    Permalink
    Definition Classes
    AnyRef
  66. def nullable: Boolean

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression
  67. def numberedTreeString: String

    Permalink
    Definition Classes
    TreeNode
  68. val origin: Origin

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

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  70. def prettyName: String

    Permalink
    Definition Classes
    Expression
  71. def prettyString: String

    Permalink
    Definition Classes
    Expression
  72. def references: AttributeSet

    Permalink
    Definition Classes
    Expression
  73. lazy val resolved: Boolean

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression
  74. def semanticEquals(other: Expression): Boolean

    Permalink
    Definition Classes
    Expression
  75. def semanticHash(): Int

    Permalink
    Definition Classes
    Expression
  76. def simpleString: String

    Permalink
    Definition Classes
    Expression → TreeNode
  77. def stringArgs: Iterator[Any]

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  78. def supportsPartial: Boolean

    Permalink
    Definition Classes
    AggregateFunction
  79. final def synchronized[T0](arg0: ⇒ T0): T0

    Permalink
    Definition Classes
    AnyRef
  80. def toAggregateExpression(isDistinct: Boolean): AggregateExpression

    Permalink
    Definition Classes
    AggregateFunction
  81. def toAggregateExpression(): AggregateExpression

    Permalink
    Definition Classes
    AggregateFunction
  82. def toCommentSafeString: String

    Permalink
    Attributes
    protected
    Definition Classes
    Expression
  83. def toString(): String

    Permalink
    Definition Classes
    TypedAggregateExpression → Expression → TreeNode → AnyRef → Any
  84. def transform(rule: PartialFunction[Expression, Expression]): Expression

    Permalink
    Definition Classes
    TreeNode
  85. def transformChildren(rule: PartialFunction[Expression, Expression], nextOperation: (Expression, PartialFunction[Expression, Expression]) ⇒ Expression): Expression

    Permalink
    Attributes
    protected
    Definition Classes
    TreeNode
  86. def transformDown(rule: PartialFunction[Expression, Expression]): Expression

    Permalink
    Definition Classes
    TreeNode
  87. def transformUp(rule: PartialFunction[Expression, Expression]): Expression

    Permalink
    Definition Classes
    TreeNode
  88. def treeString: String

    Permalink
    Definition Classes
    TreeNode
  89. val unresolvedBEncoder: ExpressionEncoder[Any]

    Permalink
  90. def update(buffer: MutableRow, input: InternalRow): Unit

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  91. final def wait(): Unit

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

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

    Permalink
    Definition Classes
    AnyRef
    Annotations
    @throws( ... )
  94. def withNewChildren(newChildren: Seq[Expression]): Expression

    Permalink
    Definition Classes
    TreeNode
  95. def withNewInputAggBufferOffset(newInputAggBufferOffset: Int): ImperativeAggregate

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate
  96. def withNewMutableAggBufferOffset(newMutableAggBufferOffset: Int): ImperativeAggregate

    Permalink
    Definition Classes
    TypedAggregateExpression → ImperativeAggregate

Inherited from Serializable

Inherited from Serializable

Inherited from Logging

Inherited from ImperativeAggregate

Inherited from AggregateFunction

Inherited from ImplicitCastInputTypes

Inherited from ExpectsInputTypes

Inherited from Expression

Inherited from TreeNode[Expression]

Inherited from Product

Inherited from Equals

Inherited from AnyRef

Inherited from Any

Ungrouped