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 voidaccumulate(org.apache.flink.table.data.RowData rowData, Object value)voidaccumulate(org.apache.flink.table.data.RowData rowData, Object value, Long order)voidaccumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value)voidaccumulate(org.apache.flink.table.data.RowData rowData, org.apache.flink.table.data.StringData value, Long order)org.apache.flink.table.data.RowDatacreateAccumulator()org.apache.flink.table.types.DataTypegetAccumulatorDataType()List<org.apache.flink.table.types.DataType>getArgumentDataTypes()org.apache.flink.table.types.DataTypegetOutputDataType()TgetValue(org.apache.flink.table.data.RowData acc)booleanisDeterministic()voidresetAccumulator(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:
 getArgumentDataTypesin classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
 
- 
getAccumulatorDataType
public org.apache.flink.table.types.DataType getAccumulatorDataType()
- Overrides:
 getAccumulatorDataTypein classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
 
- 
getOutputDataType
public org.apache.flink.table.types.DataType getOutputDataType()
- Overrides:
 getOutputDataTypein classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
 
- 
isDeterministic
public boolean isDeterministic()
- Specified by:
 isDeterministicin interfaceorg.apache.flink.table.functions.FunctionDefinition- Overrides:
 isDeterministicin classBuiltInAggregateFunction<T,org.apache.flink.table.data.RowData>
 
- 
createAccumulator
public org.apache.flink.table.data.RowData createAccumulator()
- Specified by:
 createAccumulatorin 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)
 
 - 
 
 -