Class TimeWindowedDeserializer<T>

java.lang.Object
org.apache.kafka.streams.kstream.TimeWindowedDeserializer<T>
All Implemented Interfaces:
Closeable, AutoCloseable, org.apache.kafka.common.serialization.Deserializer<Windowed<T>>

public class TimeWindowedDeserializer<T> extends Object implements org.apache.kafka.common.serialization.Deserializer<Windowed<T>>
  • Field Details

    • WINDOW_SIZE_MS_CONFIG

      public static final String WINDOW_SIZE_MS_CONFIG
      Sets window size for the deserializer in order to calculate window end times.
      See Also:
    • WINDOWED_INNER_DESERIALIZER_CLASS

      public static final String WINDOWED_INNER_DESERIALIZER_CLASS
      Default deserializer for the inner deserializer class of a windowed record. Must implement the Serde interface.
      See Also:
  • Constructor Details

    • TimeWindowedDeserializer

      public TimeWindowedDeserializer()
    • TimeWindowedDeserializer

      public TimeWindowedDeserializer(org.apache.kafka.common.serialization.Deserializer<T> inner, Long windowSize)
  • Method Details

    • getWindowSize

      public Long getWindowSize()
    • configure

      public void configure(Map<String,?> configs, boolean isKey)
      Specified by:
      configure in interface org.apache.kafka.common.serialization.Deserializer<T>
    • deserialize

      public Windowed<T> deserialize(String topic, byte[] data)
      Specified by:
      deserialize in interface org.apache.kafka.common.serialization.Deserializer<T>
    • close

      public void close()
      Specified by:
      close in interface AutoCloseable
      Specified by:
      close in interface Closeable
      Specified by:
      close in interface org.apache.kafka.common.serialization.Deserializer<T>
    • setIsChangelogTopic

      public void setIsChangelogTopic(boolean isChangelogTopic)