This is an automated email from the ASF dual-hosted git repository.

dwysakowicz pushed a commit to branch master
in repository https://gitbox.apache.org/repos/asf/flink.git

commit be5cf3c9d679ff141a1041774070c66b46b866a7
Author: Jim Hughes <jhug...@confluent.io>
AuthorDate: Thu Dec 7 08:12:55 2023 -0500

    [FLINK-33757] Deleting RankJsonPlanTest.java and RankJsonPlanITCase.java
---
 .../plan/nodes/exec/stream/RankJsonPlanTest.java   | 71 --------------------
 .../stream/jsonplan/RankJsonPlanITCase.java        | 75 ----------------------
 2 files changed, 146 deletions(-)

diff --git 
a/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/plan/nodes/exec/stream/RankJsonPlanTest.java
 
b/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/plan/nodes/exec/stream/RankJsonPlanTest.java
deleted file mode 100644
index ba4bdd7c6f1..00000000000
--- 
a/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/plan/nodes/exec/stream/RankJsonPlanTest.java
+++ /dev/null
@@ -1,71 +0,0 @@
-/*
- * 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.table.planner.plan.nodes.exec.stream;
-
-import org.apache.flink.table.api.TableConfig;
-import org.apache.flink.table.api.TableEnvironment;
-import org.apache.flink.table.planner.utils.StreamTableTestUtil;
-import org.apache.flink.table.planner.utils.TableTestBase;
-
-import org.junit.jupiter.api.BeforeEach;
-import org.junit.jupiter.api.Test;
-
-/** Test json serialization for rank. */
-class RankJsonPlanTest extends TableTestBase {
-
-    private StreamTableTestUtil util;
-    private TableEnvironment tEnv;
-
-    @BeforeEach
-    void setup() {
-        util = streamTestUtil(TableConfig.getDefault());
-        tEnv = util.getTableEnv();
-
-        String srcTableDdl =
-                "CREATE TABLE MyTable (\n"
-                        + "  a bigint,\n"
-                        + "  b int not null,\n"
-                        + "  c varchar,\n"
-                        + "  d timestamp(3)\n"
-                        + ") with (\n"
-                        + "  'connector' = 'values',\n"
-                        + "  'bounded' = 'false')";
-        tEnv.executeSql(srcTableDdl);
-    }
-
-    @Test
-    void testRank() {
-        String sinkTableDdl =
-                "CREATE TABLE MySink (\n"
-                        + "  a bigint,\n"
-                        + "  b bigint\n"
-                        + ") with (\n"
-                        + "  'connector' = 'values',\n"
-                        + "  'sink-insert-only' = 'false',\n"
-                        + "  'table-sink-class' = 'DEFAULT')";
-        tEnv.executeSql(sinkTableDdl);
-        String sql =
-                "insert into MySink SELECT a, row_num\n"
-                        + "FROM (\n"
-                        + "  SELECT a, ROW_NUMBER() OVER (PARTITION BY b ORDER 
BY a) as row_num\n"
-                        + "  FROM MyTable)\n"
-                        + "WHERE row_num <= a";
-        util.verifyJsonPlan(sql);
-    }
-}
diff --git 
a/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/runtime/stream/jsonplan/RankJsonPlanITCase.java
 
b/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/runtime/stream/jsonplan/RankJsonPlanITCase.java
deleted file mode 100644
index b6ce7733ebf..00000000000
--- 
a/flink-table/flink-table-planner/src/test/java/org/apache/flink/table/planner/runtime/stream/jsonplan/RankJsonPlanITCase.java
+++ /dev/null
@@ -1,75 +0,0 @@
-/*
- * 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.table.planner.runtime.stream.jsonplan;
-
-import org.apache.flink.table.planner.factories.TestValuesTableFactory;
-import org.apache.flink.table.planner.runtime.utils.TestData;
-import org.apache.flink.table.planner.utils.JavaScalaConversionUtil;
-import org.apache.flink.table.planner.utils.JsonPlanTestBase;
-
-import org.junit.jupiter.api.Test;
-
-import java.io.IOException;
-import java.util.Arrays;
-import java.util.List;
-import java.util.concurrent.ExecutionException;
-
-/** Test for Rank JsonPlan ser/de. */
-class RankJsonPlanITCase extends JsonPlanTestBase {
-    @Test
-    void testRank() throws ExecutionException, InterruptedException, 
IOException {
-        createTestValuesSourceTable(
-                "MyTable",
-                JavaScalaConversionUtil.toJava(TestData.data1()),
-                "a int",
-                "b varchar",
-                "c int");
-        createTestNonInsertOnlyValuesSinkTable("`result`", "a int", "b 
varchar", "c bigint");
-        String sql =
-                "insert into `result` select * from "
-                        + "(select a, b, row_number() over(partition by b 
order by c) as c from MyTable)"
-                        + " where c = 1";
-        compileSqlAndExecutePlan(sql).await();
-
-        List<String> expected = Arrays.asList("+I[1, a, 1]", "+I[3, b, 1]", 
"+I[5, c, 1]");
-        assertResult(expected, 
TestValuesTableFactory.getResultsAsStrings("result"));
-    }
-
-    @Test
-    void testFirstN() throws ExecutionException, InterruptedException, 
IOException {
-        createTestValuesSourceTable(
-                "MyTable1",
-                JavaScalaConversionUtil.toJava(TestData.data4()),
-                "a varchar",
-                "b int",
-                "c int",
-                "t as proctime()");
-        createTestNonInsertOnlyValuesSinkTable("`result1`", "a varchar", "b 
int", "c bigint");
-        String sql =
-                "insert into `result1` select * from "
-                        + "(select a, b, row_number() over(partition by a 
order by t asc) as c from MyTable1)"
-                        + " where c <= 2";
-        compileSqlAndExecutePlan(sql).await();
-
-        List<String> expected =
-                Arrays.asList(
-                        "+I[book, 1, 1]", "+I[book, 2, 2]", "+I[fruit, 4, 1]", 
"+I[fruit, 3, 2]");
-        assertResult(expected, 
TestValuesTableFactory.getResultsAsStrings("result1"));
-    }
-}

Reply via email to