Package | Description |
---|---|
org.apache.flink.streaming.api.datastream |
Modifier and Type | Method and Description |
---|---|
BroadcastStream<T> |
DataStream.broadcast(MapStateDescriptor<?,?>... broadcastStateDescriptors)
Sets the partitioning of the
DataStream so that the output elements are broadcasted
to every parallel instance of the next operation. |
BroadcastStream<IN2> |
BroadcastConnectedStream.getSecondInput()
Returns the
BroadcastStream . |
Modifier and Type | Method and Description |
---|---|
<R> BroadcastConnectedStream<T,R> |
DataStream.connect(BroadcastStream<R> broadcastStream)
Creates a new
BroadcastConnectedStream by connecting the current DataStream
or KeyedStream with a BroadcastStream . |
Constructor and Description |
---|
BroadcastConnectedStream(StreamExecutionEnvironment env,
DataStream<IN1> input1,
BroadcastStream<IN2> input2,
List<MapStateDescriptor<?,?>> broadcastStateDescriptors) |
Copyright © 2014–2021 The Apache Software Foundation. All rights reserved.