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.bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
chainingStrategy, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
DelegateOperator() |
Modifier and Type | Method and Description |
---|---|
void |
addSideOutputTags(Collection<OutputTag<?>> outputTags)
Add a collection of
OutputTag 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 a
TypeInformation ) produced by this function or input format. |
DataStreamPythonFunctionInfo |
getPythonFunctionInfo()
Returns the underlying
DataStreamPythonFunctionInfo . |
Collection<OutputTag<?>> |
getSideOutputTags()
Gets the
OutputTag s belongs to the operator. |
protected void |
invokeFinishBundle() |
void |
setNumPartitions(int numPartitions)
Sets the number of partitions.
|
checkInvokeFinishBundleByCount, close, finish, getConfiguration, getFlinkMetricContainer, isBundleFinished, open, prepareSnapshotPreBarrier, processWatermark, setCurrentKey
getChainingStrategy, getContainingTask, getCurrentKey, getExecutionConfig, getInternalTimerService, getKeyedStateBackend, getKeyedStateStore, getMetricGroup, getOperatorConfig, getOperatorID, getOperatorName, getOperatorStateBackend, getOrCreateKeyedState, getPartitionedState, getPartitionedState, getProcessingTimeService, getRuntimeContext, getTimeServiceManager, getUserCodeClassloader, hasKeyContext1, hasKeyContext2, initializeState, initializeState, isUsingCustomRawKeyedState, notifyCheckpointAborted, notifyCheckpointComplete, processLatencyMarker, processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus, processWatermarkStatus1, processWatermarkStatus2, reportOrForwardLatencyMarker, setChainingStrategy, setKeyContextElement1, setKeyContextElement2, setProcessingTimeService, setup, snapshotState, snapshotState
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
hasKeyContext
public void addSideOutputTags(Collection<OutputTag<?>> outputTags)
DataStreamPythonFunctionOperator
OutputTag
s to the operator.addSideOutputTags
in interface DataStreamPythonFunctionOperator<OUT>
public Collection<OutputTag<?>> getSideOutputTags()
DataStreamPythonFunctionOperator
OutputTag
s belongs to the operator.getSideOutputTags
in interface DataStreamPythonFunctionOperator<OUT>
public void setNumPartitions(int numPartitions)
DataStreamPythonFunctionOperator
setNumPartitions
in interface DataStreamPythonFunctionOperator<OUT>
public TypeInformation<OUT> getProducedType()
ResultTypeQueryable
TypeInformation
) produced by this function or input format.getProducedType
in interface ResultTypeQueryable<OUT>
public DataStreamPythonFunctionInfo getPythonFunctionInfo()
DataStreamPythonFunctionOperator
DataStreamPythonFunctionInfo
.getPythonFunctionInfo
in interface DataStreamPythonFunctionOperator<OUT>
public <T> DataStreamPythonFunctionOperator<T> copy(DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<T> outputTypeInfo)
DataStreamPythonFunctionOperator
copy
in interface DataStreamPythonFunctionOperator<OUT>
protected void invokeFinishBundle() throws Exception
invokeFinishBundle
in class AbstractPythonFunctionOperator<OUT>
Exception
protected PythonEnvironmentManager createPythonEnvironmentManager()
createPythonEnvironmentManager
in class AbstractPythonFunctionOperator<OUT>
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.