Uses of Package
org.apache.flink.streaming.api.functions.co
-
Classes in org.apache.flink.streaming.api.functions.co used by org.apache.flink.streaming.api.datastream Class Description BroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.CoFlatMapFunction A CoFlatMapFunction implements a flat-map transformation over two connected streams.CoMapFunction A CoFlatMapFunction implements a map() transformation over two connected streams.CoProcessFunction A function that processes elements of two streams and produces a single output one.KeyedBroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.KeyedCoProcessFunction A function that processes elements of two keyed streams and produces a single output one.ProcessJoinFunction A function that processes two joined elements and produces a single output one. -
Classes in org.apache.flink.streaming.api.functions.co used by org.apache.flink.streaming.api.functions.co Class Description BaseBroadcastProcessFunction The base class containing the functionality available to all broadcast process function.BaseBroadcastProcessFunction.Context A basecontextavailable to the broadcasted stream side of aBroadcastConnectedStream.BaseBroadcastProcessFunction.ReadOnlyContext Acontextavailable to the non-broadcasted stream side of aBroadcastConnectedStream.BroadcastProcessFunction.Context Acontextavailable to the broadcast side of aBroadcastConnectedStream.BroadcastProcessFunction.ReadOnlyContext Acontextavailable to the non-keyed side of aBroadcastConnectedStream(if any).CoProcessFunction.Context Information available in an invocation of#processElement1(Object, Context, Collector)/#processElement2(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector).CoProcessFunction.OnTimerContext Information available in an invocation of#onTimer(long, OnTimerContext, Collector).KeyedBroadcastProcessFunction.Context Acontextavailable to the broadcast side of aBroadcastConnectedStream.KeyedBroadcastProcessFunction.OnTimerContext Information available in an invocation of#onTimer(long, OnTimerContext, Collector).KeyedBroadcastProcessFunction.ReadOnlyContext Acontextavailable to the keyed stream side of aBroadcastConnectedStream(if any).KeyedCoProcessFunction.Context Information available in an invocation of#processElement1(Object, Context, Collector)/#processElement2(Object, Context, Collector)or#onTimer(long, OnTimerContext, Collector).KeyedCoProcessFunction.OnTimerContext Information available in an invocation of#onTimer(long, OnTimerContext, Collector).ProcessJoinFunction.Context The context that is available during an invocation of#processElement(Object, Object, Context, Collector). -
Classes in org.apache.flink.streaming.api.functions.co used by org.apache.flink.streaming.api.operators.co Class Description BroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.CoFlatMapFunction A CoFlatMapFunction implements a flat-map transformation over two connected streams.CoMapFunction A CoFlatMapFunction implements a map() transformation over two connected streams.CoProcessFunction A function that processes elements of two streams and produces a single output one.KeyedBroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.KeyedCoProcessFunction A function that processes elements of two keyed streams and produces a single output one.ProcessJoinFunction A function that processes two joined elements and produces a single output one. -
Classes in org.apache.flink.streaming.api.functions.co used by org.apache.flink.streaming.api.transformations Class Description BroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.KeyedBroadcastProcessFunction A function to be applied to aBroadcastConnectedStreamthat connectsBroadcastStream, i.e.