Class DelegateOperatorTransformation.DelegateOperator<OUT>
- 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.transformations.python.DelegateOperatorTransformation.DelegateOperator<OUT>
-
- All Implemented Interfaces:
Serializable
,CheckpointListener
,ResultTypeQueryable<OUT>
,KeyContext
,KeyContextHandler
,DataStreamPythonFunctionOperator<OUT>
,StreamOperator<OUT>
,StreamOperatorStateHandler.CheckpointedStreamOperator
,YieldingOperator<OUT>
- Enclosing interface:
- DelegateOperatorTransformation<OUT>
public static class DelegateOperatorTransformation.DelegateOperator<OUT> extends AbstractPythonFunctionOperator<OUT> implements DataStreamPythonFunctionOperator<OUT>
DelegateOperatorTransformation.DelegateOperator
holds configurations, e.g.OutputTag
s, which will be applied to the actual python operator at translation stage.- See Also:
- Serialized Form
-
-
Field Summary
-
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
lastRecordAttributes1, lastRecordAttributes2, latencyStats, LOG, metrics, output, processingTimeService, stateHandler, stateKeySelector1, stateKeySelector2, timeServiceManager
-
-
Constructor Summary
Constructors Constructor Description DelegateOperator()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
addSideOutputTags(Collection<OutputTag<?>> outputTags)
Add a collection ofOutputTag
s to the operator.<T> DataStreamPythonFunctionOperator<T>
copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
Make a copy of the DataStreamPythonFunctionOperator with the given pythonFunctionInfo and outputTypeInfo.protected PythonEnvironmentManager
createPythonEnvironmentManager()
Integer
getNumPartitions()
TypeInformation<OUT>
getProducedType()
Gets the data type (as aTypeInformation
) produced by this function or input format.DataStreamPythonFunctionInfo
getPythonFunctionInfo()
Returns the underlyingDataStreamPythonFunctionInfo
.Collection<OutputTag<?>>
getSideOutputTags()
Gets theOutputTag
s belongs to the operator.protected void
invokeFinishBundle()
void
setNumPartitions(int numPartitions)
Sets the number of partitions.-
Methods inherited from class org.apache.flink.streaming.api.operators.python.AbstractPythonFunctionOperator
checkInvokeFinishBundleByCount, close, finish, getConfiguration, getFlinkMetricContainer, isBundleFinished, open, prepareSnapshotPreBarrier, processWatermark, setCurrentKey
-
Methods inherited from class org.apache.flink.streaming.api.operators.AbstractStreamOperator
getContainingTask, getCurrentKey, 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, 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.streaming.api.operators.KeyContextHandler
hasKeyContext
-
Methods inherited from interface org.apache.flink.streaming.api.operators.StreamOperator
getOperatorAttributes
-
-
-
-
Method Detail
-
addSideOutputTags
public void addSideOutputTags(Collection<OutputTag<?>> outputTags)
Description copied from interface:DataStreamPythonFunctionOperator
Add a collection ofOutputTag
s to the operator.- Specified by:
addSideOutputTags
in interfaceDataStreamPythonFunctionOperator<OUT>
-
getSideOutputTags
public Collection<OutputTag<?>> getSideOutputTags()
Description copied from interface:DataStreamPythonFunctionOperator
Gets theOutputTag
s belongs to the operator.- Specified by:
getSideOutputTags
in interfaceDataStreamPythonFunctionOperator<OUT>
-
setNumPartitions
public void setNumPartitions(int numPartitions)
Description copied from interface:DataStreamPythonFunctionOperator
Sets the number of partitions. This is used for partitionCustom which takes the number of partitions to partition into as input.- Specified by:
setNumPartitions
in interfaceDataStreamPythonFunctionOperator<OUT>
-
getNumPartitions
@Nullable public Integer getNumPartitions()
-
getProducedType
public TypeInformation<OUT> getProducedType()
Description copied from interface:ResultTypeQueryable
Gets the data type (as aTypeInformation
) produced by this function or input format.- Specified by:
getProducedType
in interfaceResultTypeQueryable<OUT>
- Returns:
- The data type produced by this function or input format.
-
getPythonFunctionInfo
public DataStreamPythonFunctionInfo getPythonFunctionInfo()
Description copied from interface:DataStreamPythonFunctionOperator
Returns the underlyingDataStreamPythonFunctionInfo
.- Specified by:
getPythonFunctionInfo
in interfaceDataStreamPythonFunctionOperator<OUT>
-
copy
public <T> DataStreamPythonFunctionOperator<T> copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
Description copied from interface:DataStreamPythonFunctionOperator
Make a copy of the DataStreamPythonFunctionOperator with the given pythonFunctionInfo and outputTypeInfo. This is used for chaining optimization which may need to update the underlying pythonFunctionInfo and outputTypeInfo with the other fields not changed.- Specified by:
copy
in interfaceDataStreamPythonFunctionOperator<OUT>
-
invokeFinishBundle
protected void invokeFinishBundle() throws Exception
- Specified by:
invokeFinishBundle
in classAbstractPythonFunctionOperator<OUT>
- Throws:
Exception
-
createPythonEnvironmentManager
protected PythonEnvironmentManager createPythonEnvironmentManager()
- Specified by:
createPythonEnvironmentManager
in classAbstractPythonFunctionOperator<OUT>
-
-