@Internal public abstract class AbstractEmbeddedStatelessFunctionOperator extends AbstractEmbeddedPythonFunctionOperator<RowData> implements OneInputStreamOperator<RowData,RowData>, BoundedOneInput
Modifier and Type | Field and Description |
---|---|
protected RowType |
inputType
The input logical type.
|
protected GenericRowData |
reuseResultRowData
The GenericRowData reused holding the execution result of python udf.
|
protected StreamRecordRowDataWrappingCollector |
rowDataWrapper
The collector used to collect records.
|
protected int[] |
udfInputOffsets
The offsets of user-defined function inputs.
|
protected RowType |
udfInputType
The user-defined function input logical type.
|
protected RowType |
udfOutputType
The user-defined function output logical type.
|
protected Object[] |
userDefinedFunctionInputArgs |
protected PythonTypeUtils.DataConverter[] |
userDefinedFunctionInputConverters |
protected PythonTypeUtils.DataConverter[] |
userDefinedFunctionOutputConverters |
interpreter
bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
chainingStrategy, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
AbstractEmbeddedStatelessFunctionOperator(Configuration config,
RowType inputType,
RowType udfInputType,
RowType udfOutputType,
int[] udfInputOffsets) |
Modifier and Type | Method and Description |
---|---|
void |
open()
This method is called immediately before any elements are processed, it should contain the
operator's initialization logic, e.g.
|
close, createPythonEnvironmentManager, invokeFinishBundle, openPythonInterpreter
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
setKeyContextElement
close, finish, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
processElement, processLatencyMarker, processWatermark, processWatermarkStatus
endInput
hasKeyContext
protected final int[] udfInputOffsets
protected final RowType inputType
protected final RowType udfInputType
protected final RowType udfOutputType
protected transient GenericRowData reuseResultRowData
protected transient StreamRecordRowDataWrappingCollector rowDataWrapper
protected transient PythonTypeUtils.DataConverter[] userDefinedFunctionInputConverters
protected transient Object[] userDefinedFunctionInputArgs
protected transient PythonTypeUtils.DataConverter[] userDefinedFunctionOutputConverters
public AbstractEmbeddedStatelessFunctionOperator(Configuration config, RowType inputType, RowType udfInputType, RowType udfOutputType, int[] udfInputOffsets)
public void open() throws Exception
AbstractStreamOperator
The default implementation does nothing.
open
in interface StreamOperator<RowData>
open
in class AbstractEmbeddedPythonFunctionOperator<RowData>
Exception
- An exception in this method causes the operator to fail.Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.