Modifier and Type | Class and Description |
---|---|
class |
KeyedTwoInputBroadcastProcessOperator<KEY,IN1,IN2,OUT>
Operator for
TwoInputBroadcastStreamProcessFunction in KeyedPartitionStream . |
class |
KeyedTwoInputNonBroadcastProcessOperator<KEY,IN1,IN2,OUT>
Operator for
TwoInputNonBroadcastStreamProcessFunction in KeyedPartitionStream . |
class |
TwoInputBroadcastProcessOperator<IN1,IN2,OUT>
Operator for
TwoInputBroadcastStreamProcessFunction . |
class |
TwoInputNonBroadcastProcessOperator<IN1,IN2,OUT>
Operator for
TwoInputNonBroadcastStreamProcessFunction . |
Modifier and Type | Method and Description |
---|---|
static <IN1,IN2,OUT> |
StreamUtils.getTwoInputTransformation(String operatorName,
AbstractDataStream<IN1> inputStream1,
AbstractDataStream<IN2> inputStream2,
TypeInformation<OUT> outTypeInformation,
TwoInputStreamOperator<IN1,IN2,OUT> operator)
Construct and return a
TwoInputTransformation from two input streams. |
Modifier and Type | Method and Description |
---|---|
<R> SingleOutputStreamOperator<R> |
ConnectedStreams.transform(String functionName,
TypeInformation<R> outTypeInfo,
TwoInputStreamOperator<IN1,IN2,R> operator) |
Modifier and Type | Class and Description |
---|---|
class |
AbstractTwoInputEmbeddedPythonFunctionOperator<IN1,IN2,OUT>
AbstractTwoInputEmbeddedPythonFunctionOperator is responsible for run Python DataStream
operators with two input user defined python function in Embedded Python environment. |
class |
EmbeddedPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
The
EmbeddedPythonBatchCoBroadcastProcessOperator is responsible for executing the Python
CoBroadcastProcess Function under BATCH mode, EmbeddedPythonCoProcessOperator is used
under STREAMING mode. |
class |
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator<K,IN1,IN2,OUT>
The
EmbeddedPythonBatchKeyedCoBroadcastProcessOperator is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, EmbeddedPythonKeyedCoProcessOperator
is used under STREAMING mode. |
class |
EmbeddedPythonCoProcessOperator<IN1,IN2,OUT>
EmbeddedPythonCoProcessOperator is responsible for executing Python CoProcessFunction in
embedded Python environment. |
class |
EmbeddedPythonKeyedCoProcessOperator<K,IN1,IN2,OUT>
EmbeddedPythonKeyedCoProcessOperator is responsible for executing user defined python
KeyedCoProcessFunction in embedded Python environment. |
Modifier and Type | Class and Description |
---|---|
class |
AbstractExternalTwoInputPythonFunctionOperator<IN1,IN2,OUT>
AbstractExternalTwoInputPythonFunctionOperator is responsible for launching beam runner
which will start a python harness to execute two-input user defined python function. |
class |
ExternalPythonBatchCoBroadcastProcessOperator<IN1,IN2,OUT>
The
ExternalPythonBatchCoBroadcastProcessOperator is responsible for executing the Python
CoBroadcastProcess Function under BATCH mode, ExternalPythonCoProcessOperator is used
under STREAMING mode. |
class |
ExternalPythonBatchKeyedCoBroadcastProcessOperator<OUT>
The
ExternalPythonBatchKeyedCoBroadcastProcessOperator is responsible for executing the
Python CoBroadcastProcess function under BATCH mode, ExternalPythonKeyedCoProcessOperator
is used under STREAMING mode. |
class |
ExternalPythonCoProcessOperator<IN1,IN2,OUT>
The
ExternalPythonCoProcessOperator is responsible for executing the Python CoProcess
Function. |
class |
ExternalPythonKeyedCoProcessOperator<OUT>
ExternalPythonKeyedCoProcessOperator is responsible for launching beam runner which will
start a python harness to execute user defined python CoProcess function. |
Modifier and Type | Method and Description |
---|---|
TwoInputStreamOperator<IN1,IN2,OUT> |
TwoInputTransformation.getOperator() |
Constructor and Description |
---|
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism)
Creates a new
TwoInputTransformation from the given inputs and operator. |
TwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
TwoInputStreamOperator<IN1,IN2,OUT> operator,
TypeInformation<OUT> outputType,
int parallelism,
boolean parallelismConfigured) |
Modifier and Type | Method and Description |
---|---|
static <IN1,IN2> StreamMultipleInputProcessor |
StreamTwoInputProcessorFactory.create(TaskInvokable ownerTask,
CheckpointedInputGate[] checkpointedInputGates,
IOManager ioManager,
MemoryManager memoryManager,
TaskIOMetricGroup taskIOMetricGroup,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge,
OperatorChain<?,?> operatorChain,
StreamConfig streamConfig,
Configuration taskManagerConfig,
Configuration jobConfig,
ExecutionConfig executionConfig,
ClassLoader userClassloader,
Counter numRecordsIn,
InflightDataRescalingDescriptor inflightDataRescalingDescriptor,
Function<Integer,StreamPartitioner<?>> gatePartitioners,
TaskInfo taskInfo,
StreamTask.CanEmitBatchOfRecordsChecker canEmitBatchOfRecords) |
static <T> ThrowingConsumer<StreamRecord<T>,Exception> |
RecordProcessorUtils.getRecordProcessor1(TwoInputStreamOperator<T,?,?> operator)
Get record processor for the first input of
TwoInputStreamOperator , which will omit
call of StreamOperator.setKeyContextElement1(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>) if it doesn't have key context. |
static <T> ThrowingConsumer<StreamRecord<T>,Exception> |
RecordProcessorUtils.getRecordProcessor2(TwoInputStreamOperator<?,T,?> operator)
Get record processor for the second input of
TwoInputStreamOperator , which will omit
call of StreamOperator.setKeyContextElement2(org.apache.flink.streaming.runtime.streamrecord.StreamRecord<?>) if it doesn't have key context. |
Modifier and Type | Method and Description |
---|---|
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
String name,
String desc,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
boolean parallelismConfigured)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes)
Create a
TwoInputTransformation with memoryBytes. |
static <IN1,IN2,O> |
ExecNodeUtil.createTwoInputTransformation(Transformation<IN1> input1,
Transformation<IN2> input2,
TransformationMetadata transformationMeta,
TwoInputStreamOperator<IN1,IN2,O> operator,
TypeInformation<O> outputType,
int parallelism,
long memoryBytes,
boolean parallelismConfigured) |
Modifier and Type | Class and Description |
---|---|
class |
HashJoinOperator
Hash join base operator.
|
class |
KeyedCoProcessOperatorWithWatermarkDelay<K,IN1,IN2,OUT>
A
KeyedCoProcessOperator that supports holding back watermarks with a static delay. |
class |
SortMergeJoinOperator
An implementation that realizes the joining through a sort-merge join strategy. 1.In most cases,
its performance is weaker than HashJoin. 2.It is more stable than HashJoin, and most of the data
can be sorted stably. 3.SortMergeJoin should be the best choice if sort can be omitted in the
case of multi-level join cascade with the same key.
|
Modifier and Type | Class and Description |
---|---|
class |
AbstractStreamingJoinOperator
Abstract implementation for streaming unbounded Join operator which defines some member fields
can be shared between different implementations.
|
class |
MiniBatchStreamingJoinOperator
Streaming unbounded Join base operator which support mini-batch join.
|
class |
StreamingJoinOperator
Streaming unbounded Join operator which supports INNER/LEFT/RIGHT/FULL JOIN.
|
class |
StreamingSemiAntiJoinOperator
Streaming unbounded Join operator which supports SEMI/ANTI JOIN.
|
Modifier and Type | Class and Description |
---|---|
class |
BaseTwoInputStreamOperatorWithStateRetention
An abstract
TwoInputStreamOperator that allows its subclasses to clean up their state
based on a TTL. |
class |
TemporalProcessTimeJoinOperator
The operator to temporal join a stream on processing time.
|
class |
TemporalRowTimeJoinOperator
The operator for temporal join (FOR SYSTEM_TIME AS OF o.rowtime) on row time, it has no
limitation about message types of the left input and right input, this means the operator deals
changelog well.
|
Modifier and Type | Class and Description |
---|---|
class |
WindowJoinOperator
Streaming window join operator.
|
Constructor and Description |
---|
FirstInputOfTwoInput(TwoInputStreamOperator<RowData,RowData,RowData> operator) |
SecondInputOfTwoInput(TwoInputStreamOperator<RowData,RowData,RowData> operator) |
Constructor and Description |
---|
CopyingFirstInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData,RowData,RowData> operator,
TypeSerializer<RowData> serializer) |
CopyingSecondInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData,RowData,RowData> operator,
TypeSerializer<RowData> serializer) |
FirstInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData,RowData,RowData> operator) |
SecondInputOfTwoInputStreamOperatorOutput(TwoInputStreamOperator<RowData,RowData,RowData> operator) |
Copyright © 2014–2024 The Apache Software Foundation. All rights reserved.