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
ABroadcastStreamis 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 aBroadcastConnectedStreamfor further processing.
-
-
Constructor Summary
Constructors Modifier Constructor Description protectedBroadcastStream(StreamExecutionEnvironment env, DataStream<T> input, org.apache.flink.api.common.state.MapStateDescriptor<?,?>... broadcastStateDescriptors)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description <F> Fclean(F f)List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>>getBroadcastStateDescriptors()StreamExecutionEnvironmentgetEnvironment()org.apache.flink.api.dag.Transformation<T>getTransformation()org.apache.flink.api.common.typeinfo.TypeInformation<T>getType()
-
-
-
Constructor Detail
-
BroadcastStream
protected BroadcastStream(StreamExecutionEnvironment env, DataStream<T> input, org.apache.flink.api.common.state.MapStateDescriptor<?,?>... broadcastStateDescriptors)
-
-
Method Detail
-
getType
public org.apache.flink.api.common.typeinfo.TypeInformation<T> getType()
-
clean
public <F> F clean(F f)
-
getTransformation
public org.apache.flink.api.dag.Transformation<T> getTransformation()
-
getBroadcastStateDescriptors
public List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>> getBroadcastStateDescriptors()
-
getEnvironment
public StreamExecutionEnvironment getEnvironment()
-
-