Class FirstValueAggFunction<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,org.apache.flink.table.data.RowData>
-
- org.apache.flink.table.runtime.functions.aggregate.FirstValueAggFunction<T>
-
- All Implemented Interfaces:
Serializable
,org.apache.flink.table.functions.FunctionDefinition
@Internal public final class FirstValueAggFunction<T> extends BuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
Built-in FIRST_VALUE aggregate function.- See Also:
- Serialized Form
-
-
Constructor Summary
Constructors Constructor Description FirstValueAggFunction(org.apache.flink.table.types.logical.LogicalType valueType)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
accumulate(org.apache.flink.table.data.RowData rowData, Object value)
void
accumulate(org.apache.flink.table.data.RowData rowData, Object value, Long order)
void
accumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value)
void
accumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value, Long order)
org.apache.flink.table.data.RowData
createAccumulator()
org.apache.flink.table.types.DataType
getAccumulatorDataType()
List<org.apache.flink.table.types.DataType>
getArgumentDataTypes()
org.apache.flink.table.types.DataType
getOutputDataType()
T
getValue(org.apache.flink.table.data.RowData acc)
boolean
isDeterministic()
void
resetAccumulator(org.apache.flink.table.data.RowData rowData)
-
Methods inherited from class org.apache.flink.table.runtime.functions.aggregate.BuiltInAggregateFunction
getRequirements, getTypeInference
-
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:
getArgumentDataTypes
in classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
-
getAccumulatorDataType
public org.apache.flink.table.types.DataType getAccumulatorDataType()
- Overrides:
getAccumulatorDataType
in classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
-
getOutputDataType
public org.apache.flink.table.types.DataType getOutputDataType()
- Overrides:
getOutputDataType
in classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
-
isDeterministic
public boolean isDeterministic()
- Specified by:
isDeterministic
in interfaceorg.apache.flink.table.functions.FunctionDefinition
- Overrides:
isDeterministic
in classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
-
createAccumulator
public org.apache.flink.table.data.RowData createAccumulator()
- Specified by:
createAccumulator
in classorg.apache.flink.table.functions.ImperativeAggregateFunction<T,org.apache.flink.table.data.RowData>
-
accumulate
public void accumulate(org.apache.flink.table.data.RowData rowData, Object value)
-
accumulate
public void accumulate(org.apache.flink.table.data.RowData rowData, Object value, Long order)
-
accumulate
public void accumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value)
-
accumulate
public void accumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value, Long order)
-
resetAccumulator
public void resetAccumulator(org.apache.flink.table.data.RowData rowData)
-
-