@Internal public abstract class AbstractExternalDataStreamPythonFunctionOperator<OUT> extends AbstractExternalPythonFunctionOperator<OUT> implements DataStreamPythonFunctionOperator<OUT>
pythonFunctionRunner
bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
chainingStrategy, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
AbstractExternalDataStreamPythonFunctionOperator(Configuration config,
DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<OUT> outputTypeInfo) |
Modifier and Type | Method and Description |
---|---|
void |
addSideOutputTags(Collection<OutputTag<?>> outputTags)
Add a collection of
OutputTag s to the operator. |
protected Map<String,FlinkFnApi.CoderInfoDescriptor> |
createSideOutputCoderDescriptors() |
Map<String,String> |
getInternalParameters() |
protected OutputTag<?> |
getOutputTagById(String id) |
TypeInformation<OUT> |
getProducedType()
Gets the data type (as a
TypeInformation ) produced by this function or input format. |
PythonEnv |
getPythonEnv()
Returns the
PythonEnv used to create PythonEnvironmentManager.. |
DataStreamPythonFunctionInfo |
getPythonFunctionInfo()
Returns the underlying
DataStreamPythonFunctionInfo . |
Collection<OutputTag<?>> |
getSideOutputTags()
Gets the
OutputTag s belongs to the operator. |
protected TypeSerializer<Row> |
getSideOutputTypeSerializerById(String id) |
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
|
void |
setNumPartitions(int numPartitions)
Sets the number of partitions.
|
close, createPythonEnvironmentManager, createPythonFunctionRunner, emitResult, emitResults, invokeFinishBundle
checkInvokeFinishBundleByCount, finish, getConfiguration, getFlinkMetricContainer, isBundleFinished, 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
copy
hasKeyContext
public AbstractExternalDataStreamPythonFunctionOperator(Configuration config, DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<OUT> outputTypeInfo)
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<OUT>
open
in class AbstractExternalPythonFunctionOperator<OUT>
Exception
- An exception in this method causes the operator to fail.public PythonEnv getPythonEnv()
AbstractExternalPythonFunctionOperator
PythonEnv
used to create PythonEnvironmentManager..getPythonEnv
in class AbstractExternalPythonFunctionOperator<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 void setNumPartitions(int numPartitions)
DataStreamPythonFunctionOperator
setNumPartitions
in interface DataStreamPythonFunctionOperator<OUT>
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>
protected Map<String,FlinkFnApi.CoderInfoDescriptor> createSideOutputCoderDescriptors()
protected TypeSerializer<Row> getSideOutputTypeSerializerById(String id)
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.