Class CoGroupedStreams.UnionSerializerSnapshot<T1,T2>
- java.lang.Object
-
- org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>,CoGroupedStreams.UnionSerializer<T1,T2>>
-
- org.apache.flink.streaming.api.datastream.CoGroupedStreams.UnionSerializerSnapshot<T1,T2>
-
- All Implemented Interfaces:
org.apache.flink.api.common.typeutils.TypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>>
- Enclosing class:
- CoGroupedStreams<T1,T2>
public static class CoGroupedStreams.UnionSerializerSnapshot<T1,T2> extends org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>,CoGroupedStreams.UnionSerializer<T1,T2>>
TheTypeSerializerSnapshot
for theCoGroupedStreams.UnionSerializer
.
-
-
Constructor Summary
Constructors Constructor Description UnionSerializerSnapshot()
-
Method Summary
All Methods Instance Methods Concrete Methods Modifier and Type Method Description protected CoGroupedStreams.UnionSerializer<T1,T2>
createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers)
protected int
getCurrentOuterSnapshotVersion()
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[]
getNestedSerializers(CoGroupedStreams.UnionSerializer<T1,T2> outerSerializer)
-
Methods inherited from class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot
getCurrentVersion, getNestedSerializerSnapshots, isOuterSnapshotCompatible, readOuterSnapshot, readSnapshot, resolveOuterSchemaCompatibility, resolveOuterSchemaCompatibility, resolveSchemaCompatibility, restoreSerializer, writeOuterSnapshot, writeSnapshot
-
-
-
-
Method Detail
-
getCurrentOuterSnapshotVersion
protected int getCurrentOuterSnapshotVersion()
- Specified by:
getCurrentOuterSnapshotVersion
in classorg.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>,CoGroupedStreams.UnionSerializer<T1,T2>>
-
getNestedSerializers
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[] getNestedSerializers(CoGroupedStreams.UnionSerializer<T1,T2> outerSerializer)
- Specified by:
getNestedSerializers
in classorg.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>,CoGroupedStreams.UnionSerializer<T1,T2>>
-
createOuterSerializerWithNestedSerializers
protected CoGroupedStreams.UnionSerializer<T1,T2> createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers)
- Specified by:
createOuterSerializerWithNestedSerializers
in classorg.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<org.apache.flink.util.TaggedUnion<T1,T2>,CoGroupedStreams.UnionSerializer<T1,T2>>
-
-