Uses of Class
org.apache.flink.streaming.api.datastream.BroadcastStream
-
Packages that use BroadcastStream Package Description org.apache.flink.streaming.api.datastream -
-
Uses of BroadcastStream in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream that return BroadcastStream Modifier and Type Method Description BroadcastStream<T>DataStream. broadcast(org.apache.flink.api.common.state.MapStateDescriptor<?,?>... broadcastStateDescriptors)Sets the partitioning of theDataStreamso that the output elements are broadcasted to every parallel instance of the next operation.BroadcastStream<IN2>BroadcastConnectedStream. getSecondInput()Returns theBroadcastStream.Methods in org.apache.flink.streaming.api.datastream with parameters of type BroadcastStream Modifier and Type Method Description <R> BroadcastConnectedStream<T,R>DataStream. connect(BroadcastStream<R> broadcastStream)Creates a newBroadcastConnectedStreamby connecting the currentDataStreamorKeyedStreamwith aBroadcastStream.Constructors in org.apache.flink.streaming.api.datastream with parameters of type BroadcastStream Constructor Description BroadcastConnectedStream(StreamExecutionEnvironment env, DataStream<IN1> input1, BroadcastStream<IN2> input2, List<org.apache.flink.api.common.state.MapStateDescriptor<?,?>> broadcastStateDescriptors)
-