@Internal public static final class TwoPhaseCommitSinkFunction.StateSerializerSnapshot<TXN,CONTEXT> extends org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
TwoPhaseCommitSinkFunction.StateSerializer
.Constructor and Description |
---|
StateSerializerSnapshot() |
Modifier and Type | Method and Description |
---|---|
protected TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> |
createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers) |
protected int |
getCurrentOuterSnapshotVersion() |
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[] |
getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> outerSerializer) |
protected void |
readOuterSnapshot(int readOuterSnapshotVersion,
org.apache.flink.core.memory.DataInputView in,
ClassLoader userCodeClassLoader) |
protected org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility |
resolveOuterSchemaCompatibility(TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> newSerializer) |
protected void |
writeOuterSnapshot(org.apache.flink.core.memory.DataOutputView out) |
getCurrentVersion, getNestedSerializerSnapshots, isOuterSnapshotCompatible, readSnapshot, resolveSchemaCompatibility, restoreSerializer, writeSnapshot
protected int getCurrentOuterSnapshotVersion()
getCurrentOuterSnapshotVersion
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
protected void readOuterSnapshot(int readOuterSnapshotVersion, org.apache.flink.core.memory.DataInputView in, ClassLoader userCodeClassLoader) throws IOException
readOuterSnapshot
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
IOException
protected void writeOuterSnapshot(org.apache.flink.core.memory.DataOutputView out) throws IOException
writeOuterSnapshot
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
IOException
protected org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot.OuterSchemaCompatibility resolveOuterSchemaCompatibility(TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> newSerializer)
resolveOuterSchemaCompatibility
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
protected TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> createOuterSerializerWithNestedSerializers(org.apache.flink.api.common.typeutils.TypeSerializer<?>[] nestedSerializers)
createOuterSerializerWithNestedSerializers
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
protected org.apache.flink.api.common.typeutils.TypeSerializer<?>[] getNestedSerializers(TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT> outerSerializer)
getNestedSerializers
in class org.apache.flink.api.common.typeutils.CompositeTypeSerializerSnapshot<TwoPhaseCommitSinkFunction.State<TXN,CONTEXT>,TwoPhaseCommitSinkFunction.StateSerializer<TXN,CONTEXT>>
Copyright © 2014–2023 The Apache Software Foundation. All rights reserved.