public class SessionWindowedSerializer<T> extends Object implements org.apache.kafka.streams.kstream.internals.WindowedSerializer<T>
StreamsConfig.DEFAULT_WINDOWED_KEY_SERDE_INNER_CLASS
or
StreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASS
if the no-arg constructor is called and hence it is not passed during initialization.Constructor and Description |
---|
SessionWindowedSerializer() |
SessionWindowedSerializer(Serializer<T> inner) |
Modifier and Type | Method and Description |
---|---|
void |
close()
Close this serializer.
|
void |
configure(Map<String,?> configs,
boolean isKey)
Configure this class.
|
byte[] |
serialize(String topic,
Windowed<T> data)
Convert
data into a byte array. |
byte[] |
serializeBaseKey(String topic,
Windowed<T> data) |
clone, equals, finalize, getClass, hashCode, notify, notifyAll, toString, wait, wait, wait
serialize
public SessionWindowedSerializer()
public SessionWindowedSerializer(Serializer<T> inner)
public void configure(Map<String,?> configs, boolean isKey)
Serializer
configure
in interface Serializer<Windowed<T>>
configs
- configs in key/value pairsisKey
- whether is for key or valuepublic byte[] serialize(String topic, Windowed<T> data)
Serializer
data
into a byte array.serialize
in interface Serializer<Windowed<T>>
topic
- topic associated with datadata
- typed datapublic void close()
Serializer
This method must be idempotent as it may be called multiple times.
close
in interface Closeable
close
in interface AutoCloseable
close
in interface Serializer<Windowed<T>>