Class BroadcastStream<T>
- java.lang.Object
-
- org.apache.flink.streaming.api.datastream.BroadcastStream<T>
-
- Type Parameters:
T
- The type of input/output elements.
@PublicEvolving public class BroadcastStream<T> extends Object
ABroadcastStream
is a stream withbroadcast state(s)
. This can be created by any stream using theDataStream.broadcast(MapStateDescriptor[])
method and implicitly creates states where the user can store elements of the createdBroadcastStream
. (seeBroadcastConnectedStream
).Note that no further operation can be applied to these streams. The only available option is to connect them with a keyed or non-keyed stream, using the
DataStream.connect(BroadcastStream)
and theDataStream.connect(BroadcastStream)
respectively. Applying these methods will result it aBroadcastConnectedStream
for further processing.
-
-
Constructor Summary
Constructors Modifier Constructor Description protected
BroadcastStream(StreamExecutionEnvironment env, DataStream<T> input, MapStateDescriptor<?,?>... broadcastStateDescriptors)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <F> F
clean(F f)
List<MapStateDescriptor<?,?>>
getBroadcastStateDescriptors()
StreamExecutionEnvironment
getEnvironment()
Transformation<T>
getTransformation()
TypeInformation<T>
getType()
-
-
-
Constructor Detail
-
BroadcastStream
protected BroadcastStream(StreamExecutionEnvironment env, DataStream<T> input, MapStateDescriptor<?,?>... broadcastStateDescriptors)
-
-
Method Detail
-
getType
public TypeInformation<T> getType()
-
clean
public <F> F clean(F f)
-
getTransformation
public Transformation<T> getTransformation()
-
getBroadcastStateDescriptors
public List<MapStateDescriptor<?,?>> getBroadcastStateDescriptors()
-
getEnvironment
public StreamExecutionEnvironment getEnvironment()
-
-