public abstract static class GenericUDAFSum.GenericUDAFSumEvaluator<ResultType extends org.apache.hadoop.io.Writable> extends GenericUDAFEvaluator
GenericUDAFEvaluator.AbstractAggregationBuffer, GenericUDAFEvaluator.AggregationBuffer, GenericUDAFEvaluator.AggregationType, GenericUDAFEvaluator.Mode| Modifier and Type | Field and Description |
|---|---|
protected PrimitiveObjectInspector |
inputOI |
protected boolean |
isWindowing |
protected PrimitiveObjectInspector |
outputOI |
protected ResultType |
result |
protected boolean |
sumDistinct |
partitionEvaluator| Constructor and Description |
|---|
GenericUDAFSumEvaluator() |
| Modifier and Type | Method and Description |
|---|---|
protected boolean |
isEligibleValue(org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumEvaluator.SumAgg agg,
Object input)
Check if the input object is eligible to contribute to the sum.
|
boolean |
isWindowingDistinct() |
void |
setSumDistinct(boolean sumDistinct) |
void |
setWindowing(boolean isWindowing) |
Object |
terminatePartial(GenericUDAFEvaluator.AggregationBuffer agg)
Get partial aggregation result.
|
aggregate, close, configure, createPartitionEvaluator, estimate, evaluate, getExprString, getNewAggregationBuffer, getPartitionWindowingEvaluator, getWindowingEvaluator, init, isEstimable, iterate, merge, reset, terminateprotected PrimitiveObjectInspector inputOI
protected PrimitiveObjectInspector outputOI
protected ResultType extends org.apache.hadoop.io.Writable result
protected boolean isWindowing
protected boolean sumDistinct
public void setWindowing(boolean isWindowing)
public void setSumDistinct(boolean sumDistinct)
public boolean isWindowingDistinct()
public Object terminatePartial(GenericUDAFEvaluator.AggregationBuffer agg) throws HiveException
GenericUDAFEvaluatorterminatePartial in class GenericUDAFEvaluatorHiveExceptionprotected boolean isEligibleValue(org.apache.hadoop.hive.ql.udf.generic.GenericUDAFSum.GenericUDAFSumEvaluator.SumAgg agg,
Object input)
input - the input objectCopyright © 2019 The Apache Software Foundation. All Rights Reserved.