Class PercentileAggFunction<T>
- java.lang.Object
-
- org.apache.flink.table.functions.UserDefinedFunction
-
- org.apache.flink.table.functions.ImperativeAggregateFunction<T,ACC>
-
- org.apache.flink.table.functions.AggregateFunction<T,ACC>
-
- org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction<T,PercentileAggFunction.PercentileAccumulator>
-
- org.apache.flink.table.runtime.functions.aggregate.PercentileAggFunction<T>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.table.functions.FunctionDefinition
- Direct Known Subclasses:
PercentileAggFunction.MultiPercentileAggFunction,PercentileAggFunction.SinglePercentileAggFunction
@Internal public abstract class PercentileAggFunction<T> extends BuiltInAggregateFunction<T,PercentileAggFunction.PercentileAccumulator>
Built-in PERCENTILE aggregate function.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static classPercentileAggFunction.MultiPercentileAggFunctionPercentile agg function with multiple percentage parameters.static classPercentileAggFunction.PercentileAccumulatorAccumulator for PERCENTILE.static classPercentileAggFunction.SinglePercentileAggFunctionPercentile agg function with only one percentage parameter.
-
Field Summary
Fields Modifier and Type Field Description protected org.apache.flink.table.types.DataTypefrequencyTypeprotected org.apache.flink.table.types.DataTypevalueType
-
Constructor Summary
Constructors Constructor Description PercentileAggFunction(org.apache.flink.table.types.logical.LogicalType inputType, org.apache.flink.table.types.logical.LogicalType frequencyType)
-
Method Summary
-
Methods inherited from class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
getArgumentDataTypes, getOutputDataType, getRequirements, getTypeInference, isDeterministic
-
Methods inherited from class org.apache.flink.table.functions.ImperativeAggregateFunction
getAccumulatorType, getResultType
-
Methods inherited from class org.apache.flink.table.functions.UserDefinedFunction
close, functionIdentifier, open, toString
-
-
-
-
Method Detail
-
getAccumulatorDataType
public org.apache.flink.table.types.DataType getAccumulatorDataType()
- Overrides:
getAccumulatorDataTypein classBuiltInAggregateFunction<T,PercentileAggFunction.PercentileAccumulator>
-
createAccumulator
public PercentileAggFunction.PercentileAccumulator createAccumulator()
- Specified by:
createAccumulatorin classorg.apache.flink.table.functions.ImperativeAggregateFunction<T,PercentileAggFunction.PercentileAccumulator>
-
accumulate
public void accumulate(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double percentage) throws Exception
- Throws:
Exception
-
accumulate
public void accumulate(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double percentage, @Nullable Number frequency) throws Exception
- Throws:
Exception
-
accumulate
public void accumulate(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double[] percentage) throws Exception
- Throws:
Exception
-
accumulate
public void accumulate(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double[] percentage, @Nullable Number frequency) throws Exception
- Throws:
Exception
-
retract
public void retract(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double percentage) throws Exception
- Throws:
Exception
-
retract
public void retract(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double percentage, @Nullable Number frequency) throws Exception
- Throws:
Exception
-
retract
public void retract(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double[] percentage) throws Exception
- Throws:
Exception
-
retract
public void retract(PercentileAggFunction.PercentileAccumulator acc, @Nullable Object value, Double[] percentage, @Nullable Number frequency) throws Exception
- Throws:
Exception
-
merge
public void merge(PercentileAggFunction.PercentileAccumulator acc, Iterable<PercentileAggFunction.PercentileAccumulator> its) throws Exception
- Throws:
Exception
-
-