Class KvToFlinkKeyKeySelector<K,V>

java.lang.Object
org.apache.beam.runners.flink.translation.wrappers.streaming.KvToFlinkKeyKeySelector<K,V>
All Implemented Interfaces:
Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.java.functions.KeySelector<WindowedValue<KV<K,V>>,FlinkKey>, org.apache.flink.api.java.typeutils.ResultTypeQueryable<FlinkKey>

public class KvToFlinkKeyKeySelector<K,V> extends Object implements org.apache.flink.api.java.functions.KeySelector<WindowedValue<KV<K,V>>,FlinkKey>, org.apache.flink.api.java.typeutils.ResultTypeQueryable<FlinkKey>
KeySelector that retrieves a key from a KV. This will return the key as encoded by the provided Coder in a FlinkKey. This ensures that all key comparisons/hashing happen on the encoded form.
See Also:
  • Constructor Details

    • KvToFlinkKeyKeySelector

      public KvToFlinkKeyKeySelector(Coder<K> keyCoder)
  • Method Details

    • getKey

      public FlinkKey getKey(WindowedValue<KV<K,V>> value)
      Specified by:
      getKey in interface org.apache.flink.api.java.functions.KeySelector<K,V>
    • getProducedType

      public org.apache.flink.api.common.typeinfo.TypeInformation<FlinkKey> getProducedType()
      Specified by:
      getProducedType in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable<K>