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

[jira] [Updated] (FLINK-26389) Many operators of ”flink-end-to-end-tests“ have been deprecated and need to be updated

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

ChengyunZhang updated FLINK-26389:
----------------------------------
    Description: 
Many  functions  of  ”flink-end-to-end-tests“ have been  deprecated .the specific contents are as follows:

org.apache.flink.streaming.connectors.gcp.pubsub.EmulatedPubSubSourceTest:the "collect" on line 147 has been deprecated;
org.apache.flink.table.tpcds.TpcdsTestProgram:both the "CsvTableSource" on line 163 and the "CsvTableSink" on line 115 have been deprecated;
org.apache.flink.streaming.tests.PeriodicStreamingJob:both the "keyby" on line 68 and the "writeAsText" on line 70 have been deprecated;
org.apache.flink.sql.tests.BatchSQLTestProgram: the "CsvTableSink" on line 68 has been deprecated;
FileSinkProgram:the "keyBy" on line 89 has been deprecated ;
org.apache.flink.streaming.tests.DistributedCacheViaBlobTestProgram: the "writeAsText" on line 68 has been deprecated
org.apache.flink.streaming.tests.RocksDBStateMemoryControlTestProgram:the "assignTimestampsAndWatermarks" on line 64 has been deprecated;
org.apache.flink.streaming.tests.StatefulStreamJobUpgradeTestProgram: the "assignTimestampsAndWatermarks" on line 96 has been deprecated;
org.apache.flink.table.tpcds.TpcdsTestProgram:the "CsvTableSink" on line 115 has been deprecated.

  was:
Many  functions  of  ”flink-end-to-end-tests“ have been  deprecated .the specific contents are as follows:

org.apache.flink.streaming.connectors.gcp.pubsub.EmulatedPubSubSourceTest:the "collect" on line 147 has been deprecated;
org.apache.flink.table.tpcds.TpcdsTestProgram:both the "CsvTableSource" on line 163 and the "CsvTableSink" on line 115 have been deprecated;
org.apache.flink.streaming.tests.PeriodicStreamingJob:both the "keyby" on line 68 and the "writeAsText" on line 70 have been deprecated;
org.apache.flink.sql.tests.BatchSQLTestProgram: the "CsvTableSink" on line 68 has been deprecated;
FileSinkProgram:the "keyBy" on line 89 has been deprecated and line 57 of the code has an extra ";";
org.apache.flink.tests.util.activation.OperatingSystemRestriction:line 115 of the code has an extra ';';
org.apache.flink.streaming.tests.DistributedCacheViaBlobTestProgram: the "writeAsText" on line 68 has been deprecated
org.apache.flink.streaming.tests.RocksDBStateMemoryControlTestProgram:the "assignTimestampsAndWatermarks" on line 64 has been deprecated;
org.apache.flink.streaming.tests.StatefulStreamJobUpgradeTestProgram: the "assignTimestampsAndWatermarks" on line 96 has been deprecated;
org.apache.flink.streaming.kafka.test.KafkaExample:both the "FlinkKafkaConsumer" on line 56 and the "keyBy" on line 62 have been deprecated;
org.apache.flink.table.tpcds.TpcdsTestProgram:the "CsvTableSink" on line 115 has been deprecated.


> Many operators of ”flink-end-to-end-tests“  have been  deprecated and need to be updated
> ----------------------------------------------------------------------------------------
>
>                 Key: FLINK-26389
>                 URL: https://issues.apache.org/jira/browse/FLINK-26389
>             Project: Flink
>          Issue Type: Improvement
>          Components: Tests
>    Affects Versions: 1.14.3
>            Reporter: ChengyunZhang
>            Priority: Major
>
> Many  functions  of  ”flink-end-to-end-tests“ have been  deprecated .the specific contents are as follows:
> org.apache.flink.streaming.connectors.gcp.pubsub.EmulatedPubSubSourceTest:the "collect" on line 147 has been deprecated;
> org.apache.flink.table.tpcds.TpcdsTestProgram:both the "CsvTableSource" on line 163 and the "CsvTableSink" on line 115 have been deprecated;
> org.apache.flink.streaming.tests.PeriodicStreamingJob:both the "keyby" on line 68 and the "writeAsText" on line 70 have been deprecated;
> org.apache.flink.sql.tests.BatchSQLTestProgram: the "CsvTableSink" on line 68 has been deprecated;
> FileSinkProgram:the "keyBy" on line 89 has been deprecated ;
> org.apache.flink.streaming.tests.DistributedCacheViaBlobTestProgram: the "writeAsText" on line 68 has been deprecated
> org.apache.flink.streaming.tests.RocksDBStateMemoryControlTestProgram:the "assignTimestampsAndWatermarks" on line 64 has been deprecated;
> org.apache.flink.streaming.tests.StatefulStreamJobUpgradeTestProgram: the "assignTimestampsAndWatermarks" on line 96 has been deprecated;
> org.apache.flink.table.tpcds.TpcdsTestProgram:the "CsvTableSink" on line 115 has been deprecated.



--
This message was sent by Atlassian Jira
(v8.20.1#820001)