Package org.apache.kafka.streams.kstream
Class TimeWindowedSerializer<T>
- java.lang.Object
-
- org.apache.kafka.streams.kstream.TimeWindowedSerializer<T>
-
- All Implemented Interfaces:
Closeable
,AutoCloseable
,Serializer<Windowed<T>>
,org.apache.kafka.streams.kstream.internals.WindowedSerializer<T>
public class TimeWindowedSerializer<T> extends Object implements org.apache.kafka.streams.kstream.internals.WindowedSerializer<T>
The inner serde class can be specified by setting the propertyStreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS
orStreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization.
-
-
Constructor Summary
Constructors Constructor Description TimeWindowedSerializer()
TimeWindowedSerializer(Serializer<T> inner)
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
close()
Close this serializer.void
configure(Map<String,?> configs, boolean isKey)
Configure this class.byte[]
serialize(String topic, Windowed<T> data)
Convertdata
into a byte array.byte[]
serializeBaseKey(String topic, Windowed<T> data)
-
Methods inherited from class java.lang.Object
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
-
Methods inherited from interface org.apache.kafka.common.serialization.Serializer
serialize
-
-
-
-
Constructor Detail
-
TimeWindowedSerializer
public TimeWindowedSerializer()
-
TimeWindowedSerializer
public TimeWindowedSerializer(Serializer<T> inner)
-
-
Method Detail
-
configure
public void configure(Map<String,?> configs, boolean isKey)
Description copied from interface:Serializer
Configure this class.- Specified by:
configure
in interfaceSerializer<T>
- Parameters:
configs
- configs in key/value pairsisKey
- whether is for key or value
-
serialize
public byte[] serialize(String topic, Windowed<T> data)
Description copied from interface:Serializer
Convertdata
into a byte array.- Specified by:
serialize
in interfaceSerializer<T>
- Parameters:
topic
- topic associated with datadata
- typed data- Returns:
- serialized bytes
-
close
public void close()
Description copied from interface:Serializer
Close this serializer.This method must be idempotent as it may be called multiple times.
- Specified by:
close
in interfaceAutoCloseable
- Specified by:
close
in interfaceCloseable
- Specified by:
close
in interfaceSerializer<T>
-
-