Class WindowKeySchema

    • Constructor Summary

      Constructors 
      Constructor Description
      WindowKeySchema()  
    • Method Summary

      All Methods Static Methods Instance Methods Concrete Methods 
      Modifier and Type Method Description
      static <K> Windowed<K> from​(byte[] binaryKey, long windowSize, Deserializer<K> deserializer, String topic)  
      static Windowed<org.apache.kafka.common.utils.Bytes> fromStoreBytesKey​(byte[] binaryKey, long windowSize)  
      static <K> Windowed<K> fromStoreKey​(byte[] binaryKey, long windowSize, Deserializer<K> deserializer, String topic)  
      static <K> Windowed<K> fromStoreKey​(Windowed<org.apache.kafka.common.utils.Bytes> windowedKey, Deserializer<K> deserializer, String topic)  
      org.apache.kafka.streams.state.internals.HasNextCondition hasNextCondition​(org.apache.kafka.common.utils.Bytes binaryKeyFrom, org.apache.kafka.common.utils.Bytes binaryKeyTo, long from, long to)
      Create an implementation of HasNextCondition that knows when to stop iterating over the KeyValueSegments.
      org.apache.kafka.common.utils.Bytes lowerRange​(org.apache.kafka.common.utils.Bytes key, long from)
      Given a range of record keys and a time, construct a Segmented key that represents the lower range of keys to search when performing range queries.
      org.apache.kafka.common.utils.Bytes lowerRangeFixedSize​(org.apache.kafka.common.utils.Bytes key, long from)
      Given a range of fixed size record keys and a time, construct a Segmented key that represents the lower range of keys to search when performing range queries.
      <S extends Segment>
      List<S>
      segmentsToSearch​(org.apache.kafka.streams.state.internals.Segments<S> segments, long from, long to)
      Used during SegmentedBytesStore.fetch(Bytes, long, long) operations to determine which segments should be scanned.
      long segmentTimestamp​(org.apache.kafka.common.utils.Bytes key)
      Extract the timestamp of the segment from the key.
      static <K> byte[] toBinary​(Windowed<K> timeKey, Serializer<K> serializer, String topic)  
      static <K> org.apache.kafka.common.utils.Bytes toStoreKeyBinary​(K key, long timestamp, int seqnum, StateSerdes<K,​?> serdes)  
      static org.apache.kafka.common.utils.Bytes toStoreKeyBinary​(org.apache.kafka.common.utils.Bytes key, long timestamp, int seqnum)  
      static <K> org.apache.kafka.common.utils.Bytes toStoreKeyBinary​(Windowed<K> timeKey, int seqnum, StateSerdes<K,​?> serdes)  
      static org.apache.kafka.common.utils.Bytes toStoreKeyBinary​(Windowed<org.apache.kafka.common.utils.Bytes> timeKey, int seqnum)  
      org.apache.kafka.common.utils.Bytes upperRange​(org.apache.kafka.common.utils.Bytes key, long to)
      Given a range of record keys and a time, construct a Segmented key that represents the upper range of keys to search when performing range queries.
      org.apache.kafka.common.utils.Bytes upperRangeFixedSize​(org.apache.kafka.common.utils.Bytes key, long to)
      Given a range of fixed size record keys and a time, construct a Segmented key that represents the upper range of keys to search when performing range queries.