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 |
CoBroadcastWithKeyedOperator<KS,IN1,IN2,OUT>
A
TwoInputStreamOperator for executing KeyedBroadcastProcessFunctions . |
class |
CoBroadcastWithNonKeyedOperator<IN1,IN2,OUT>
A
TwoInputStreamOperator for executing BroadcastProcessFunctions . |
class |
CoProcessOperator<IN1,IN2,OUT>
A
StreamOperator for executing
CoProcessFunctions . |
class |
CoStreamFlatMap<IN1,IN2,OUT>
StreamOperator for processing
CoFlatMapFunctions . |
class |
CoStreamMap<IN1,IN2,OUT>
StreamOperator for processing
CoMapFunctions . |
class |
IntervalJoinOperator<K,T1,T2,OUT>
An
operator to execute time-bounded stream inner joins. |
class |
KeyedCoProcessOperator<K,IN1,IN2,OUT>
A
StreamOperator for executing keyed
KeyedCoProcessFunction . |
class |
LegacyKeyedCoProcessOperator<K,IN1,IN2,OUT>
Deprecated.
Replaced by
KeyedCoProcessOperator which takes KeyedCoProcessFunction |
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. |
Constructor and Description |
---|
StreamTwoInputProcessor(Collection<InputGate> inputGates1,
Collection<InputGate> inputGates2,
TypeSerializer<IN1> inputSerializer1,
TypeSerializer<IN2> inputSerializer2,
TwoInputStreamTask<IN1,IN2,?> checkpointedTask,
CheckpointingMode checkpointMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
TaskIOMetricGroup metrics,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge,
String taskName,
OperatorChain<?,?> operatorChain) |
StreamTwoInputSelectableProcessor(Collection<InputGate> inputGates1,
Collection<InputGate> inputGates2,
TypeSerializer<IN1> inputSerializer1,
TypeSerializer<IN2> inputSerializer2,
StreamTask<?,?> streamTask,
CheckpointingMode checkpointingMode,
Object lock,
IOManager ioManager,
Configuration taskManagerConfig,
StreamStatusMaintainer streamStatusMaintainer,
TwoInputStreamOperator<IN1,IN2,?> streamOperator,
WatermarkGauge input1WatermarkGauge,
WatermarkGauge input2WatermarkGauge,
String taskName,
OperatorChain<?,?> operatorChain) |
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.
|
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 |
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
This operator works by keeping on the state collection of probe and build records to process
on next watermark.
|
Copyright © 2014–2020 The Apache Software Foundation. All rights reserved.