@Internal public class PythonStreamGroupTableAggregateOperator extends AbstractPythonStreamGroupAggregateOperator
Modifier and Type | Field and Description |
---|---|
protected static String |
STREAM_GROUP_TABLE_AGGREGATE_URN |
bais, baisWrapper, baos, baosWrapper, inputType, outputType, rowDataWrapper, userDefinedFunctionInputType, userDefinedFunctionOutputType
pythonFunctionRunner
bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
chainingStrategy, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
Constructor and Description |
---|
PythonStreamGroupTableAggregateOperator(Configuration config,
RowType inputType,
RowType outputType,
PythonAggregateFunctionInfo[] aggregateFunctions,
DataViewSpec[][] dataViewSpecs,
int[] grouping,
int indexOfCountStar,
boolean generateUpdateBefore,
long minRetentionTime,
long maxRetentionTime) |
Modifier and Type | Method and Description |
---|---|
String |
getFunctionUrn() |
FlinkFnApi.UserDefinedAggregateFunctions |
getUserDefinedFunctionsProto()
Gets the proto representation of the Python user-defined table aggregate function to be
executed.
|
createUserDefinedFunctionInputType, createUserDefinedFunctionOutputType, emitResult, onEventTime, onProcessingTime, open, processElementInternal
createInputCoderInfoDescriptor, createOutputCoderInfoDescriptor, createPythonFunctionRunner, getCurrentKey, getKeyType, getPythonEnv, processElement, setCurrentKey
endInput
close, createPythonEnvironmentManager, emitResults, invokeFinishBundle
checkInvokeFinishBundleByCount, finish, getConfiguration, getFlinkMetricContainer, isBundleFinished, prepareSnapshotPreBarrier, processWatermark
getChainingStrategy, getContainingTask, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimers
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
registerProcessingCleanupTimer
setKeyContextElement
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
processLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatus
hasKeyContext
@VisibleForTesting protected static final String STREAM_GROUP_TABLE_AGGREGATE_URN
public PythonStreamGroupTableAggregateOperator(Configuration config, RowType inputType, RowType outputType, PythonAggregateFunctionInfo[] aggregateFunctions, DataViewSpec[][] dataViewSpecs, int[] grouping, int indexOfCountStar, boolean generateUpdateBefore, long minRetentionTime, long maxRetentionTime)
public FlinkFnApi.UserDefinedAggregateFunctions getUserDefinedFunctionsProto()
getUserDefinedFunctionsProto
in class AbstractPythonStreamGroupAggregateOperator
public String getFunctionUrn()
getFunctionUrn
in class AbstractPythonStreamAggregateOperator
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.