Uses of Class
org.apache.storm.streams.Pair
Package
Description
-
Uses of Pair in org.apache.storm.sql.runtime.streams.functions
-
Uses of Pair in org.apache.storm.streams
Modifier and TypeMethodDescriptionstatic <T1,
T2> Pair<T1, T2> Pair.of
(T1 first, T2 second) Constructs a new pair of values.Modifier and TypeMethodDescriptionPairStream.coGroupByKey
(PairStream<K, V1> otherStream) Groups the values of this stream with the values having the same key from the other stream.<V1> PairStream<K,
Pair<V, V1>> PairStream.fullOuterJoin
(PairStream<K, V1> otherStream) Does a full outer join of the values of this stream with the values having the same key from the other stream.<V1> PairStream<K,
Pair<V, V1>> PairStream.join
(PairStream<K, V1> otherStream) Join the values of this stream with the values having the same key from the other stream.<V1> PairStream<K,
Pair<V, V1>> PairStream.leftOuterJoin
(PairStream<K, V1> otherStream) Does a left outer join of the values of this stream with the values having the same key from the other stream.<V1> PairStream<K,
Pair<V, V1>> PairStream.rightOuterJoin
(PairStream<K, V1> otherStream) Does a right outer join of the values of this stream with the values having the same key from the other stream.Modifier and TypeMethodDescriptionPairStream<K,
V> Returns a stream consisting of the elements of this stream that matches the given filter.PairStream<K,
V> Returns a stream consisting of the elements of this stream, additionally performing the provided action on each element as they are consumed from the resulting stream. -
Uses of Pair in org.apache.storm.streams.operations
-
Uses of Pair in org.apache.storm.streams.operations.mappers
-
Uses of Pair in org.apache.storm.streams.processors
Modifier and TypeMethodDescriptionvoid
void
protected void
void
void
void
void
protected void
-
Uses of Pair in org.apache.storm.windowing
Modifier and TypeMethodDescriptionvoid
WatermarkCountEvictionPolicy.restoreState
(Pair<Long, Long> state)