Package | Description |
---|---|
org.apache.flink.streaming.api.utils | |
org.apache.flink.table.runtime.operators.python.aggregate |
Modifier and Type | Method and Description |
---|---|
static FlinkFnApi.UserDefinedAggregateFunction |
PythonOperatorUtils.getUserDefinedAggregateFunctionProto(PythonAggregateFunctionInfo pythonFunctionInfo,
DataViewUtils.DataViewSpec[] dataViewSpecs) |
Constructor and Description |
---|
PythonStreamGroupAggregateOperator(Configuration config,
RowType inputType,
RowType outputType,
PythonAggregateFunctionInfo[] aggregateFunctions,
DataViewUtils.DataViewSpec[][] dataViewSpecs,
int[] grouping,
int indexOfCountStar,
boolean countStarInserted,
boolean generateUpdateBefore,
long minRetentionTime,
long maxRetentionTime) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.