[
https://issues.apache.org/jira/browse/FLINK-10605?page=com.atlassian.jira.plugin.system.issuetabpanels:comment-tabpanel&focusedCommentId=16656874#comment-16656874
]
ASF GitHub Bot commented on FLINK-10605:
----------------------------------------
igalshilman commented on a change in pull request #6881: [FLINK-10605] [core]
Upgrade AvroSerializer snapshot to implement new TypeSerializerSnapshot
interface
URL: https://github.com/apache/flink/pull/6881#discussion_r226672698
##########
File path:
flink-formats/flink-avro/src/main/java/org/apache/flink/formats/avro/typeutils/AvroSerializerSnapshot.java
##########
@@ -0,0 +1,163 @@
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one
+ * or more contributor license agreements. See the NOTICE file
+ * distributed with this work for additional information
+ * regarding copyright ownership. The ASF licenses this file
+ * to you under the Apache License, Version 2.0 (the
+ * "License"); you may not use this file except in compliance
+ * with the License. You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.flink.formats.avro.typeutils;
+
+import org.apache.flink.annotation.VisibleForTesting;
+import org.apache.flink.api.common.typeutils.TypeSerializer;
+import org.apache.flink.api.common.typeutils.TypeSerializerSchemaCompatibility;
+import org.apache.flink.api.common.typeutils.TypeSerializerSnapshot;
+import org.apache.flink.core.memory.DataInputView;
+import org.apache.flink.core.memory.DataOutputView;
+
+import org.apache.avro.Schema;
+import org.apache.avro.SchemaCompatibility;
+import org.apache.avro.SchemaCompatibility.SchemaPairCompatibility;
+
+import java.io.IOException;
+import java.util.Objects;
+
+import static org.apache.flink.util.Preconditions.checkNotNull;
+
+/**
+ * An {@code Avro} specific implementation of a {@link TypeSerializerSnapshot}.
+ *
+ * @param <T> The data type that the originating serializer of this
configuration serializes.
+ */
+public final class AvroSerializerSnapshot<T> implements
TypeSerializerSnapshot<T> {
+ private Class<T> runtimeType;
+ private Schema schema;
+
+ @SuppressWarnings("WeakerAccess")
+ public AvroSerializerSnapshot() {
+ // this constructor is used when restoring from a checkpoint.
+ }
+
+ AvroSerializerSnapshot(Schema schema, Class<T> runtimeType) {
+ this.schema = schema;
+ this.runtimeType = runtimeType;
+ }
+
+ @Override
+ public int getCurrentVersion() {
+ return 1;
+ }
+
+ @Override
+ public void write(DataOutputView out) throws IOException {
+ checkNotNull(runtimeType);
+ checkNotNull(schema);
+
+ out.writeUTF(runtimeType.getName());
+ out.writeUTF(schema.toString(false));
+ }
+
+ @Override
+ public void read(int readVersion, DataInputView in, ClassLoader
userCodeClassLoader) throws IOException {
+ final String previousRuntimeClassName = in.readUTF();
+ final String previousSchemaDefinition = in.readUTF();
+
+ this.runtimeType = findClassOrThrow(userCodeClassLoader,
previousRuntimeClassName);
+ this.schema = parseAvroSchema(previousSchemaDefinition);
+ }
+
+ @Override
+ public <NS extends TypeSerializer<T>>
TypeSerializerSchemaCompatibility<T, NS>
+ resolveSchemaCompatibility(NS newSerializer) {
+ if (!(newSerializer instanceof AvroSerializer)) {
+ return TypeSerializerSchemaCompatibility.incompatible();
+ }
+ AvroSerializer<?> newAvroSerializer = (AvroSerializer<?>)
newSerializer;
+ return resolveSchemaCompatibility(schema,
newAvroSerializer.getAvroSchema());
+ }
+
+ @Override
+ public TypeSerializer<T> restoreSerializer() {
+ checkNotNull(runtimeType);
+ checkNotNull(schema);
+
+ if (AvroSerializer.isGenericRecord(runtimeType)) {
+ return new AvroSerializer<>(runtimeType, schema);
+ }
+ else {
+ return new AvroSerializer<>(runtimeType);
+ }
+ }
+
+ //
------------------------------------------------------------------------------------------------------------
+ // Helpers
+ //
------------------------------------------------------------------------------------------------------------
+
+ /**
+ * Resolves writer/reader schema compatibly.
+ *
+ * <p>Checks whenever a new version of a schema (reader) can read
values serialized with the old schema (writer).
+ * If the schemas are compatible according to {@code Avro} schema
resolution rules
+ * (@see <a
href="https://avro.apache.org/docs/current/spec.html#Schema+Resolution">Schema
Resolution</a>).
+ */
+ @VisibleForTesting
+ static <T, NS extends TypeSerializer<T>>
TypeSerializerSchemaCompatibility<T, NS> resolveSchemaCompatibility(
+ Schema writerSchema,
+ Schema readerSchema) {
+
+ if (Objects.equals(writerSchema, readerSchema)) {
+ return
TypeSerializerSchemaCompatibility.compatibleAsIs();
+ }
+
+ final SchemaPairCompatibility compatibility =
+
SchemaCompatibility.checkReaderWriterCompatibility(readerSchema, writerSchema);
+
+ return avroCompatibilityToFlinkCompatibility(compatibility);
+ }
+
+ private static <T, NS extends TypeSerializer<T>>
TypeSerializerSchemaCompatibility<T, NS>
+ avroCompatibilityToFlinkCompatibility(SchemaPairCompatibility
compatibility) {
+ switch (compatibility.getType()) {
+ case COMPATIBLE: {
+ // The new serializer would be able to read
data persisted with *this* serializer, therefore no migration
+ // is required.
+ return
TypeSerializerSchemaCompatibility.compatibleAsIs();
+ }
+ case INCOMPATIBLE: {
+ return
TypeSerializerSchemaCompatibility.compatibleAfterMigration();
Review comment:
Yes, you are right. I have changed it.
----------------------------------------------------------------
This is an automated message from the Apache Git Service.
To respond to the message, please log on GitHub and use the
URL above to go to the specific comment.
For queries about this service, please contact Infrastructure at:
[email protected]
> Upgrade AvroSerializer snapshot to implement new TypeSerializerSnapshot
> interface
> ---------------------------------------------------------------------------------
>
> Key: FLINK-10605
> URL: https://issues.apache.org/jira/browse/FLINK-10605
> Project: Flink
> Issue Type: Sub-task
> Components: Type Serialization System
> Reporter: Igal Shilman
> Assignee: Igal Shilman
> Priority: Major
> Labels: pull-request-available
> Fix For: 1.7.0
>
>
> This issue introduces a new AvroSerializerSnapshot implementation that
> conforms to the new TypeSerializerSnapshot API.
--
This message was sent by Atlassian JIRA
(v7.6.3#76005)