protected static class GroupByKeyTranslator.KeyedByTimestamp<K,V> extends io.gearpump.streaming.dsl.api.functions.MapFunction<org.apache.beam.sdk.util.WindowedValue<KV<K,V>>,KV<Instant,org.apache.beam.sdk.util.WindowedValue<KV<K,V>>>>
Constructor and Description |
---|
KeyedByTimestamp(WindowFn<KV<K,V>,BoundedWindow> windowFn,
TimestampCombiner timestampCombiner) |
Modifier and Type | Method and Description |
---|---|
KV<Instant,org.apache.beam.sdk.util.WindowedValue<KV<K,V>>> |
map(org.apache.beam.sdk.util.WindowedValue<KV<K,V>> wv) |