Class TimeWindow.Serializer
- java.lang.Object
-
- org.apache.flink.api.common.typeutils.TypeSerializer<T>
-
- org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<TimeWindow>
-
- org.apache.flink.streaming.api.windowing.windows.TimeWindow.Serializer
-
- All Implemented Interfaces:
Serializable
- Enclosing class:
- TimeWindow
public static class TimeWindow.Serializer extends org.apache.flink.api.common.typeutils.base.TypeSerializerSingleton<TimeWindow>
The serializer used to write the TimeWindow type.- See Also:
- Serialized Form
-
-
Nested Class Summary
Nested Classes Modifier and Type Class Description static class
TimeWindow.Serializer.TimeWindowSerializerSnapshot
Serializer configuration snapshot for compatibility and format evolution.
-
Constructor Summary
Constructors Constructor Description Serializer()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description void
copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target)
TimeWindow
copy(TimeWindow from)
TimeWindow
copy(TimeWindow from, TimeWindow reuse)
TimeWindow
createInstance()
TimeWindow
deserialize(org.apache.flink.core.memory.DataInputView source)
TimeWindow
deserialize(TimeWindow reuse, org.apache.flink.core.memory.DataInputView source)
int
getLength()
boolean
isImmutableType()
void
serialize(TimeWindow record, org.apache.flink.core.memory.DataOutputView target)
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TimeWindow>
snapshotConfiguration()
-
-
-
Method Detail
-
isImmutableType
public boolean isImmutableType()
- Specified by:
isImmutableType
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
createInstance
public TimeWindow createInstance()
- Specified by:
createInstance
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
copy
public TimeWindow copy(TimeWindow from)
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
copy
public TimeWindow copy(TimeWindow from, TimeWindow reuse)
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
getLength
public int getLength()
- Specified by:
getLength
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
serialize
public void serialize(TimeWindow record, org.apache.flink.core.memory.DataOutputView target) throws IOException
- Specified by:
serialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
- Throws:
IOException
-
deserialize
public TimeWindow deserialize(org.apache.flink.core.memory.DataInputView source) throws IOException
- Specified by:
deserialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
- Throws:
IOException
-
deserialize
public TimeWindow deserialize(TimeWindow reuse, org.apache.flink.core.memory.DataInputView source) throws IOException
- Specified by:
deserialize
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
- Throws:
IOException
-
copy
public void copy(org.apache.flink.core.memory.DataInputView source, org.apache.flink.core.memory.DataOutputView target) throws IOException
- Specified by:
copy
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
- Throws:
IOException
-
snapshotConfiguration
public org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<TimeWindow> snapshotConfiguration()
- Specified by:
snapshotConfiguration
in classorg.apache.flink.api.common.typeutils.TypeSerializer<TimeWindow>
-
-