Class AbstractPythonStreamGroupAggregateOperator
- java.lang.Object
-
- org.apache.flink.streaming.api.operators.AbstractStreamOperator<OUT>
-
- org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator<OUT>
-
- org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator<OUT>
-
- org.apache.flink.table.runtime.operators.python.AbstractOneInputPythonFunctionOperator<RowData,RowData>
-
- org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
-
- org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamGroupAggregateOperator
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,BoundedOneInput
,Input<RowData>
,KeyContext
,KeyContextHandler
,OneInputStreamOperator<RowData,RowData>
,StreamOperator<RowData>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,Triggerable<RowData,VoidNamespace>
,YieldingOperator<RowData>
,CleanupState
- Direct Known Subclasses:
PythonStreamGroupAggregateOperator
,PythonStreamGroupTableAggregateOperator
@Internal public abstract class AbstractPythonStreamGroupAggregateOperator extends AbstractPythonStreamAggregateOperator implements Triggerable<RowData,VoidNamespace>, CleanupState
Base class forPythonStreamGroupAggregateOperator
andPythonStreamGroupTableAggregateOperator
.- See Also:
- Serialized Form
-
-
Field Summary
-
Fields inherited from class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
bais, baisWrapper, baos, baosWrapper, inputType, outputType, rowDataWrapper, userDefinedFunctionInputType, userDefinedFunctionOutputType
-
Fields inherited from class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
pythonFunctionRunner
-
Fields inherited from class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
-
Fields inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
combinedWatermark, lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description AbstractPythonStreamGroupAggregateOperator(Configuration config, RowType inputType, RowType outputType, PythonAggregateFunctionInfo[] aggregateFunctions, DataViewSpec[][] dataViewSpecs, int[] grouping, int indexOfCountStar, boolean generateUpdateBefore, long minRetentionTime, long maxRetentionTime)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method 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)
-
Methods inherited from class org.apache.flink.table.runtime.operators.python.aggregate.AbstractPythonStreamAggregateOperator
createInputCoderInfoDescriptor, createOutputCoderInfoDescriptor, createPythonFunctionRunner, getCurrentKey, getFunctionUrn, getKeyType, getPythonEnv, processElement, setCurrentKey
-
Methods inherited from class org.apache.flink.table.runtime.operators.python.AbstractOneInputPythonFunctionOperator
endInput
-
Methods inherited from class org.apache.flink.streaming.api.operators.python.process.AbstractExternalPythonFunctionOperator
close, createPythonEnvironmentManager, emitResults, invokeFinishBundle
-
Methods inherited from class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
checkInvokeFinishBundleByCount, finish, getConfiguration, getFlinkMetricContainer, isBundleFinished, prepareSnapshotPreBarrier, processWatermark
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
getContainingTask, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getStateKeySelector1, getStateKeySelector2, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isAsyncStateProcessingEnabled, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processRecordAttributes, processRecordAttributes1, processRecordAttributes2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setKeyContextElement1, setKeyContextElement2, setMailboxExecutor, setProcessingTimeService, setup, snapshotState, snapshotState, useSplittableTimers
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.flink.api.common.state.CheckpointListener
notifyCheckpointAborted, notifyCheckpointComplete
-
Methods inherited from interface org.apache.flink.table.runtime.functions.CleanupState
registerProcessingCleanupTimer
-
Methods inherited from interface org.apache.flink.streaming.api.operators.Input
processLatencyMarker, processRecordAttributes, processWatermark, processWatermarkStatus
-
Methods inherited from interface org.apache.flink.streaming.api.operators.KeyContextHandler
hasKeyContext
-
Methods inherited from interface org.apache.flink.streaming.api.operators.OneInputStreamOperator
setKeyContextElement
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
close, finish, getMetricGroup, getOperatorAttributes, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
-
-
-
-
Constructor Detail
-
AbstractPythonStreamGroupAggregateOperator
public AbstractPythonStreamGroupAggregateOperator(Configuration config, RowType inputType, RowType outputType, PythonAggregateFunctionInfo[] aggregateFunctions, DataViewSpec[][] dataViewSpecs, int[] grouping, int indexOfCountStar, boolean generateUpdateBefore, long minRetentionTime, long maxRetentionTime)
-
-
Method Detail
-
open
public void open() throws Exception
Description copied from class:AbstractStreamOperator
This method is called immediately before any elements are processed, it should contain the operator's initialization logic, e.g. state initialization.The default implementation does nothing.
- Specified by:
open
in interfaceStreamOperator<RowData>
- Overrides:
open
in classAbstractPythonStreamAggregateOperator
- Throws:
Exception
- An exception in this method causes the operator to fail.
-
onEventTime
public void onEventTime(InternalTimer<RowData,VoidNamespace> timer)
Invoked when an event-time timer fires.- Specified by:
onEventTime
in interfaceTriggerable<RowData,VoidNamespace>
-
onProcessingTime
public void onProcessingTime(InternalTimer<RowData,VoidNamespace> timer) throws Exception
Invoked when a processing-time timer fires.- Specified by:
onProcessingTime
in interfaceTriggerable<RowData,VoidNamespace>
- Throws:
Exception
-
processElementInternal
public void processElementInternal(RowData value) throws Exception
- Specified by:
processElementInternal
in classAbstractPythonStreamAggregateOperator
- Throws:
Exception
-
emitResult
public void emitResult(Tuple3<String,byte[],Integer> resultTuple) throws Exception
Description copied from class:AbstractExternalPythonFunctionOperator
Sends the execution result to the downstream operator.- Specified by:
emitResult
in classAbstractExternalPythonFunctionOperator<RowData>
- Throws:
Exception
-
createUserDefinedFunctionInputType
public RowType createUserDefinedFunctionInputType()
- Specified by:
createUserDefinedFunctionInputType
in classAbstractPythonStreamAggregateOperator
-
createUserDefinedFunctionOutputType
public RowType createUserDefinedFunctionOutputType()
- Specified by:
createUserDefinedFunctionOutputType
in classAbstractPythonStreamAggregateOperator
-
getUserDefinedFunctionsProto
protected FlinkFnApi.UserDefinedAggregateFunctions getUserDefinedFunctionsProto()
Description copied from class:AbstractPythonStreamAggregateOperator
Gets the proto representation of the Python user-defined aggregate functions to be executed.- Overrides:
getUserDefinedFunctionsProto
in classAbstractPythonStreamAggregateOperator
-
-