Uses of Class
org.apache.storm.streams.Pair
-
-
Uses of Pair in org.apache.storm.sql.runtime.streams.functions
Methods in org.apache.storm.sql.runtime.streams.functions that return Pair Modifier and Type Method Description Pair<Object,Values>
StreamInsertMapToPairFunction. apply(Values input)
-
Uses of Pair in org.apache.storm.streams
Methods in org.apache.storm.streams that return Pair Modifier and Type Method Description static <T1,T2>
Pair<T1,T2>Pair. of(T1 first, T2 second)
Constructs a new pair of values.Methods in org.apache.storm.streams that return types with arguments of type Pair Modifier and Type Method Description <V1> PairStream<K,Pair<Iterable<V>,Iterable<V1>>>
PairStream. 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.Method parameters in org.apache.storm.streams with type arguments of type Pair Modifier and Type Method Description PairStream<K,V>
PairStream. filter(Predicate<? super Pair<K,V>> predicate)
Returns a stream consisting of the elements of this stream that matches the given filter.PairStream<K,V>
PairStream. peek(Consumer<? super Pair<K,V>> action)
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
Methods in org.apache.storm.streams.operations that return Pair Modifier and Type Method Description Pair<V1,V2>
PairValueJoiner. apply(V1 value1, V2 value2)
Joins two values and produces aPair
of the values as the result. -
Uses of Pair in org.apache.storm.streams.operations.mappers
Methods in org.apache.storm.streams.operations.mappers that return Pair Modifier and Type Method Description Pair<K,V>
PairValueMapper. apply(Tuple input)
-
Uses of Pair in org.apache.storm.streams.processors
Methods in org.apache.storm.streams.processors with parameters of type Pair Modifier and Type Method Description void
AggregateByKeyProcessor. execute(Pair<K,V> input)
void
CoGroupByKeyProcessor. execute(Pair<K,?> input, String sourceStream)
protected void
FlatMapValuesProcessor. execute(Pair<K,V> input)
void
JoinProcessor. execute(Pair<K,?> input, String sourceStream)
void
MapValuesProcessor. execute(Pair<K,V> input)
void
MergeAggregateByKeyProcessor. execute(Pair<K,A> input)
void
ReduceByKeyProcessor. execute(Pair<K,V> input)
protected void
UpdateStateByKeyProcessor. execute(Pair<K,V> input)
-
Uses of Pair in org.apache.storm.windowing
Methods in org.apache.storm.windowing that return Pair Modifier and Type Method Description Pair<Long,Long>
WatermarkCountEvictionPolicy. getState()
Methods in org.apache.storm.windowing with parameters of type Pair Modifier and Type Method Description void
WatermarkCountEvictionPolicy. restoreState(Pair<Long,Long> state)
-