Uses of Class
org.apache.flink.streaming.api.datastream.KeyedStream
-
Packages that use KeyedStream Package Description org.apache.flink.streaming.api.datastream -
-
Uses of KeyedStream in org.apache.flink.streaming.api.datastream
Methods in org.apache.flink.streaming.api.datastream that return KeyedStream Modifier and Type Method Description KeyedStream<T,KEY>
KeyedStream. enableAsyncState()
Enable the async state processing for following keyed processing function.protected KeyedStream<T,org.apache.flink.api.java.tuple.Tuple>
DataStream. keyBy(org.apache.flink.api.common.operators.Keys<T> keys)
<K> KeyedStream<T,K>
DataStream. keyBy(org.apache.flink.api.java.functions.KeySelector<T,K> key)
It creates a newKeyedStream
that uses the provided key for partitioning its operator states.<K> KeyedStream<T,K>
DataStream. keyBy(org.apache.flink.api.java.functions.KeySelector<T,K> key, org.apache.flink.api.common.typeinfo.TypeInformation<K> keyType)
It creates a newKeyedStream
that uses the provided key with explicit type information for partitioning its operator states.Methods in org.apache.flink.streaming.api.datastream with parameters of type KeyedStream Modifier and Type Method Description <T1> KeyedStream.IntervalJoin<T,T1,KEY>
KeyedStream. intervalJoin(KeyedStream<T1,KEY> otherStream)
Join elements of thisKeyedStream
with elements of anotherKeyedStream
over a time interval that can be specified withKeyedStream.IntervalJoin.between(Duration, Duration)
.Constructors in org.apache.flink.streaming.api.datastream with parameters of type KeyedStream Constructor Description IntervalJoined(KeyedStream<IN1,KEY> left, KeyedStream<IN2,KEY> right, long lowerBound, long upperBound, boolean lowerBoundInclusive, boolean upperBoundInclusive)
KeyedPartitionWindowedStream(StreamExecutionEnvironment environment, KeyedStream<T,KEY> input)
WindowedStream(KeyedStream<T,K> input, WindowAssigner<? super T,W> windowAssigner)
-