@Internal public abstract class AbstractPythonStreamGroupAggregateOperator extends AbstractPythonStreamAggregateOperator implements Triggerable<RowData,VoidNamespace>, CleanupState
PythonStreamGroupAggregateOperator
and PythonStreamGroupTableAggregateOperator
.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 |
---|
AbstractPythonStreamGroupAggregateOperator(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 |
---|---|
RowType |
createUserDefinedFunctionInputType() |
RowType |
createUserDefinedFunctionOutputType() |
void |
emitResult(Tuple3<String,byte[],Integer> resultTuple)
Sends the execution result to the downstream operator.
|
protected FlinkFnApi.UserDefinedAggregateFunctions |
getUserDefinedFunctionsProto()
Gets the proto representation of the Python user-defined aggregate functions to be executed.
|
void |
onEventTime(InternalTimer<RowData,VoidNamespace> timer)
Invoked when an event-time timer fires.
|
void |
onProcessingTime(InternalTimer<RowData,VoidNamespace> timer)
Invoked when a processing-time timer fires.
|
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g. state initialization.
|
void |
processElementInternal(RowData value) |
createInputCoderInfoDescriptor, createOutputCoderInfoDescriptor, createPythonFunctionRunner, getCurrentKey, getFunctionUrn, 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
public AbstractPythonStreamGroupAggregateOperator(Configuration config, RowType inputType, RowType outputType, PythonAggregateFunctionInfo[] aggregateFunctions, DataViewSpec[][] dataViewSpecs, int[] grouping, int indexOfCountStar, boolean generateUpdateBefore, long minRetentionTime, long maxRetentionTime)
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<RowData>
open
in class AbstractPythonStreamAggregateOperator
Exception
- An exception in this method causes the operator to fail.public void onEventTime(InternalTimer<RowData,VoidNamespace> timer)
onEventTime
in interface Triggerable<RowData,VoidNamespace>
public void onProcessingTime(InternalTimer<RowData,VoidNamespace> timer) throws Exception
onProcessingTime
in interface Triggerable<RowData,VoidNamespace>
Exception
public void processElementInternal(RowData value) throws Exception
processElementInternal
in class AbstractPythonStreamAggregateOperator
Exception
public void emitResult(Tuple3<String,byte[],Integer> resultTuple) throws Exception
AbstractExternalPythonFunctionOperator
emitResult
in class AbstractExternalPythonFunctionOperator<RowData>
Exception
public RowType createUserDefinedFunctionInputType()
createUserDefinedFunctionInputType
in class AbstractPythonStreamAggregateOperator
public RowType createUserDefinedFunctionOutputType()
createUserDefinedFunctionOutputType
in class AbstractPythonStreamAggregateOperator
protected FlinkFnApi.UserDefinedAggregateFunctions getUserDefinedFunctionsProto()
AbstractPythonStreamAggregateOperator
getUserDefinedFunctionsProto
in class AbstractPythonStreamAggregateOperator
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.