Package org.apache.kafka.streams.kstream
Class SessionWindowedSerializer<T>
- java.lang.Object
 - 
- org.apache.kafka.streams.kstream.SessionWindowedSerializer<T>
 
 
- 
- All Implemented Interfaces:
 Closeable,AutoCloseable,Serializer<Windowed<T>>,org.apache.kafka.streams.kstream.internals.WindowedSerializer<T>
public class SessionWindowedSerializer<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_CLASSorStreamsConfig.DEFAULT_WINDOWED_VALUE_SERDE_INNER_CLASSif the no-arg constructor is called and hence it is not passed during initialization. 
- 
- 
Constructor Summary
Constructors Constructor Description SessionWindowedSerializer()SessionWindowedSerializer(Serializer<T> inner) 
- 
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description voidclose()Close this serializer.voidconfigure(Map<String,?> configs, boolean isKey)Configure this class.byte[]serialize(String topic, Windowed<T> data)Convertdatainto 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
- 
SessionWindowedSerializer
public SessionWindowedSerializer()
 
- 
SessionWindowedSerializer
public SessionWindowedSerializer(Serializer<T> inner)
 
 - 
 
- 
Method Detail
- 
configure
public void configure(Map<String,?> configs, boolean isKey)
Description copied from interface:SerializerConfigure this class.- Specified by:
 configurein 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:SerializerConvertdatainto a byte array.- Specified by:
 serializein interfaceSerializer<T>- Parameters:
 topic- topic associated with datadata- typed data- Returns:
 - serialized bytes
 
 
- 
close
public void close()
Description copied from interface:SerializerClose this serializer.This method must be idempotent as it may be called multiple times.
- Specified by:
 closein interfaceAutoCloseable- Specified by:
 closein interfaceCloseable- Specified by:
 closein interfaceSerializer<T>
 
 - 
 
 -