OUT
- The output type of the CoBroadcastProcess function@Internal public class EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT> extends EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT> implements BoundedMultiInput
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator
is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, EmbeddedPythonKeyedCoProcessOperator
is used under STREAMING mode. This operator forces to run out data from broadcast side first, and
then process data from regular side.timestamp
collector, hasSideOutput, outputTypeInfo, sideOutputContext
interpreter
bundleFinishedCallback, config, elementCount, lastFinishBundleTime, maxBundleSize, systemEnvEnabled
chainingStrategy, latencyStats, LOG, metrics, output, processingTimeService
Constructor and Description |
---|
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator(Configuration config,
DataStreamPythonFunctionInfo pythonFunctionInfo,
TypeInformation<IN1> inputTypeInfo1,
TypeInformation<IN2> inputTypeInfo2,
TypeInformation<OUT> outputTypeInfo) |
Modifier and Type | Method and Description |
---|---|
void |
endInput(int inputId)
It is notified that no more data will arrive from the input identified by the
inputId . |
void |
processElement1(StreamRecord<IN1> element)
Processes one element that arrived on the first input of this two-input operator.
|
copy, createUserDefinedFunctionsProto, getFunctionContext, getTimerContext, onEventTime, onProcessingTime, open
close, openPythonInterpreter, processElement2
addSideOutputTags, getJobParameters, getProducedType, getPythonFunctionInfo, getSideOutputTags, setNumPartitions
createPythonEnvironmentManager, 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
processLatencyMarker1, processLatencyMarker2, processWatermark1, processWatermark2, processWatermarkStatus1, processWatermarkStatus2
finish, getMetricGroup, getOperatorID, initializeState, prepareSnapshotPreBarrier, setKeyContextElement1, setKeyContextElement2, snapshotState
notifyCheckpointAborted, notifyCheckpointComplete
getCurrentKey, setCurrentKey
hasKeyContext
public EmbeddedPythonBatchKeyedCoBroadcastProcessOperator(Configuration config, DataStreamPythonFunctionInfo pythonFunctionInfo, TypeInformation<IN1> inputTypeInfo1, TypeInformation<IN2> inputTypeInfo2, TypeInformation<OUT> outputTypeInfo)
public void endInput(int inputId) throws Exception
BoundedMultiInput
inputId
. The inputId
is numbered starting from 1, and `1` indicates the first input.
WARNING: It is not safe to use this method to commit any transactions or other side
effects! You can use this method to e.g. flush data buffered for the given input or implement
an ordered reading from multiple inputs via InputSelectable
.
endInput
in interface BoundedMultiInput
endInput
in class AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT>
Exception
public void processElement1(StreamRecord<IN1> element) throws Exception
TwoInputStreamOperator
processElement1
in interface TwoInputStreamOperator<IN1,IN2,OUT>
processElement1
in class AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT>
Exception
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.