Class WindowedKvKeySelector<InputT,K>

java.lang.Object
org.apache.beam.runners.flink.translation.types.WindowedKvKeySelector<InputT,K>
All Implemented Interfaces:
Serializable, org.apache.flink.api.common.functions.Function, org.apache.flink.api.java.functions.KeySelector<WindowedValue<KV<K,InputT>>,byte[]>, org.apache.flink.api.java.typeutils.ResultTypeQueryable<byte[]>

public class WindowedKvKeySelector<InputT,K> extends Object implements org.apache.flink.api.java.functions.KeySelector<WindowedValue<KV<K,InputT>>,byte[]>, org.apache.flink.api.java.typeutils.ResultTypeQueryable<byte[]>
KeySelector that extracts the key from a KV and returns it in encoded form as a byte array.
See Also:
  • Constructor Details

  • Method Details

    • getKey

      public byte[] getKey(WindowedValue<KV<K,InputT>> value) throws Exception
      Specified by:
      getKey in interface org.apache.flink.api.java.functions.KeySelector<InputT,K>
      Throws:
      Exception
    • getProducedType

      public org.apache.flink.api.common.typeinfo.TypeInformation<byte[]> getProducedType()
      Specified by:
      getProducedType in interface org.apache.flink.api.java.typeutils.ResultTypeQueryable<InputT>