org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates
Class VectorAggregateExpression

java.lang.Object
  extended by org.apache.hadoop.hive.ql.exec.vector.expressions.aggregates.VectorAggregateExpression
All Implemented Interfaces:
Serializable
Direct Known Subclasses:
VectorUDAFAvgDecimal, VectorUDAFCount, VectorUDAFCountStar, VectorUDAFSumDecimal

public abstract class VectorAggregateExpression
extends Object
implements Serializable

Base class for aggregation expressions.

See Also:
Serialized Form

Nested Class Summary
static interface VectorAggregateExpression.AggregationBuffer
          Buffer interface to store aggregates.
 
Constructor Summary
VectorAggregateExpression()
           
 
Method Summary
abstract  void aggregateInput(VectorAggregateExpression.AggregationBuffer agg, VectorizedRowBatch unit)
           
abstract  void aggregateInputSelection(VectorAggregationBufferRow[] aggregationBufferSets, int aggregateIndex, VectorizedRowBatch vrg)
           
abstract  Object evaluateOutput(VectorAggregateExpression.AggregationBuffer agg)
           
abstract  int getAggregationBufferFixedSize()
           
abstract  VectorAggregateExpression.AggregationBuffer getNewAggregationBuffer()
           
abstract  ObjectInspector getOutputObjectInspector()
           
 boolean hasVariableSize()
           
abstract  void init(AggregationDesc desc)
           
abstract  void reset(VectorAggregateExpression.AggregationBuffer agg)
           
 
Methods inherited from class java.lang.Object
equals, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
 

Constructor Detail

VectorAggregateExpression

public VectorAggregateExpression()
Method Detail

getNewAggregationBuffer

public abstract VectorAggregateExpression.AggregationBuffer getNewAggregationBuffer()
                                                                             throws HiveException
Throws:
HiveException

aggregateInput

public abstract void aggregateInput(VectorAggregateExpression.AggregationBuffer agg,
                                    VectorizedRowBatch unit)
                             throws HiveException
Throws:
HiveException

aggregateInputSelection

public abstract void aggregateInputSelection(VectorAggregationBufferRow[] aggregationBufferSets,
                                             int aggregateIndex,
                                             VectorizedRowBatch vrg)
                                      throws HiveException
Throws:
HiveException

reset

public abstract void reset(VectorAggregateExpression.AggregationBuffer agg)
                    throws HiveException
Throws:
HiveException

evaluateOutput

public abstract Object evaluateOutput(VectorAggregateExpression.AggregationBuffer agg)
                               throws HiveException
Throws:
HiveException

getOutputObjectInspector

public abstract ObjectInspector getOutputObjectInspector()

getAggregationBufferFixedSize

public abstract int getAggregationBufferFixedSize()

hasVariableSize

public boolean hasVariableSize()

init

public abstract void init(AggregationDesc desc)
                   throws HiveException
Throws:
HiveException


Copyright © 2014 The Apache Software Foundation. All rights reserved.