Modifier and Type | Method and Description |
---|---|
Pair<Object,Values> |
StreamInsertMapToPairFunction.apply(Values input) |
Modifier and Type | Method and Description |
---|---|
static <T1,T2> Pair<T1,T2> |
Pair.of(T1 first,
T2 second)
Constructs a new pair of values.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and 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.
|
Modifier and Type | Method and Description |
---|---|
Pair<V1,V2> |
PairValueJoiner.apply(V1 value1,
V2 value2)
Joins two values and produces a
Pair of the values as the result. |
Modifier and Type | Method and Description |
---|---|
Pair<K,V> |
PairValueMapper.apply(Tuple input) |
Modifier and Type | Method and Description |
---|---|
void |
CoGroupByKeyProcessor.execute(Pair<K,?> input,
String sourceStream) |
void |
JoinProcessor.execute(Pair<K,?> input,
String sourceStream) |
void |
MergeAggregateByKeyProcessor.execute(Pair<K,A> input) |
void |
ReduceByKeyProcessor.execute(Pair<K,V> input) |
void |
AggregateByKeyProcessor.execute(Pair<K,V> input) |
protected void |
UpdateStateByKeyProcessor.execute(Pair<K,V> input) |
protected void |
FlatMapValuesProcessor.execute(Pair<K,V> input) |
void |
MapValuesProcessor.execute(Pair<K,V> input) |
Modifier and Type | Method and Description |
---|---|
Pair<Long,Long> |
WatermarkCountEvictionPolicy.getState() |
Modifier and Type | Method and Description |
---|---|
void |
WatermarkCountEvictionPolicy.restoreState(Pair<Long,Long> state) |
Copyright © 2022 The Apache Software Foundation. All rights reserved.