You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@flink.apache.org by ja...@apache.org on 2019/07/15 05:19:56 UTC

[flink] branch master updated: [FLINK-13217][table-planner-blink] Fix FlinkLogicalRelFactories to make it compile with Scala 2.12

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

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


The following commit(s) were added to refs/heads/master by this push:
     new 2c4e83c  [FLINK-13217][table-planner-blink] Fix FlinkLogicalRelFactories to make it compile with Scala 2.12
2c4e83c is described below

commit 2c4e83c4d9de47ff282e43c3c7b1447e2f9b96a8
Author: Jark Wu <im...@gmail.com>
AuthorDate: Mon Jul 15 11:10:41 2019 +0800

    [FLINK-13217][table-planner-blink] Fix FlinkLogicalRelFactories to make it compile with Scala 2.12
---
 .../table/calcite/FlinkLogicalRelFactories.scala   | 25 +---------------------
 1 file changed, 1 insertion(+), 24 deletions(-)

diff --git a/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/calcite/FlinkLogicalRelFactories.scala b/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/calcite/FlinkLogicalRelFactories.scala
index 11b0681..ce4bda2 100644
--- a/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/calcite/FlinkLogicalRelFactories.scala
+++ b/flink-table/flink-table-planner-blink/src/main/scala/org/apache/flink/table/calcite/FlinkLogicalRelFactories.scala
@@ -25,7 +25,7 @@ import org.apache.flink.table.runtime.rank.{RankRange, RankType}
 import org.apache.flink.table.sinks.TableSink
 
 import com.google.common.collect.ImmutableList
-import org.apache.calcite.plan.{Contexts, RelOptCluster, RelOptTable, RelTraitSet}
+import org.apache.calcite.plan.{Contexts, RelOptCluster, RelOptTable}
 import org.apache.calcite.rel.`type`.{RelDataType, RelDataTypeField}
 import org.apache.calcite.rel.core.RelFactories._
 import org.apache.calcite.rel.core._
@@ -106,13 +106,6 @@ object FlinkLogicalRelFactories {
         fetch: RexNode): RelNode = {
       FlinkLogicalSort.create(input, collation, offset, fetch)
     }
-
-    @deprecated // to be removed before 2.0
-    def createSort(
-        traits: RelTraitSet, input: RelNode,
-        collation: RelCollation, offset: RexNode, fetch: RexNode): RelNode = {
-      createSort(input, collation, offset, fetch)
-    }
   }
 
   /**
@@ -177,22 +170,6 @@ object FlinkLogicalRelFactories {
         semiJoinDone: Boolean): RelNode = {
       FlinkLogicalJoin.create(left, right, condition, joinType)
     }
-
-    def createJoin(
-        left: RelNode,
-        right: RelNode,
-        condition: RexNode,
-        joinType: JoinRelType,
-        variablesStopped: util.Set[String],
-        semiJoinDone: Boolean): RelNode = {
-      createJoin(
-        left,
-        right,
-        condition,
-        CorrelationId.setOf(variablesStopped),
-        joinType,
-        semiJoinDone)
-    }
   }
 
   /**