Package | Description |
---|---|
org.apache.flink.streaming.api.datastream |
Modifier and Type | Method and Description |
---|---|
KeyedStream<T,org.apache.flink.api.java.tuple.Tuple> |
DataStream.keyBy(int... fields)
Deprecated.
|
<K> KeyedStream<T,K> |
DataStream.keyBy(org.apache.flink.api.java.functions.KeySelector<T,K> key)
It creates a new
KeyedStream 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 new
KeyedStream that uses the provided key with explicit type
information for partitioning its operator states. |
KeyedStream<T,org.apache.flink.api.java.tuple.Tuple> |
DataStream.keyBy(String... fields)
Deprecated.
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector)
|
static <T,K> KeyedStream<T,K> |
DataStreamUtils.reinterpretAsKeyedStream(DataStream<T> stream,
org.apache.flink.api.java.functions.KeySelector<T,K> keySelector,
org.apache.flink.api.common.typeinfo.TypeInformation<K> typeInfo)
|
Modifier and Type | Method and Description |
---|---|
<T1> KeyedStream.IntervalJoin<T,T1,KEY> |
KeyedStream.intervalJoin(KeyedStream<T1,KEY> otherStream)
Join elements of this
KeyedStream with elements of another KeyedStream over a
time interval that can be specified with KeyedStream.IntervalJoin.between(Time, Time) . |
Constructor and Description |
---|
IntervalJoined(KeyedStream<IN1,KEY> left,
KeyedStream<IN2,KEY> right,
long lowerBound,
long upperBound,
boolean lowerBoundInclusive,
boolean upperBoundInclusive) |
IntervalJoined(KeyedStream<IN1,KEY> left,
KeyedStream<IN2,KEY> right,
long lowerBound,
long upperBound,
boolean lowerBoundInclusive,
boolean upperBoundInclusive) |
WindowedStream(KeyedStream<T,K> input,
WindowAssigner<? super T,W> windowAssigner) |
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.