You are viewing a plain text version of this content. The canonical link for it is here.
Posted to issues@flink.apache.org by "Aljoscha Krettek (Jira)" <ji...@apache.org> on 2020/01/03 14:21:00 UTC

[jira] [Assigned] (FLINK-13632) Update serializer upgrade tests to restore from 1.8 and beyond

     [ https://issues.apache.org/jira/browse/FLINK-13632?page=com.atlassian.jira.plugin.system.issuetabpanels:all-tabpanel ]

Aljoscha Krettek reassigned FLINK-13632:
----------------------------------------

    Assignee:     (was: Aljoscha Krettek)

> Update serializer upgrade tests to restore from 1.8 and beyond
> --------------------------------------------------------------
>
>                 Key: FLINK-13632
>                 URL: https://issues.apache.org/jira/browse/FLINK-13632
>             Project: Flink
>          Issue Type: Sub-task
>          Components: Tests
>    Affects Versions: 1.10.0
>            Reporter: Till Rohrmann
>            Priority: Blocker
>             Fix For: 1.10.0
>
>
> FLINK-11767 introduced a new test base ({{TypeSerializerUpgradeTestBase}}) for writing serializer upgrade tests. Now we need to migrate all existing tests from {{TypeSerializerSnapshotMigrationTestBase}} to use the new test base and update them to restore from Flink 1.8 onward.
> It seems these are the subclasses:
> * TtlSerializerStateMigrationTest (org.apache.flink.runtime.state.ttl)
> * ValueSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * PrimitiveArraySerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils.base.array)
> * AvroSerializerMigrationTest (org.apache.flink.formats.avro.typeutils)
> * TupleSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * BufferEntrySerializerMigrationTest (org.apache.flink.streaming.api.operators.co)
> * TimerSerializerSnapshotMigrationTest (org.apache.flink.streaming.api.operators)
> * StreamElementSerializerMigrationTest (org.apache.flink.streaming.runtime.streamrecord)
> * KryoSnapshotMigrationTest (org.apache.flink.api.java.typeutils.runtime.kryo)
> * BaseTypeSerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils.base)
> * NullableSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * VoidNamespacieSerializerSnapshotMigrationTest (org.apache.flink.runtime.state)
> * ScalaOptionSerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)
> * ScalaTrySerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)
> * JavaSerializerSnapshotMigrationTest (org.apache.flink.runtime.state)
> * LockableTypeSerializerSnapshotMigrationTest (org.apache.flink.cep.nfa.sharedbuffer)
> * NFASerializerSnapshotsMigrationTest (org.apache.flink.cep)
> * WindowSerializerSnapshotsMigrationTest (org.apache.flink.streaming.runtime.operators.windowing)
> * UnionSerializerMigrationTest (org.apache.flink.streaming.api.datastream)
> * TwoPhaseCommitSinkStateSerializerMigrationTest (org.apache.flink.streaming.api.functions.sink)
> * KafkaSerializerSnapshotsMigrationTest (org.apache.flink.streaming.connectors.kafka)
> * KafkaSerializerSnapshotsMigrationTest (org.apache.flink.streaming.connectors.kafka)
> * RowSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * ValueArraySerializerSnapshotMigrationTest (org.apache.flink.graph.types.valuearray)
> * MapSerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils.base)
> * CompositeTypeSerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils)
> * ListSerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils.base)
> * EnumSerializerSnapshotMigrationTest (org.apache.flink.api.common.typeutils.base)
> * PojoSerializerSnapshotMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * ArrayListSerializerMigrationTest (org.apache.flink.runtime.state)
> * CopyableSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * WritableSerializerMigrationTest (org.apache.flink.api.java.typeutils.runtime)
> * ListViewSerializerSnapshotMigrationTest (org.apache.flink.table.dataview)
> * MapViewSerializerSnapshotMigrationTest (org.apache.flink.table.dataview)
> * ScalaEitherSerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)
> * LongValueWithProperHashCodeSerializerSnapshotMigrationTest (org.apache.flink.graph.drivers.transform)
> * ScalaCaseClassSerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)
> * TraversableSerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)
> * EnumValueSerializerSnapshotMigrationTest (org.apache.flink.api.scala.typeutils)



--
This message was sent by Atlassian Jira
(v8.3.4#803005)