Class LagAggFunction<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,LagAggFunction.LagAcc<T>>
-
- org.apache.flink.table.runtime.functions.aggregate.LagAggFunction<T>
-
- All Implemented Interfaces:
Serializable,org.apache.flink.table.functions.FunctionDefinition
public class LagAggFunction<T> extends BuiltInAggregateFunction<T,LagAggFunction.LagAcc<T>>
LagAggregateFunction.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static classLagAggFunction.LagAcc<T>Accumulator for LAG.
-
Constructor Summary
Constructors Constructor Description LagAggFunction(org.apache.flink.table.types.logical.LogicalType[] valueTypes)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidaccumulate(LagAggFunction.LagAcc<T> acc, T value)voidaccumulate(LagAggFunction.LagAcc<T> acc, T value, int offset)voidaccumulate(LagAggFunction.LagAcc<T> acc, T value, int offset, T defaultValue)LagAggFunction.LagAcc<T>createAccumulator()org.apache.flink.table.types.DataTypegetAccumulatorDataType()List<org.apache.flink.table.types.DataType>getArgumentDataTypes()org.apache.flink.table.types.DataTypegetOutputDataType()TgetValue(LagAggFunction.LagAcc<T> acc)voidresetAccumulator(LagAggFunction.LagAcc<T> acc)-
Methods inherited from class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
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
-
getArgumentDataTypes
public List<org.apache.flink.table.types.DataType> getArgumentDataTypes()
- Overrides:
getArgumentDataTypesin classBuiltInAggregateFunction<T,LagAggFunction.LagAcc<T>>
-
getAccumulatorDataType
public org.apache.flink.table.types.DataType getAccumulatorDataType()
- Overrides:
getAccumulatorDataTypein classBuiltInAggregateFunction<T,LagAggFunction.LagAcc<T>>
-
getOutputDataType
public org.apache.flink.table.types.DataType getOutputDataType()
- Overrides:
getOutputDataTypein classBuiltInAggregateFunction<T,LagAggFunction.LagAcc<T>>
-
accumulate
public void accumulate(LagAggFunction.LagAcc<T> acc, T value) throws Exception
- Throws:
Exception
-
accumulate
public void accumulate(LagAggFunction.LagAcc<T> acc, T value, int offset) throws Exception
- Throws:
Exception
-
accumulate
public void accumulate(LagAggFunction.LagAcc<T> acc, T value, int offset, T defaultValue) throws Exception
- Throws:
Exception
-
resetAccumulator
public void resetAccumulator(LagAggFunction.LagAcc<T> acc) throws Exception
- Throws:
Exception
-
getValue
public T getValue(LagAggFunction.LagAcc<T> acc)
- Specified by:
getValuein classorg.apache.flink.table.functions.AggregateFunction<T,LagAggFunction.LagAcc<T>>
-
createAccumulator
public LagAggFunction.LagAcc<T> createAccumulator()
- Specified by:
createAccumulatorin classorg.apache.flink.table.functions.ImperativeAggregateFunction<T,LagAggFunction.LagAcc<T>>
-
-