diff --git a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Column.scala b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Column.scala index fde17963bfd05..734535c2e14c1 100644 --- a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Column.scala +++ b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Column.scala @@ -1270,14 +1270,17 @@ class Column private[sql] (private[sql] val expr: proto.Expression) extends Logg private[sql] object Column { - def apply(name: String): Column = Column { builder => + def apply(name: String): Column = Column(name, None) + + def apply(name: String, planId: Option[Long]): Column = Column { builder => name match { case "*" => builder.getUnresolvedStarBuilder case _ if name.endsWith(".*") => builder.getUnresolvedStarBuilder.setUnparsedTarget(name) case _ => - builder.getUnresolvedAttributeBuilder.setUnparsedIdentifier(name) + val attributeBuilder = builder.getUnresolvedAttributeBuilder.setUnparsedIdentifier(name) + planId.foreach(attributeBuilder.setPlanId) } } diff --git a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Dataset.scala b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Dataset.scala index 560276d154e45..87aadfe437be1 100644 --- a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Dataset.scala +++ b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/Dataset.scala @@ -117,6 +117,8 @@ import org.apache.spark.util.Utils */ class Dataset[T] private[sql] (val session: SparkSession, private[sql] val plan: proto.Plan) extends Serializable { + // Make sure we don't forget to set plan id. + assert(plan.getRoot.getCommon.hasPlanId) override def toString: String = { try { @@ -873,7 +875,14 @@ class Dataset[T] private[sql] (val session: SparkSession, private[sql] val plan: * @group untypedrel * @since 3.4.0 */ - def col(colName: String): Column = functions.col(colName) + def col(colName: String): Column = { + val planId = if (plan.getRoot.hasCommon && plan.getRoot.getCommon.hasPlanId) { + Option(plan.getRoot.getCommon.getPlanId) + } else { + None + } + Column.apply(colName, planId) + } /** * Selects column based on the column name specified as a regex and returns it as [[Column]]. diff --git a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/SparkSession.scala b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/SparkSession.scala index 0e5aaace20d65..a63c23e6bf1e9 100644 --- a/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/SparkSession.scala +++ b/connector/connect/client/jvm/src/main/scala/org/apache/spark/sql/SparkSession.scala @@ -17,6 +17,7 @@ package org.apache.spark.sql import java.io.Closeable +import java.util.concurrent.atomic.AtomicLong import scala.collection.JavaConverters._ @@ -48,7 +49,10 @@ import org.apache.spark.sql.connect.client.util.Cleaner * .getOrCreate() * }}} */ -class SparkSession(private val client: SparkConnectClient, private val cleaner: Cleaner) +class SparkSession( + private val client: SparkConnectClient, + private val cleaner: Cleaner, + private val planIdGenerator: AtomicLong) extends Serializable with Closeable with Logging { @@ -183,6 +187,7 @@ class SparkSession(private val client: SparkConnectClient, private val cleaner: private[sql] def newDataset[T](f: proto.Relation.Builder => Unit): Dataset[T] = { val builder = proto.Relation.newBuilder() f(builder) + builder.getCommonBuilder.setPlanId(planIdGenerator.getAndIncrement()) val plan = proto.Plan.newBuilder().setRoot(builder).build() new Dataset[T](this, plan) } @@ -204,6 +209,15 @@ class SparkSession(private val client: SparkConnectClient, private val cleaner: client.execute(plan).asScala.foreach(_ => ()) } + /** + * This resets the plan id generator so we can produce plans that are comparable. + * + * For testing only! + */ + private[sql] def resetPlanIdGenerator(): Unit = { + planIdGenerator.set(0) + } + override def close(): Unit = { client.shutdown() allocator.close() @@ -213,9 +227,11 @@ class SparkSession(private val client: SparkConnectClient, private val cleaner: // The minimal builder needed to create a spark session. // TODO: implements all methods mentioned in the scaladoc of [[SparkSession]] object SparkSession extends Logging { + private val planIdGenerator = new AtomicLong + def builder(): Builder = new Builder() - private lazy val cleaner = { + private[sql] lazy val cleaner = { val cleaner = new Cleaner cleaner.start() cleaner @@ -238,7 +254,7 @@ object SparkSession extends Logging { if (_client == null) { _client = SparkConnectClient.builder().build() } - new SparkSession(_client, cleaner) + new SparkSession(_client, cleaner, planIdGenerator) } } } diff --git a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/ClientE2ETestSuite.scala b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/ClientE2ETestSuite.scala index c9d9f43cbaff2..7077d8c94e8df 100644 --- a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/ClientE2ETestSuite.scala +++ b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/ClientE2ETestSuite.scala @@ -27,7 +27,7 @@ import org.apache.commons.io.output.TeeOutputStream import org.scalactic.TolerantNumerics import org.apache.spark.sql.connect.client.util.{IntegrationTestUtils, RemoteSparkSession} -import org.apache.spark.sql.functions.{aggregate, array, col, lit, sequence, shuffle, transform, udf} +import org.apache.spark.sql.functions.{aggregate, array, col, lit, rand, sequence, shuffle, transform, udf} import org.apache.spark.sql.types._ class ClientE2ETestSuite extends RemoteSparkSession { @@ -399,4 +399,11 @@ class ClientE2ETestSuite extends RemoteSparkSession { .getSeq[Int](0) assert(result.toSet === Set(1, 2, 3, 74)) } + + test("ambiguous joins") { + val left = spark.range(100).select(col("id"), rand(10).as("a")) + val right = spark.range(100).select(col("id"), rand(12).as("a")) + val joined = left.join(right, left("id") === right("id")).select(left("id"), right("a")) + assert(joined.schema.catalogString === "struct") + } } diff --git a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/DatasetSuite.scala b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/DatasetSuite.scala index 412371c41863a..c3c80a08379fe 100644 --- a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/DatasetSuite.scala +++ b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/DatasetSuite.scala @@ -16,11 +16,11 @@ */ package org.apache.spark.sql -import scala.collection.JavaConverters._ +import java.util.concurrent.TimeUnit +import java.util.concurrent.atomic.AtomicLong import io.grpc.Server -import io.grpc.netty.NettyServerBuilder -import java.util.concurrent.TimeUnit +import io.grpc.inprocess.{InProcessChannelBuilder, InProcessServerBuilder} import org.scalatest.BeforeAndAfterEach import org.scalatest.funsuite.AnyFunSuite // scalastyle:ignore funsuite @@ -40,33 +40,27 @@ class DatasetSuite private var service: DummySparkConnectService = _ private var ss: SparkSession = _ - private def getNewSparkSession(port: Int): SparkSession = { - assert(port != 0) - SparkSession - .builder() - .client( - SparkConnectClient - .builder() - .connectionString(s"sc://localhost:$port") - .build()) - .build() + private def newSparkSession(): SparkSession = { + val client = new SparkConnectClient( + proto.UserContext.newBuilder().build(), + InProcessChannelBuilder.forName(getClass.getName).directExecutor().build(), + "test") + new SparkSession(client, cleaner = SparkSession.cleaner, planIdGenerator = new AtomicLong) } private def startDummyServer(): Unit = { service = new DummySparkConnectService() - val sb = NettyServerBuilder - // Let server bind to any free port - .forPort(0) + server = InProcessServerBuilder + .forName(getClass.getName) .addService(service) - - server = sb.build + .build() server.start() } override def beforeEach(): Unit = { super.beforeEach() startDummyServer() - ss = getNewSparkSession(server.getPort) + ss = newSparkSession() } override def afterEach(): Unit = { @@ -76,47 +70,6 @@ class DatasetSuite } } - test("limit") { - val df = ss.newDataset(_ => ()) - val builder = proto.Relation.newBuilder() - builder.getLimitBuilder.setInput(df.plan.getRoot).setLimit(10) - - val expectedPlan = proto.Plan.newBuilder().setRoot(builder).build() - df.limit(10).analyze - val actualPlan = service.getAndClearLatestInputPlan() - assert(actualPlan.equals(expectedPlan)) - } - - test("select") { - val df = ss.newDataset(_ => ()) - - val builder = proto.Relation.newBuilder() - val dummyCols = Seq[Column](Column("a"), Column("b")) - builder.getProjectBuilder - .setInput(df.plan.getRoot) - .addAllExpressions(dummyCols.map(_.expr).asJava) - val expectedPlan = proto.Plan.newBuilder().setRoot(builder).build() - - df.select(dummyCols: _*).analyze - val actualPlan = service.getAndClearLatestInputPlan() - assert(actualPlan.equals(expectedPlan)) - } - - test("filter") { - val df = ss.newDataset(_ => ()) - - val builder = proto.Relation.newBuilder() - val dummyCondition = Column.fn("dummy func", Column("a")) - builder.getFilterBuilder - .setInput(df.plan.getRoot) - .setCondition(dummyCondition.expr) - val expectedPlan = proto.Plan.newBuilder().setRoot(builder).build() - - df.filter(dummyCondition).analyze - val actualPlan = service.getAndClearLatestInputPlan() - assert(actualPlan.equals(expectedPlan)) - } - test("write") { val df = ss.newDataset(_ => ()).limit(10) diff --git a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/PlanGenerationTestSuite.scala b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/PlanGenerationTestSuite.scala index b759471e777f3..f7589d957ca57 100644 --- a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/PlanGenerationTestSuite.scala +++ b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/PlanGenerationTestSuite.scala @@ -18,13 +18,14 @@ package org.apache.spark.sql import java.nio.file.{Files, Path} import java.util.Collections +import java.util.concurrent.atomic.AtomicLong import scala.collection.mutable import scala.util.{Failure, Success, Try} import com.google.protobuf.util.JsonFormat import io.grpc.inprocess.InProcessChannelBuilder -import org.scalatest.BeforeAndAfterAll +import org.scalatest.{BeforeAndAfterAll, BeforeAndAfterEach} import org.scalatest.funsuite.{AnyFunSuite => ConnectFunSuite} // scalastyle:ignore funsuite import org.apache.spark.connect.proto @@ -55,7 +56,11 @@ import org.apache.spark.sql.types._ * `connector/connect/server` module */ // scalastyle:on -class PlanGenerationTestSuite extends ConnectFunSuite with BeforeAndAfterAll with Logging { +class PlanGenerationTestSuite + extends ConnectFunSuite + with BeforeAndAfterAll + with BeforeAndAfterEach + with Logging { // Borrowed from SparkFunSuite private val regenerateGoldenFiles: Boolean = System.getenv("SPARK_GENERATE_GOLDEN_FILES") == "1" @@ -102,8 +107,12 @@ class PlanGenerationTestSuite extends ConnectFunSuite with BeforeAndAfterAll wit val client = SparkConnectClient( proto.UserContext.newBuilder().build(), InProcessChannelBuilder.forName("/dev/null").build()) - val builder = SparkSession.builder().client(client) - session = builder.build() + session = + new SparkSession(client, cleaner = SparkSession.cleaner, planIdGenerator = new AtomicLong) + } + + override protected def beforeEach(): Unit = { + session.resetPlanIdGenerator() } override protected def afterAll(): Unit = { @@ -361,7 +370,8 @@ class PlanGenerationTestSuite extends ConnectFunSuite with BeforeAndAfterAll wit } test("apply") { - simple.select(simple.apply("a")) + val stable = simple + stable.select(stable("a")) } test("hint") { @@ -369,7 +379,8 @@ class PlanGenerationTestSuite extends ConnectFunSuite with BeforeAndAfterAll wit } test("col") { - simple.select(simple.col("id"), simple.col("b")) + val stable = simple + stable.select(stable.col("id"), stable.col("b")) } test("colRegex") { diff --git a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/SparkSessionSuite.scala b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/SparkSessionSuite.scala deleted file mode 100644 index 8410073d6ec59..0000000000000 --- a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/SparkSessionSuite.scala +++ /dev/null @@ -1,120 +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.spark.sql - -import io.grpc.Server -import io.grpc.netty.NettyServerBuilder -import java.util.concurrent.TimeUnit -import org.scalatest.BeforeAndAfterEach -import org.scalatest.funsuite.AnyFunSuite // scalastyle:ignore funsuite - -import org.apache.spark.connect.proto -import org.apache.spark.sql.connect.client.{DummySparkConnectService, SparkConnectClient} - -class SparkSessionSuite - extends AnyFunSuite // scalastyle:ignore funsuite - with BeforeAndAfterEach { - - private var server: Server = _ - private var service: DummySparkConnectService = _ - private val SERVER_PORT = 15250 - - private def startDummyServer(port: Int): Unit = { - service = new DummySparkConnectService() - val sb = NettyServerBuilder - .forPort(port) - .addService(service) - - server = sb.build - server.start() - } - - override def beforeEach(): Unit = { - super.beforeEach() - startDummyServer(SERVER_PORT) - } - - override def afterEach(): Unit = { - if (server != null) { - server.shutdownNow() - assert(server.awaitTermination(5, TimeUnit.SECONDS), "server failed to shutdown") - } - } - - test("SparkSession initialisation with connection string") { - val ss = SparkSession - .builder() - .client( - SparkConnectClient - .builder() - .connectionString(s"sc://localhost:$SERVER_PORT") - .build()) - .build() - val plan = proto.Plan.newBuilder().build() - ss.analyze(plan, proto.Explain.ExplainMode.SIMPLE) - assert(plan.equals(service.getAndClearLatestInputPlan())) - } - - private def rangePlanCreator( - start: Long, - end: Long, - step: Long, - numPartitions: Option[Int]): proto.Plan = { - val builder = proto.Relation.newBuilder() - val rangeBuilder = builder.getRangeBuilder - .setStart(start) - .setEnd(end) - .setStep(step) - numPartitions.foreach(rangeBuilder.setNumPartitions) - proto.Plan.newBuilder().setRoot(builder).build() - } - - private def testRange( - start: Long, - end: Long, - step: Long, - numPartitions: Option[Int], - failureHint: String): Unit = { - val expectedPlan = rangePlanCreator(start, end, step, numPartitions) - val actualPlan = service.getAndClearLatestInputPlan() - assert(actualPlan.equals(expectedPlan), failureHint) - } - - test("range query") { - val ss = SparkSession - .builder() - .client( - SparkConnectClient - .builder() - .connectionString(s"sc://localhost:$SERVER_PORT") - .build()) - .build() - - ss.range(10).analyze - testRange(0, 10, 1, None, "Case: range(10)") - - ss.range(0, 20).analyze - testRange(0, 20, 1, None, "Case: range(0, 20)") - - ss.range(6, 20, 3).analyze - testRange(6, 20, 3, None, "Case: range(6, 20, 3)") - - ss.range(10, 100, 5, 2).analyze - testRange(10, 100, 5, Some(2), "Case: range(6, 20, 3, Some(2))") - } - -} diff --git a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/connect/client/SparkConnectClientSuite.scala b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/connect/client/SparkConnectClientSuite.scala index 98dacbcab8919..8e827007950b7 100644 --- a/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/connect/client/SparkConnectClientSuite.scala +++ b/connector/connect/client/jvm/src/test/scala/org/apache/spark/sql/connect/client/SparkConnectClientSuite.scala @@ -26,6 +26,7 @@ import org.scalatest.funsuite.AnyFunSuite // scalastyle:ignore funsuite import org.apache.spark.connect.proto import org.apache.spark.connect.proto.{AnalyzePlanRequest, AnalyzePlanResponse, ExecutePlanRequest, ExecutePlanResponse, SparkConnectServiceGrpc} +import org.apache.spark.sql.SparkSession import org.apache.spark.sql.connect.common.config.ConnectCommon class SparkConnectClientSuite @@ -33,20 +34,23 @@ class SparkConnectClientSuite with BeforeAndAfterEach { private var client: SparkConnectClient = _ + private var service: DummySparkConnectService = _ private var server: Server = _ private def startDummyServer(port: Int): Unit = { - val sb = NettyServerBuilder + service = new DummySparkConnectService + server = NettyServerBuilder .forPort(port) - .addService(new DummySparkConnectService()) - - server = sb.build + .addService(service) + .build() server.start() } + override def beforeEach(): Unit = { super.beforeEach() client = null server = null + service = null } override def afterEach(): Unit = { @@ -104,6 +108,16 @@ class SparkConnectClientSuite } } + test("SparkSession initialisation with connection string") { + val testPort = 16002 + client = SparkConnectClient.builder().connectionString(s"sc://localhost:$testPort").build() + startDummyServer(testPort) + val session = SparkSession.builder().client(client).build() + val df = session.range(10) + df.analyze // Trigger RPC + assert(df.plan === service.getAndClearLatestInputPlan()) + } + private case class TestPackURI( connectionString: String, isCorrect: Boolean, diff --git a/connector/connect/common/src/test/resources/query-tests/queries/alias_string.json b/connector/connect/common/src/test/resources/query-tests/queries/alias_string.json index 1209a4dfb8771..98ea62f986b99 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/alias_string.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/alias_string.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/alias_string.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/alias_string.proto.bin index 1f969506e38ec..6e8467cccde18 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/alias_string.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/alias_string.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.json b/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.json index ba861c077fbcf..b469cbd0a3351 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.proto.bin index 788038972d890..7034d39cd8a57 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/alias_symbol.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/apply.json b/connector/connect/common/src/test/resources/query-tests/queries/apply.json index d53d24efef806..e484781708ebf 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/apply.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/apply.json @@ -1,13 +1,20 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "expressions": [{ "unresolvedAttribute": { - "unparsedIdentifier": "a" + "unparsedIdentifier": "a", + "planId": "0" } }] } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/apply.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/apply.proto.bin index 80cb4ad244ee0..5d5efcead5e1c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/apply.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/apply.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/as_string.json b/connector/connect/common/src/test/resources/query-tests/queries/as_string.json index 501189fbe13a9..d74c9d16a7ffb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/as_string.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/as_string.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/as_string.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/as_string.proto.bin index f433909e126a5..829d6083e094d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/as_string.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/as_string.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.json b/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.json index e2a7d2bb193cb..ca69a743175f0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.proto.bin index c9ad3f8e0c5a5..f7111a4651d92 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/as_symbol.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/coalesce.json b/connector/connect/common/src/test/resources/query-tests/queries/coalesce.json index 34a329f893ae1..cb08412296aa8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/coalesce.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/coalesce.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartition": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/coalesce.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/coalesce.proto.bin index ed1a6ce29fab7..b03e7d58a2bfd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/coalesce.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/coalesce.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/col.json b/connector/connect/common/src/test/resources/query-tests/queries/col.json index aa2c09ce0d756..f3abc8a81affb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/col.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/col.json @@ -1,17 +1,25 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "expressions": [{ "unresolvedAttribute": { - "unparsedIdentifier": "id" + "unparsedIdentifier": "id", + "planId": "0" } }, { "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/col.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/col.proto.bin index 6db0c6bb0b05f..15c4eabb8d505 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/col.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/col.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/colRegex.json b/connector/connect/common/src/test/resources/query-tests/queries/colRegex.json index 90d35213bbbfe..56021594c8811 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/colRegex.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/colRegex.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "2" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/colRegex.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/colRegex.proto.bin index 6503926be7a46..2f3ab10233ef8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/colRegex.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/colRegex.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_add.json b/connector/connect/common/src/test/resources/query-tests/queries/column_add.json index c7c88bdc5d11e..cfa40fac8c6f9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_add.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_add.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_add.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_add.proto.bin index 26ccd472276e8..10b410b5b08b5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_add.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_add.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_alias.json b/connector/connect/common/src/test/resources/query-tests/queries/column_alias.json index 559d7c7b254d5..4fe650db9d3b5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_alias.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_alias.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_alias.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_alias.proto.bin index b05b217b0617b..e9b9076832877 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_alias.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_alias.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_and.json b/connector/connect/common/src/test/resources/query-tests/queries/column_and.json index 1faa3965b12a7..d3f8cd0e73cbc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_and.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_and.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_and.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_and.proto.bin index a566569f29308..241f1a9303b2c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_and.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_and.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_apply.json b/connector/connect/common/src/test/resources/query-tests/queries/column_apply.json index c72cdda0c2999..b203a20a0ea6c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_apply.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_apply.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_apply.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_apply.proto.bin index bbc3bacbd9cc1..9e56d5891f503 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_apply.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_apply.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.json b/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.json index 15c6c6cf09354..426fd1fbb7592 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.proto.bin index 4762a9fad8c46..602beafb01cbe 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_as_multi.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.json b/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.json index dff2912f8b6cf..e943c01f26fbe 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.proto.bin index 83592a71e5caf..2952e871f6e65 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_as_with_metadata.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc.json b/connector/connect/common/src/test/resources/query-tests/queries/column_asc.json index 11d2915091c3f..31f3102f77a49 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_asc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_asc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_asc.proto.bin index 56e5c5d207631..ee5bda529c453 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_asc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_asc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.json b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.json index 11d2915091c3f..31f3102f77a49 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.proto.bin index 56e5c5d207631..ee5bda529c453 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_first.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.json b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.json index eac9be9e5ac13..94326e0f6621d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.proto.bin index 21665330de2e0..496fe40192dae 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_asc_nulls_last.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_between.json b/connector/connect/common/src/test/resources/query-tests/queries/column_between.json index 8473a3e7cdaa8..20927b93d8438 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_between.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_between.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_between.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_between.proto.bin index c651f8856bbbd..d03dd02a2f36a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_between.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_between.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.json b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.json index 17431e74d9427..bd3ac671fca33 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.proto.bin index 3517777d8afa3..4815bc7dd1a20 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseAND.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.json b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.json index cfd8e2dfb7f1a..eaa27ffa46164 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.proto.bin index 16ea227007bb0..9cf110da4ad61 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseOR.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.json b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.json index d3e4c326c26ca..c51eb3140c339 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.proto.bin index 2c154418bb7e4..70c61f9620576 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_bitwiseXOR.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_cast.json b/connector/connect/common/src/test/resources/query-tests/queries/column_cast.json index d014ce98803e5..1a1ee5ed4d51a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_cast.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_cast.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_cast.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_cast.proto.bin index 3b3d04193ac01..60e807b4c3507 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_cast.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_cast.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_contains.json b/connector/connect/common/src/test/resources/query-tests/queries/column_contains.json index 862dd8cefa00d..05d6ccf38b367 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_contains.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_contains.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_contains.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_contains.proto.bin index 12a45de9ce601..9c796f9470c31 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_contains.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_contains.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc.json b/connector/connect/common/src/test/resources/query-tests/queries/column_desc.json index f882e4abad250..50efda387ec44 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_desc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_desc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_desc.proto.bin index 3d9b64634d9d7..df2589d8231bc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_desc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_desc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.json b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.json index 707ced41a1620..bed300feea2eb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.proto.bin index 54ae15ef70bef..b8caacc55b9e8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_first.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.json b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.json index f882e4abad250..50efda387ec44 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.proto.bin index 3d9b64634d9d7..df2589d8231bc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_desc_nulls_last.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_divide.json b/connector/connect/common/src/test/resources/query-tests/queries/column_divide.json index 081717618223a..8d71061b151ca 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_divide.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_divide.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_divide.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_divide.proto.bin index 856a75655915a..49b5d8d2590dd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_divide.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_divide.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.json b/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.json index ff39dfa6532a2..92639eeedc67d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.proto.bin index b95d8d3dcd60f..edafc8b1f1f51 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_dropFields.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.json b/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.json index 99edefdc9a430..f4171c2792fbd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.proto.bin index c854a66c726cb..03f41a339f00c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_endsWith.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.json b/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.json index 3481ee46e5a5f..eea1da49bc59e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.proto.bin index d38e1836b3fe7..22de941ad44b0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_eqNullSafe.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_equals.json b/connector/connect/common/src/test/resources/query-tests/queries/column_equals.json index 834afc4dee7ab..7397f4fb46acd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_equals.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_equals.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_equals.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_equals.proto.bin index e8505e38fdca2..e226de59ddcd4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_equals.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_equals.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_geq.json b/connector/connect/common/src/test/resources/query-tests/queries/column_geq.json index aca63fadf09c9..9f24bc251739f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_geq.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_geq.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_geq.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_geq.proto.bin index c0762cef053d9..1c4af866109ab 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_geq.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_geq.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_getField.json b/connector/connect/common/src/test/resources/query-tests/queries/column_getField.json index d68d274a406d3..21d5bb6f23d89 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_getField.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_getField.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_getField.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_getField.proto.bin index eac146d122fb3..c76b69bf5fa4a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_getField.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_getField.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.json b/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.json index 41eb3eadafcb2..e3bfd3d6e842a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.proto.bin index 92083231b141a..9120801100fea 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_getItem.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_gt.json b/connector/connect/common/src/test/resources/query-tests/queries/column_gt.json index 658a17c00ab34..4bb8fb41f249d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_gt.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_gt.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_gt.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_gt.proto.bin index 9304b3dae72cb..44ca37fbb4048 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_gt.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_gt.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.json b/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.json index bc751f0ce1d5a..47c1b63abe319 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.proto.bin index 10226e50caa2f..285400db7daf5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_ilike.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.json b/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.json index 0eb722a08ecc3..f594918ed930a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.proto.bin index 1f96b82d070b9..1030abda5b8c2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_isNaN.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.json b/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.json index bb2403f1d1935..f34d3f4eac552 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.proto.bin index 45574baf87cc3..e8cccdf024934 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_isNotNull.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.json b/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.json index 386ad8898eb03..74e990622a3a7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.proto.bin index 44b48593580a0..8fc24a9e21b38 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_isNull.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isin.json b/connector/connect/common/src/test/resources/query-tests/queries/column_isin.json index 1a990cc085160..d8811a4e780b5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_isin.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_isin.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_isin.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_isin.proto.bin index 9e61c9d26d6bf..365e07f35bb48 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_isin.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_isin.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_leq.json b/connector/connect/common/src/test/resources/query-tests/queries/column_leq.json index 9ea4d99f9b7cf..cda8694c0439e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_leq.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_leq.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_leq.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_leq.proto.bin index 7f62d95ee34b3..e8463292e4040 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_leq.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_leq.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_like.json b/connector/connect/common/src/test/resources/query-tests/queries/column_like.json index 2afab4b03297a..1390451af55ab 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_like.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_like.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_like.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_like.proto.bin index dee7e79301ce8..07382ec1643cb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_like.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_like.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_lt.json b/connector/connect/common/src/test/resources/query-tests/queries/column_lt.json index 019e33cd10640..c927e75de181b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_lt.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_lt.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_lt.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_lt.proto.bin index ff658957ceef3..f4c3a110b126b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_lt.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_lt.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.json b/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.json index 7cbe8a11fd9db..0c5a78eea2dff 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.proto.bin index 461b09b0b8254..55bfeba04ed66 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_modulo.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.json b/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.json index 58ebb2604dac0..8c17581c67d1c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.proto.bin index 4ca350de10b14..8fd1b3941d1f7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_multiply.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_not.json b/connector/connect/common/src/test/resources/query-tests/queries/column_not.json index 39417760083b7..2f873196ba1d0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_not.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_not.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_not.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_not.proto.bin index 59a14a4019851..19609b6ee85a5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_not.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_not.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.json b/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.json index de8f07fb47869..589d57a18b94b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.proto.bin index 006450915a3e3..cdf0b4290e61e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_not_equals.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_or.json b/connector/connect/common/src/test/resources/query-tests/queries/column_or.json index 091280b2ae6f5..ae1424f763feb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_or.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_or.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_or.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_or.proto.bin index aaf78e293e9a0..69f219e938a4e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_or.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_or.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.json b/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.json index 490766a88d793..e53403db41cd0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.proto.bin index 7e2b6996c70da..7dd56baf04213 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_rlike.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_star.json b/connector/connect/common/src/test/resources/query-tests/queries/column_star.json index ecb84fee1745f..ef88067a7a4c1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_star.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_star.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_star.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_star.proto.bin index bde97f5f8ef6c..3ca04d082d766 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_star.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_star.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.json b/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.json index 26372cb4e5014..e1159b5673dba 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.proto.bin index 63c5c7f5330dc..af744b7d6b47c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_star_with_target.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.json b/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.json index fe66f718e23ce..431e13d818639 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.proto.bin index dd10f51fcdd24..fa1132c73de7b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_startsWith.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_substr.json b/connector/connect/common/src/test/resources/query-tests/queries/column_substr.json index 6c074decbba60..3b02117cc6e5b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_substr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_substr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_substr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_substr.proto.bin index e050495220d5e..636a46a480626 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_substr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_substr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.json b/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.json index 79a42858f09c1..d15c2941ee1bd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.proto.bin index 794972c95bf71..f5716427588ed 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_subtract.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.json b/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.json index 5e39ebe6074b2..0db558e49e38c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.proto.bin index 7ff0a7c8ad513..66343bea4e29b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_unary_minus.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.json b/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.json index 8c0004a6abb49..db2ceccfd22ab 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.proto.bin index 51e8c7ce37e19..031c3683c5e6d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_when_otherwise.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_withField.json b/connector/connect/common/src/test/resources/query-tests/queries/column_withField.json index ba9d22bcc5d11..86b9396a4e13f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/column_withField.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/column_withField.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/column_withField.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/column_withField.proto.bin index 33be23b4c61c3..a413740fa5054 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/column_withField.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/column_withField.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.json b/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.json index bac0eebf8ee83..fecba18096bb3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.proto.bin index b86654bb57fe9..ff6d2f3b4a7a0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/crossJoin.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/cube_column.json b/connector/connect/common/src/test/resources/query-tests/queries/cube_column.json index 49016593a34c5..5b9709ff06576 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/cube_column.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/cube_column.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/cube_column.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/cube_column.proto.bin index c706144de5959..d46e40b39dcfe 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/cube_column.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/cube_column.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/cube_string.json b/connector/connect/common/src/test/resources/query-tests/queries/cube_string.json index 49016593a34c5..5b9709ff06576 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/cube_string.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/cube_string.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/cube_string.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/cube_string.proto.bin index c706144de5959..d46e40b39dcfe 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/cube_string.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/cube_string.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/describe.json b/connector/connect/common/src/test/resources/query-tests/queries/describe.json index c3e9ded313340..d767db5241f45 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/describe.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/describe.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "describe": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/describe.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/describe.proto.bin index a39ee7fc80ce5..8a2117e519f6a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/describe.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/describe.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/distinct.json b/connector/connect/common/src/test/resources/query-tests/queries/distinct.json index 094caa1420806..ae796b520353c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/distinct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/distinct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "deduplicate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/distinct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/distinct.proto.bin index 4892a7c71625b..07430c4383106 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/distinct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/distinct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.json b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.json index 094caa1420806..ae796b520353c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "deduplicate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.proto.bin index 4892a7c71625b..07430c4383106 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.json b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.json index e55248a383efa..e72e23c86caf0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "deduplicate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.proto.bin index 51d419de57097..c8e3885fbf804 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_array.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.json b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.json index d2a9e0414187f..754cecac4b256 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "deduplicate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.proto.bin index 57c97010bddbc..1a2d635e58e56 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_names_seq.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.json b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.json index 7b2468c70a69e..c4a8df30c5867 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "deduplicate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.proto.bin index 496dc9e451642..719a373c2e384 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/dropDuplicates_varargs.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.json b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.json index 275f15a04e162..6a8546d9326c4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "drop": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.proto.bin index 65d2cac04cc6f..f4585af804ae6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_column.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.json b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.json index 96d50cef533ac..69c31ec585859 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "drop": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.proto.bin index 29ae3de0fcca4..c085f69fc544a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/drop_multiple_strings.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.json b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.json index 454bb1744b85c..7f4cd227186e9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "drop": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.proto.bin index 3cf2a6b652ada..37d71479cdb84 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_column.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.json b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.json index 812fc60d9d2f1..7e4c4e8feb1b5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "drop": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.proto.bin index a4146717a0bf2..9d704de48c888 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/drop_single_string.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/except.json b/connector/connect/common/src/test/resources/query-tests/queries/except.json index d88134dc26893..6544e03f6e10d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/except.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/except.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/except.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/except.proto.bin index 64fcb2a45c9d7..0e9efea2f94d0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/except.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/except.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.json b/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.json index dfb04bf53a18f..e77b583b9c287 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.proto.bin index cc746e54e0020..19f9231eb2674 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/exceptAll.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/filter.json b/connector/connect/common/src/test/resources/query-tests/queries/filter.json index eeb5c26954183..1046e1262150e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/filter.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/filter.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "filter": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/filter.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/filter.proto.bin index adaec008b76ed..069171ead3233 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/filter.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/filter.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.json b/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.json index 77635b5117221..a2c49ec98c611 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "filter": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.proto.bin index e7ddb9c54fa0b..56e5be565435b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/filter_expr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_abs.json b/connector/connect/common/src/test/resources/query-tests/queries/function_abs.json index 16002c3f4d102..13df3437ddabe 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_abs.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_abs.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_abs.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_abs.proto.bin index 3f56daaa382cd..86cfbc09a8f91 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_abs.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_abs.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_acos.json b/connector/connect/common/src/test/resources/query-tests/queries/function_acos.json index 01f3eb936eba0..7506c0f6cb630 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_acos.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_acos.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_acos.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_acos.proto.bin index e42dfe0c28d9a..cc6a279cb188e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_acos.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_acos.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.json index d3af379493c3a..6a83b4ab008bc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.proto.bin index 5d6e171aee599..e16ed2ba92e3f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_acosh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.json b/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.json index 2a9a5f176401f..b1b2e78a08435 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.proto.bin index b257a77e26b68..6abacc9cc2b40 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_add_months.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.json b/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.json index 833350ad0b399..3116837aeb876 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.proto.bin index 5fec870563f77..f97843e086a58 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_aggregate.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.json b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.json index 069fe54c6dc6a..5579faf119647 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.proto.bin index 1c06f9004475a..bac82f670b298 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.json b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.json index fbdc69cd793ce..851862082ca04 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.proto.bin index 12f2ec5362d87..fd61420fd1e45 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_approx_count_distinct_rsd.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array.json index 7c75a9def64ee..20fe495bb9bf4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array.proto.bin index 0a5b09e8b995d..2b679eb4c6db1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.json index 7e2a7e300a28f..cabd44c063dec 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.proto.bin index 9832323a527bd..76f2f0255bf25 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_append.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.json index 4c81b0c8b3881..c3ebf313190c2 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.proto.bin index 28a30d579b252..949d66cb951f0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_compact.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.json index 6e43c2768db70..a362d66d9d64d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.proto.bin index cdb20044cc990..d8764f60364c2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_contains.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.json index c512dd362c468..d38f4194bcd2b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.proto.bin index 5adda1b1f4537..e6359c074bf23 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_distinct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.json index f27cce411990e..17d50c87161d6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.proto.bin index a7a06cb7ec3e9..692511b2f74a6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_except.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.json index 6c6b95933933e..f4540edbf4108 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.proto.bin index c18114edbd01b..6e2178ad124e9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_insert.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.json index 5149f675e8cbc..1b95a6724f86d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.proto.bin index bab4ead039aea..67fb497cf270c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_intersect.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.json index 8dcaad72daf41..94e8c176cefbf 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.proto.bin index db6dc1adff84f..fbab1b208605d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.json index bbad2109ff273..ad580c33e476c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.proto.bin index 0604d19d0c926..e3fb6b3bf67c3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_join_with_null_replacement.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.json index 1270be928a925..ba67984758a5a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.proto.bin index f96db47323ae0..f7a98c08cd175 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_max.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.json index e36f2275c4f0e..a342ae18f9ef7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.proto.bin index 4b01ad396748a..02cfdfeb215d6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_min.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.json index d13d31d467b8e..4c212cb028273 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.proto.bin index c26fbff6f0697..4ef2b11273f25 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_position.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.json index 99fa5f3a1bb72..8c562247714a4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.proto.bin index 68b37cdbfbe95..95e2872ad77bd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_remove.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.json index b445ce38ee031..c9d9f1f9ca79d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.proto.bin index 186b8027beac1..e370db16e977c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_repeat.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.json index 2e851777cbff5..406dc54c8cd2f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.proto.bin index da38e74e5db28..2074caae16384 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.json index df8c94c62573e..95be74d0b4c81 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.proto.bin index 3217e0b59d17d..c1e2363f0fdab 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_sort_with_comparator.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.json b/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.json index f6e83f316c733..7d54079cdb47e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.proto.bin index 951d568139922..fc3d9d7cd0fd1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_array_union.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.json b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.json index 94c87c477dbfa..ce1d288e00d78 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.proto.bin index 771dd700f13fd..216f306507d40 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_overlap.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.json b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.json index 80d9c8c85c2ce..14769082725f1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.proto.bin index ea88aa580414f..609f52db32478 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_arrays_zip.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc.json b/connector/connect/common/src/test/resources/query-tests/queries/function_asc.json index 9d963d55ec18a..30740c81ba412 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_asc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_asc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_asc.proto.bin index 8236485b4f61d..7c5bc4213a6f8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_asc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_asc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.json b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.json index 9d963d55ec18a..30740c81ba412 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.proto.bin index 8236485b4f61d..7c5bc4213a6f8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_first.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.json b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.json index cf6adf0cc3646..b8bbbb73544f4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.proto.bin index 8292c9d24d71f..1eb6f88cac874 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_asc_nulls_last.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.json index 5d815ff83bfe3..3c4dcb70fead3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.proto.bin index 26505e9591218..5989bd3b5c606 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ascii.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asin.json b/connector/connect/common/src/test/resources/query-tests/queries/function_asin.json index fd61c2ffbf1cb..4bf89be753458 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_asin.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_asin.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asin.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_asin.proto.bin index 3b4b86cc15b93..737ad789da268 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_asin.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_asin.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.json index 6d41470ca615a..238571b0231c6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.proto.bin index c125ca3114aa2..01ea4675b22eb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_asinh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.json b/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.json index 35312d1fbb3c0..5520b70a0250b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.proto.bin index b88dab9c58ed7..6992604efe1b3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_assert_true_with_message.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atan.json b/connector/connect/common/src/test/resources/query-tests/queries/function_atan.json index bab8ef27ec3f5..3ae4e7ef188ec 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_atan.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_atan.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atan.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_atan.proto.bin index e946720aad4c0..b932086941f45 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_atan.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_atan.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.json b/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.json index 04a3490df12df..7d08116c40ae6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.proto.bin index 3271fecbf8126..372ae8358494e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_atan2.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.json index 2ae1d25ed06ef..8daec8813917e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.proto.bin index 89c594f4baa3e..0aa2f3527ae9c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_atanh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_avg.json b/connector/connect/common/src/test/resources/query-tests/queries/function_avg.json index f9e582b9219ff..b433f1ea89c29 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_avg.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_avg.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_avg.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_avg.proto.bin index 24bbef4be5e3a..9d9bd296dbdda 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_avg.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_avg.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_base64.json b/connector/connect/common/src/test/resources/query-tests/queries/function_base64.json index fc8e388be9ba1..97739dca283ef 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_base64.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_base64.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_base64.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_base64.proto.bin index bcc329dc78b42..fc854d974752b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_base64.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_base64.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bin.json b/connector/connect/common/src/test/resources/query-tests/queries/function_bin.json index 658990a6f9076..304e56504bad9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_bin.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_bin.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bin.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_bin.proto.bin index d499f54e72176..e8d55fb8d6149 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_bin.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_bin.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.json b/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.json index 771ac0fdc021c..df21871cb535d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.proto.bin index 52c0ca8df49e3..860c2eaec0e85 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_bit_length.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.json b/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.json index c350c65312dd4..7ddf73253e0a3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.proto.bin index 9acca430f5f73..bfaefb2a20075 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_bitwise_not.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bround.json b/connector/connect/common/src/test/resources/query-tests/queries/function_bround.json index c908004921242..585a0befb224d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_bround.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_bround.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bround.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_bround.proto.bin index 90b949a0a680f..8625ccb1a58f1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_bround.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_bround.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.json b/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.json index 4ec5fb5f27b4f..971660144a5bc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.proto.bin index 4ccecb3d59c2d..1b389401f15e6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_bucket.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.json index 5f3753452ea83..5a9961ab47f55 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.proto.bin index ce56aea7a5693..3761deb1663a2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.json index 94a61a5fd05f5..bda5e85924c30 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.proto.bin index 4d3b25dada472..8db402ac167e0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ceil_scale.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.json b/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.json index aa36f12c05405..497922b5df75c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.proto.bin index 36b892c647638..ec871018489c2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_coalesce.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_col.json b/connector/connect/common/src/test/resources/query-tests/queries/function_col.json index 63988117f4311..0420a3d12f6fe 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_col.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_col.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_col.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_col.proto.bin index 4a4eb9b59869b..e113880f31b77 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_col.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_col.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.json b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.json index 109392a141e8a..c5bae4baef352 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.proto.bin index b96919003c0db..e3827b9f650ae 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_list.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.json b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.json index fa06e613e75b6..615386d050e14 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.proto.bin index dda4b4f0ff251..5fb97f27d25b6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_collect_set.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_concat.json b/connector/connect/common/src/test/resources/query-tests/queries/function_concat.json index c251769297701..4a053d9c3c354 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_concat.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_concat.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_concat.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_concat.proto.bin index 293ab94e506d0..e53eb7a75b8a2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_concat.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_concat.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.json b/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.json index bd88b533d6a9f..b9ba89b42185c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.proto.bin index 7da2b07049312..2fbc4f7090448 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_concat_ws.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_conv.json b/connector/connect/common/src/test/resources/query-tests/queries/function_conv.json index 6ea114c4511df..c6734936bfcd1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_conv.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_conv.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_conv.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_conv.proto.bin index 9dd42bd34c0d5..373b997b79240 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_conv.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_conv.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_corr.json b/connector/connect/common/src/test/resources/query-tests/queries/function_corr.json index d1fc5417f8d2e..6fadb0385622b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_corr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_corr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_corr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_corr.proto.bin index d8bb18b3c064b..fdeeb4fd12d19 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_corr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_corr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cos.json b/connector/connect/common/src/test/resources/query-tests/queries/function_cos.json index f53521db9c287..f7072dff03404 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_cos.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_cos.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cos.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_cos.proto.bin index d21e15b0aa083..09fd198b097c0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_cos.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_cos.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.json index 151c7f835eb87..3bcab61d37a0d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.proto.bin index 202a4ba8a8fe5..54d5da8fabfa6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_cosh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cot.json b/connector/connect/common/src/test/resources/query-tests/queries/function_cot.json index 2100af7d09ea2..62ce963fa8737 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_cot.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_cot.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cot.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_cot.proto.bin index d26a2d30cca62..e79c32660a772 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_cot.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_cot.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_count.json b/connector/connect/common/src/test/resources/query-tests/queries/function_count.json index 77eff56f6ef48..126a0ca242c52 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_count.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_count.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_count.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_count.proto.bin index 97667ca836022..6c87a809ad0c4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_count.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_count.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.json b/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.json index d33f9d958e179..eb211ceb239aa 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.proto.bin index a4582f9801320..591e2300ec689 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_countDistinct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.json b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.json index a1227d5b54a4f..3c4df70a5fbfc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.proto.bin index ffcfae52acb8f..4a7202f15e768 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_pop.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.json index c7d6ddf1273ec..7c723069e4671 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.proto.bin index c830d80acc3e1..ebff687730e35 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_covar_samp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.json b/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.json index ecb8f964a8485..1892a9af85d97 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.proto.bin index ceb4e60fa912b..54ad14dedae4e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_crc32.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_csc.json b/connector/connect/common/src/test/resources/query-tests/queries/function_csc.json index ceb722b1b1f14..88504ed9c5280 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_csc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_csc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_csc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_csc.proto.bin index 147af78100ddb..0ed5022a73adf 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_csc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_csc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.json b/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.json index 4e22d94aa3057..ac48841199075 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.proto.bin index fe9c87a0a03e5..7578245aabe3a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_cume_dist.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.json b/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.json index 0c4d080f71dcc..6dab8c39d626c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.proto.bin index ef6fcd56b1795..f32c3f541c4c7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_current_date.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.json index 48e5b84689c2b..16af5eb9ba084 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.proto.bin index b4f0e65d307ca..5a1f3de6c3a9a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_current_timestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.json b/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.json index 6453851f7bcd5..f81ad3335242c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.proto.bin index ce4b1a6e8bb82..f4dbc16b05c1d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_date_add.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.json b/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.json index 8a65dbcb016e6..9b3d469ed4e98 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.proto.bin index f1322a228e998..7226c20974b2a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_date_format.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.json b/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.json index 90d9ea0f7adf1..f1dde0902a20a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.proto.bin index fe779f24a10bf..43b630c27ed45 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_date_sub.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.json b/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.json index a1cadc2b2699a..363da9b9b9006 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.proto.bin index 7fcaf3be6bd48..f037fb8d34a56 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_date_trunc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.json b/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.json index 4ab99ffbbed0f..b5ef560486d0d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.proto.bin index 0f567ba2a9408..02e917b406838 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_datediff.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.json b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.json index 4e9156323cb5f..3e453c1f7a652 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.proto.bin index d0a12815c2731..3a2973e21e5a0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofmonth.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.json b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.json index b8ff1c59613ad..74715de151e77 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.proto.bin index 9a4d4cc7735d5..fceea203c790e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofweek.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.json b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.json index 047142c10b0e5..d23c6790a47dd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.proto.bin index 5d8efe15f6684..a526b449ae0a4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_dayofyear.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_days.json b/connector/connect/common/src/test/resources/query-tests/queries/function_days.json index 8fb62b4a2e4b9..9e20c48729a30 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_days.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_days.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_days.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_days.proto.bin index ecfa97f445c9c..b0a8472f8c4ff 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_days.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_days.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_decode.json b/connector/connect/common/src/test/resources/query-tests/queries/function_decode.json index 67ec30bf4c3c3..6be60808e64f3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_decode.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_decode.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_decode.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_decode.proto.bin index 952b5c6ed04c5..18b8bbcf6a01d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_decode.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_decode.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.json b/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.json index 152c92cbe6cbd..e096b07e4dc6e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.proto.bin index 772d2ee9d3b12..e2d264bb2e108 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_degrees.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.json b/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.json index 3cc81b32613fe..46c5e1eaddfc0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.proto.bin index 2df47f4ce657b..4597e63be8379 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_dense_rank.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc.json b/connector/connect/common/src/test/resources/query-tests/queries/function_desc.json index 8f1d61d70ac8d..0841b33b8fb69 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_desc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_desc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_desc.proto.bin index a1237f80486f1..bd549431a832c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_desc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_desc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.json b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.json index fa0654bbda7d2..683de2af2388a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.proto.bin index 22de37fb20f4b..b46e09d6ef3d1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_first.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.json b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.json index 8f1d61d70ac8d..0841b33b8fb69 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.proto.bin index a1237f80486f1..bd549431a832c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_desc_nulls_last.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.json b/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.json index a037f4155e2a1..ef5551440934c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.proto.bin index ceb7df30178c7..993818c6cb4bf 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_element_at.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_encode.json b/connector/connect/common/src/test/resources/query-tests/queries/function_encode.json index 1f3767de7c853..92e95f2c946d0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_encode.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_encode.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_encode.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_encode.proto.bin index e46a529ccf4d1..9644825af470b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_encode.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_encode.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_exists.json b/connector/connect/common/src/test/resources/query-tests/queries/function_exists.json index abf4410f76ff7..76d107092ae1e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_exists.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_exists.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_exists.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_exists.proto.bin index edd91a6c3415d..27fbc03c69880 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_exists.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_exists.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_exp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_exp.json index a563d4dfbe52b..d317efef75eee 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_exp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_exp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_exp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_exp.proto.bin index 290c68a7f1f8f..7def20c94df00 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_exp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_exp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_explode.json b/connector/connect/common/src/test/resources/query-tests/queries/function_explode.json index 4f8614806c10e..35ad40ccdd04f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_explode.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_explode.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_explode.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_explode.proto.bin index c95b243aba775..9c15f942bb11d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_explode.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_explode.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.json b/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.json index 3ac00c249959f..efd7f4b524d47 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.proto.bin index 151dce8fff696..9f2cf9554dd15 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_explode_outer.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.json b/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.json index 7d18209a0f7ca..d425a6de709b7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.proto.bin index 09ddfe1534312..3c310cb04ce3d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_expm1.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_expr.json b/connector/connect/common/src/test/resources/query-tests/queries/function_expr.json index 30c40ef354c91..99c69b8e8905b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_expr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_expr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_expr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_expr.proto.bin index d0ef70d31e7b8..2e59d436bc811 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_expr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_expr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.json b/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.json index a2f3f83141c13..7f13a10480915 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.proto.bin index 15d31d6074021..ac776eb60d2b0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_factorial.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_filter.json b/connector/connect/common/src/test/resources/query-tests/queries/function_filter.json index 687f6c0bc23e6..f6b565324b8ba 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_filter.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_filter.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_filter.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_filter.proto.bin index 85831fc0f716a..a53c554598662 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_filter.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_filter.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.json b/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.json index 51ad29afbb696..1d9667c88901f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.proto.bin index a378a54db7faa..5b7db291cc37f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_filter_with_pair_input.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_first.json b/connector/connect/common/src/test/resources/query-tests/queries/function_first.json index e483363cec528..dc33bad3c506a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_first.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_first.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_first.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_first.proto.bin index a52b2870750f1..cb029dfd26be9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_first.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_first.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.json b/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.json index 88b318c79acb5..32da97271d2dd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.proto.bin index 36f77dcb07398..e6bb018a37005 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_flatten.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_floor.json b/connector/connect/common/src/test/resources/query-tests/queries/function_floor.json index 02607b93e4762..78924f5f33627 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_floor.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_floor.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_floor.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_floor.proto.bin index 3e9ccb0b2a8dc..b52696ca4d00a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_floor.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_floor.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.json b/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.json index fd092a4e07eb0..394621e4dd314 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.proto.bin index c03a3ceb0861a..ee0665bab644c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_floor_scale.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_forall.json b/connector/connect/common/src/test/resources/query-tests/queries/function_forall.json index c63c5b5897ae5..93134aba0fa9c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_forall.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_forall.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_forall.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_forall.proto.bin index a515a03d99597..3199c758c04ac 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_forall.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_forall.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.json b/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.json index 89b9807f7a899..daa648c0a599e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.proto.bin index f4263f97b4955..81e2c4d5fd54d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_format_number.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.json b/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.json index c23894d1bd15a..798e79e6618f5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.proto.bin index 8a01afa326f34..8acd3b619b41e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_from_csv.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.json b/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.json index b86b8c129605e..ddfa91abca05e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.proto.bin index 23d781bbb92a7..ad95d0f2b343d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_from_json.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.json b/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.json index e6bb43f962822..81d6608adb18f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.proto.bin index 16125102a333d..b1c34caaf62f0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_from_unixtime.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.json index 8345dfbb6ecf6..5d63fd829f302 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.proto.bin index 934b8465135a2..34bf9c64f3a97 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_from_utc_timestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_get.json b/connector/connect/common/src/test/resources/query-tests/queries/function_get.json index 0980e6fbdca66..7a2a89447c079 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_get.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_get.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_get.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_get.proto.bin index 11f56f6a85aab..be40df955a407 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_get.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_get.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.json b/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.json index 1e2771d53dd31..17adf9230a6eb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.proto.bin index b3dc06c1d8f6b..08ad8f4f91bad 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_get_json_object.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.json b/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.json index 80d411803e712..bf5d50edec84f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.proto.bin index 3f8f3a5e37d9f..44d9d5f8cfb2d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_greatest.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hash.json b/connector/connect/common/src/test/resources/query-tests/queries/function_hash.json index 926ca2716c86a..6ef504a006457 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_hash.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_hash.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hash.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_hash.proto.bin index ef8fe3f1908c9..284700c4c5ea9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_hash.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_hash.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hex.json b/connector/connect/common/src/test/resources/query-tests/queries/function_hex.json index 051304a992a14..af9d0dd298277 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_hex.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_hex.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hex.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_hex.proto.bin index a5961db213381..9d8c3b5e23584 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_hex.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_hex.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hour.json b/connector/connect/common/src/test/resources/query-tests/queries/function_hour.json index b2a3ae643813d..2621b9f81913c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_hour.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_hour.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hour.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_hour.proto.bin index 265086f56fee8..6cdb50364c133 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_hour.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_hour.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hours.json b/connector/connect/common/src/test/resources/query-tests/queries/function_hours.json index 4cccc0eef4771..a72a8656362fd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_hours.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_hours.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hours.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_hours.proto.bin index 17cb707448a94..6e8203b89e320 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_hours.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_hours.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.json b/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.json index 3e64ad01515ff..2d0d6be0164bc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.proto.bin index 4250484e005d4..3ad07a2a1ee45 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_hypot.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.json b/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.json index 14dd59387b152..896bb3d0209da 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.proto.bin index 1c7822a645d5f..72df35bd9b387 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_initcap.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_inline.json b/connector/connect/common/src/test/resources/query-tests/queries/function_inline.json index 1e55f7680a2e5..4abdac736d0fe 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_inline.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_inline.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_inline.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_inline.proto.bin index a0210b7cfc170..261e28e3acaa8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_inline.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_inline.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.json b/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.json index a89cbd96e213f..d74ee83eeff3e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.proto.bin index cc316078c3afd..d757e5afe3050 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_inline_outer.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.json b/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.json index 9d3c651874a06..47f2e461eba46 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.proto.bin index 4d773db4952f6..c3c6414d5d881 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_input_file_name.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.json b/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.json index 0eb722a08ecc3..f594918ed930a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.proto.bin index 1f96b82d070b9..1030abda5b8c2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_isnan.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.json b/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.json index 3d51a2f8748a6..7443fc97f42cf 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.proto.bin index 8abf3ceadc189..3d1fbd4dedfe7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_isnull.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.json b/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.json index bcded73e4f938..32de63452c364 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.proto.bin index 9b908290bbd2d..e51be42b38d34 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_json_tuple.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.json b/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.json index 0d987d1252eb3..7399d7a6da388 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.proto.bin index ea0ec7f993b22..848a4842e2462 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_kurtosis.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lag.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lag.json index ee529f00dc52c..dd1cba376f3c7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lag.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lag.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lag.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lag.proto.bin index 908b872ec53a9..7fd85861fb8c8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lag.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lag.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_last.json b/connector/connect/common/src/test/resources/query-tests/queries/function_last.json index 428660970ab2c..f26e5887ed527 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_last.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_last.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_last.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_last.proto.bin index e14ee792a6c2a..69221737be671 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_last.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_last.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.json b/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.json index 21e5d982c608c..2cb1635caf47e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.proto.bin index c211151c0a3df..1afb5c02ae347 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_last_day.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lead.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lead.json index 8c38eec6daf8d..ef76586d381dd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lead.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lead.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lead.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lead.proto.bin index 45f9e784037f8..9bcdcdb3617a9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lead.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lead.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_least.json b/connector/connect/common/src/test/resources/query-tests/queries/function_least.json index 1c83d8187382c..403531c9f6958 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_least.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_least.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_least.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_least.proto.bin index 9533cf00cf40c..c9ead802a9616 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_least.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_least.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_length.json b/connector/connect/common/src/test/resources/query-tests/queries/function_length.json index 9c9ed8a6c60c7..f2c3c69255897 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_length.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_length.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_length.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_length.proto.bin index c2d1436785058..a14f94085b3b6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_length.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_length.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.json b/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.json index 8220a56ba3ff3..10caaf184fee5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.proto.bin index 49cdc5adc4fb0..75b48541b7663 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_levenshtein.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lit.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lit.json index 2ca89e900b8d2..3cb1f421207c9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lit.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lit.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lit.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lit.proto.bin index 2644023b3725a..9149628d7a331 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lit.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lit.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.json index 4c0ae1e1b5aa2..68281d2e6d9d1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.proto.bin index f793457110fce..b1a9e70c7c802 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_localtimestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_locate.json b/connector/connect/common/src/test/resources/query-tests/queries/function_locate.json index bbf2ef9480dce..7939fdd2c7559 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_locate.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_locate.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_locate.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_locate.proto.bin index b1677c5d73a95..cc7ced9957a52 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_locate.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_locate.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.json b/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.json index 996107c534cfd..269f39701608a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.proto.bin index f2ab262aaaa89..162ab0108c132 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_locate_with_pos.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log.json b/connector/connect/common/src/test/resources/query-tests/queries/function_log.json index b9628776cbbcc..1b2d0ed0b1447 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_log.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_log.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_log.proto.bin index 537849aed11c1..548fb480dd27e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_log.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_log.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log10.json b/connector/connect/common/src/test/resources/query-tests/queries/function_log10.json index 6aa99f1521a9c..13292d83c4727 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_log10.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_log10.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log10.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_log10.proto.bin index f508b2aeebdaa..22d4655a6efbd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_log10.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_log10.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.json b/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.json index 359ab79adf3f3..4e9e6847c3c36 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.proto.bin index f1b7134a1d9c6..9a72c377b0cc4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_log1p.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log2.json b/connector/connect/common/src/test/resources/query-tests/queries/function_log2.json index ade59f2f866c0..ec29e154a0e1d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_log2.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_log2.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log2.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_log2.proto.bin index a7fec7a802f57..34e3780650540 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_log2.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_log2.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.json b/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.json index 185d36b202d8f..6bc2a4ec3335a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.proto.bin index 172793b7d465b..2e64e15ed5555 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_log_with_base.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lower.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lower.json index 34693974e1a42..f7fe5beba2c02 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lower.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lower.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lower.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lower.proto.bin index e3022e48ebec3..7c736d93f7729 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lower.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lower.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.json index 7d722e655b739..b9f3e6700bfa4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.proto.bin index 71f692f5059dc..470ab1cc44add 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.json b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.json index 0bd0d27b0d1f7..aeb39ba09ad20 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,bytes:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.proto.bin index 25d14fd459fcb..b4acebb394c7a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_lpad_binary.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.json index a5c4b69cbef01..dd3b459520221 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.proto.bin index 5b78a82e3468c..162b6a7337bb9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.json index 266ccfa36ceaa..3c4825792dc3c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.proto.bin index c842be406c87d..13455d7091e9f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ltrim_with_pattern.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.json b/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.json index 33c1bbcba65ef..a363298dd123a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.proto.bin index 8eff6951ba8c8..0526825fccade 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_make_date.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map.json index 3f2bb1cf1101d..ca9d3bf2bcc71 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map.proto.bin index a774137b38c89..229a48b75131d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.json index 2a1369806c5b8..f56f6cee20ab0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.proto.bin index 2b03aedd396a8..0a76d3a1193ea 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_concat.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.json index b7f9c2b1b6bd2..56833f9651023 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.proto.bin index 6ae21121eb765..e517479020e16 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_contains_key.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.json index 2cb5a2af142f2..0226506545010 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.proto.bin index f8e5894ffe56c..f1451d4ad7ba4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_entries.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.json index d49f546bedc70..5099377a52a06 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.proto.bin index cff017d65eb5d..fac64e79a5bf0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_filter.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.json index 9a999a689ff7a..1eb1f7d2ef066 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.proto.bin index 1cc02430683a0..f5333b1c882bc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_arrays.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.json index 0b4983881f0d1..399ba8d1021bf 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.proto.bin index 6ef02d0282717..2938c84f77116 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_from_entries.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.json index 3719473dfe785..5af013295cd9f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.proto.bin index ed11768367a2f..ee19968bacc2c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_keys.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.json index b935f371cc45b..3c5eb651801dc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.proto.bin index df3bf18c8f2ef..4cd7c488ada48 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.json b/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.json index e9206324ed9d9..9d035545eb313 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.proto.bin index 28ed3380aebf5..f14eb1a3c93d3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_map_zip_with.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_max.json b/connector/connect/common/src/test/resources/query-tests/queries/function_max.json index 2aba75d43377a..b23dd9d14c643 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_max.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_max.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_max.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_max.proto.bin index 34d523d28b830..788c9539b5767 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_max.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_max.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.json b/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.json index dff4f19d5b684..da311e340cc50 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.proto.bin index ae2694bd057b5..284c2453af8bd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_max_by.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_md5.json b/connector/connect/common/src/test/resources/query-tests/queries/function_md5.json index 8147dabc97cb7..e8718594b0be3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_md5.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_md5.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_md5.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_md5.proto.bin index 4a962d74d3579..d3ec7c26a2ede 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_md5.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_md5.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_median.json b/connector/connect/common/src/test/resources/query-tests/queries/function_median.json index f09852dc5e320..7331454b9ecb0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_median.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_median.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_median.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_median.proto.bin index 9e68ef19aae2b..59533e5be5992 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_median.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_median.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_min.json b/connector/connect/common/src/test/resources/query-tests/queries/function_min.json index 35ab6361cdf8e..1b7266b6774e4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_min.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_min.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_min.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_min.proto.bin index aa820535cfb1f..b82f4c5309222 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_min.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_min.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.json b/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.json index 84a56f69c256f..d2478f5e81abe 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.proto.bin index a746bab538944..ddc642b95000c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_min_by.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_minute.json b/connector/connect/common/src/test/resources/query-tests/queries/function_minute.json index 12f54f6cf58a4..7c749cdff82f5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_minute.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_minute.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_minute.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_minute.proto.bin index cda3703a46e16..e81b7dad85331 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_minute.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_minute.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_mode.json b/connector/connect/common/src/test/resources/query-tests/queries/function_mode.json index 257a1e6ba7d13..8e8183e9e0883 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_mode.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_mode.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_mode.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_mode.proto.bin index d7fb046953eb4..dca0953a387b1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_mode.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_mode.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.json b/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.json index e4caa30e4efe4..0a14f1008976e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.proto.bin index 04cdd9f2590a6..724ce3ac6904c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_monotonically_increasing_id.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_month.json b/connector/connect/common/src/test/resources/query-tests/queries/function_month.json index 8065be8dc7322..7ea1e5d0375e9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_month.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_month.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_month.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_month.proto.bin index a4637b35831e1..b97100a6fe2ec 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_month.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_month.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months.json b/connector/connect/common/src/test/resources/query-tests/queries/function_months.json index 189def244d2f0..278bab76a6544 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_months.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_months.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_months.proto.bin index 9f6ea9641f64f..fdcd96750dc9c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_months.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_months.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.json b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.json index b5e91be905f6a..0fa772d26cd41 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.proto.bin index 50ff5c5d88d49..22ddc1813e0fb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.json b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.json index ae7b3f124f9d9..d11bfbd7f2426 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.proto.bin index 7a5231cfe1897..bf9c545911ffd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_months_between_with_roundoff.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.json b/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.json index 0af98419ff17d..69daab270c2b9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.proto.bin index 59f2d8a49f4cb..f314a73dcae65 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_nanvl.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_negate.json b/connector/connect/common/src/test/resources/query-tests/queries/function_negate.json index 7256a697270d2..e269fabe44be1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_negate.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_negate.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_negate.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_negate.proto.bin index 7f45c5e08ee30..9c56c111ceee6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_negate.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_negate.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.json b/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.json index fef8b2fa899c0..486523dcad3ec 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.proto.bin index 3e2716dbc8da9..a97bd75f129db 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_next_day.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.json b/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.json index 4d14c28dfcf72..4c764a5d5603c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.proto.bin index 51d26e4c70b28..f87e1695f22e3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_nth_value.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.json b/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.json index 1cd06b27791ef..2346a788b64bd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.proto.bin index 6fec68ebb1999..d9ccd2e8a6007 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_ntile.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.json b/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.json index 1cdb4d9289e3e..7be9ac82662a4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.proto.bin index 3287d4ee314cf..484ebbb6487b0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_octet_length.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.json b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.json index 2243bb7f325ee..b580570f923a6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.proto.bin index 9feb660a45ab8..2110ae9c14610 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.json b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.json index 383b0b8370a1a..99d5426c46fba 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.proto.bin index 0011bcdb74814..9a09d28d84fde 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_overlay_with_len.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.json b/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.json index 3119e2af8b77b..d8778ec8cd81d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.proto.bin index 594de0f59b701..d668f7e1504cb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_percent_rank.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.json b/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.json index 15569edc49e22..6289464de2a37 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.proto.bin index 246a2c6b89990..f44ec86888f6c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_percentile_approx.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.json b/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.json index e1741769851f8..1dc2cb54cbb67 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.proto.bin index 36967776636e7..a2bb94dbb5173 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_pmod.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.json b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.json index 9e6b94da8f7d5..f8a9db37e62be 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.proto.bin index a4676028ae412..fc50f5f4c85b7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.json b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.json index a272b1cfc6e3e..0e8cd4c1509e1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.proto.bin index f7f093a0bf494..19d700665e7f5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_posexplode_outer.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_pow.json b/connector/connect/common/src/test/resources/query-tests/queries/function_pow.json index 5816a7c846048..187636fb360c6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_pow.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_pow.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_pow.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_pow.proto.bin index 00e5d023e0fc6..6e1d3b06fe87a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_pow.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_pow.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_product.json b/connector/connect/common/src/test/resources/query-tests/queries/function_product.json index 7a3d4c43f9ce8..1dfb7f81912d3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_product.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_product.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_product.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_product.proto.bin index 21a5feb50f45e..8c3fbd31eb6b3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_product.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_product.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.json b/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.json index b1554e4647d9c..b95867e0be963 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.proto.bin index 2d99708f27c09..fdc2d96fb08ca 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_quarter.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_radians.json b/connector/connect/common/src/test/resources/query-tests/queries/function_radians.json index f585cf1089acf..837960dedc653 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_radians.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_radians.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_radians.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_radians.proto.bin index a4f6f9531f291..33a2521b22ac9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_radians.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_radians.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.json b/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.json index 454029736d493..5318466706bd8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.proto.bin index efc81b60598e0..7fbd33b9869ca 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_raise_error.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.json index 4532f9fa85076..453ea54bd0ef3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.proto.bin index 7ce12ed0d1ef1..566a49d641293 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rand_with_seed.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.json b/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.json index 88f12466cb7f0..ef84f05c3e193 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.proto.bin index 3ba184d4d0c05..b0064842bf308 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_randn_with_seed.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rank.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rank.json index ab199e7c6d230..93c8dc38d668a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rank.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rank.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rank.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rank.proto.bin index d15a9c6d0d6c0..3aef331fb1739 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rank.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rank.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.json b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.json index 154f403653119..5d9c7a5b4a5ab 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.proto.bin index efaf5e8390859..32ba8b6dcb5e9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_extract.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.json b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.json index 66b3f0b0f6b2f..83dd7a8569fd4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.proto.bin index e543d8bbcb8c5..b7d3fde25cf85 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_regexp_replace.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.json b/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.json index efb54e0fff8f1..93869adfbedca 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.proto.bin index 43bfdf13e3ff1..dd7f2d5de513d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_reverse.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rint.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rint.json index 7e86e340854c2..ea5bcebf81d72 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rint.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rint.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rint.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rint.proto.bin index 81377729ceb73..bd47adc8476fa 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rint.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rint.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_round.json b/connector/connect/common/src/test/resources/query-tests/queries/function_round.json index c908004921242..585a0befb224d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_round.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_round.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_round.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_round.proto.bin index 90b949a0a680f..8625ccb1a58f1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_round.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_round.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.json b/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.json index 2185a41e2fbe2..3d5ac8afe3db3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.proto.bin index 080d1fc35b8be..90b4fcb27d3f1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_row_number.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.json index 0692f80247a77..d9b78a0cfd7a9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.proto.bin index 9158982448191..d4c355afee0b7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.json index 0c83e6add70c7..0daaf1636f13d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,bytes:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.proto.bin index fd510d0c24111..c6f9f22146c61 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rpad_binary.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.json index 8f74f50a8b7dc..5fe66e8e33596 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.proto.bin index 0c2884acdf5bc..4320bf6ac397c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.json b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.json index be88802d77876..d4c3c0ca68eb2 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.proto.bin index 4caf46240c7c5..37f4782f46161 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_rtrim_with_pattern.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.json b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.json index 4548b63ee4377..6df6438a1a9ca 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.proto.bin index 130f29db338dc..99475ddf30d11 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_csv.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.json b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.json index e2b8452a5a932..06110d326e1ef 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.proto.bin index 85260e2e944f2..c4ca00e629262 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.json b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.json index e4017e52169d5..ab05ffa940c50 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.proto.bin index dd8cc70aec6b8..482485501dd37 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_schema_of_json_with_options.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sec.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sec.json index 9c5b436dfa236..1cab2239755ca 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sec.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sec.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sec.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sec.proto.bin index a3e2a41d7c362..8760f57a6d4f0 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sec.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sec.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_second.json b/connector/connect/common/src/test/resources/query-tests/queries/function_second.json index 629782e5bd27e..c77a572b88aa0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_second.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_second.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_second.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_second.proto.bin index 91ded71d17bfb..193c46e917ba2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_second.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_second.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.json index ac483d09d9641..412ac0272dd57 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.proto.bin index cdfcb458aed23..4b62f22574d32 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.json index 09ab7def5898b..991b42faddb76 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.proto.bin index 56360a6c15eca..01c0136c6df16 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sentences_with_locale.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.json index 646c0d974e589..84bced640ff37 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.proto.bin index 79a44c8cff86a..09e1ab3be7dab 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sequence.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.json b/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.json index 21d989e79f342..5c7d953402b24 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.proto.bin index 34da8ae34c622..7f4ee24d53692 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_session_window.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.json index 21f43ef833a87..ce5014ac2f7e6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.proto.bin index c5db8db015000..3fdfdb2a072de 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sha1.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.json index 03ab5463692e0..5278d604e97b9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.proto.bin index 8eec0a9be58a7..20a0ee1082ae2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sha2.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.json b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.json index 5f2f9aaec546f..12decd300ab03 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.proto.bin index 11f8f737d72f9..94bfbc99fce2d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftleft.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.json b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.json index 9da302a006119..c2295c4abaaa2 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.proto.bin index 6775161f619dc..910d12f50d6a9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftright.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.json b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.json index 4565a88d45e94..875e26a5a5652 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.proto.bin index 3c13eef3d45a1..aba9c425dca96 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_shiftrightunsigned.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_signum.json b/connector/connect/common/src/test/resources/query-tests/queries/function_signum.json index 4b29b4ef04ad9..bcf6ad7eb174d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_signum.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_signum.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_signum.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_signum.proto.bin index 2fddfe1d63f62..af52abfb7f25b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_signum.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_signum.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sin.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sin.json index 238b7bfb7a363..cb5b0da073456 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sin.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sin.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sin.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sin.proto.bin index 2743ff0a1ec6e..a63f574fa59cb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sin.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sin.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.json index 5d4f56b387f85..e0f46b428611e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.proto.bin index 13492acdba5bb..2f17ab02a6d94 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sinh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_size.json b/connector/connect/common/src/test/resources/query-tests/queries/function_size.json index e75665d8144dd..37c9cd1ac1ba7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_size.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_size.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_size.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_size.proto.bin index a0dbe3709cb68..a8ae600a3dd7a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_size.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_size.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.json b/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.json index f328e02df8a5e..4b14c8d5ca79c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.proto.bin index c4ecdc95ab3a2..889f96b2d2a39 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_skewness.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_slice.json b/connector/connect/common/src/test/resources/query-tests/queries/function_slice.json index 497a1626eef73..b0a63248784ea 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_slice.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_slice.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_slice.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_slice.proto.bin index 3e1ff1ec8c8c7..620a006f775d6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_slice.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_slice.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.json index e8b279c0a936b..b42bede5cd172 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.proto.bin index 9fe1405d5d268..994048af2afc4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sort_array.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.json b/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.json index d07adf80e1a6d..851745b32ebe0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.proto.bin index 16dfd3e47555c..df99cd64e7203 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_spark_partition_id.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_split.json b/connector/connect/common/src/test/resources/query-tests/queries/function_split.json index 4fc19aa5811d4..001d44dcaaf6e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_split.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_split.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_split.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_split.proto.bin index b4b2004d3bc0c..cab0bde7b6da2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_split.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_split.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.json b/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.json index d22760653b08b..45a7588838ff8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.proto.bin index 5ed2b1d2ce987..497297fad8715 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_split_with_limit.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.json index fe4b6ac5e7fe2..f9a2b76520c13 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.proto.bin index bd86cdf8ee963..e98e3bdfdb665 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sqrt.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.json b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.json index 766918cadf103..1403817886ca0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.proto.bin index 5558c9428ec5f..8d214eea8e74e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.json b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.json index 4f3e80c8db1df..35e3a08b219f8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.proto.bin index 8ae3277a81e91..b679f55014f97 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_pop.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.json index dc8450d608e81..17cd0fd5e5976 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.proto.bin index cb5ec80622866..9f22eba5e39aa 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_stddev_samp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_struct.json b/connector/connect/common/src/test/resources/query-tests/queries/function_struct.json index 4efade2ea1248..ba950215a2591 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_struct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_struct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_struct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_struct.proto.bin index 62537a07c99f2..079c2be3c52e5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_struct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_struct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_substring.json b/connector/connect/common/src/test/resources/query-tests/queries/function_substring.json index ca8ea713cfb3d..84a70cf1c0236 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_substring.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_substring.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_substring.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_substring.proto.bin index 9f7b06da99a5a..d302cd95c7434 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_substring.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_substring.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.json b/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.json index 5d5afc5960d96..dc81d925957cd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.proto.bin index bda6160177e9d..192bb2e300dc3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_substring_index.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sum.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sum.json index 6735b7a0e1628..e9526a20b67fb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sum.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sum.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sum.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sum.proto.bin index 47e99c8d52ac3..0e347bbc0a167 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sum.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sum.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.json b/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.json index d4335e2d1ef0d..4614cf99ad3a6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.proto.bin index 1f1026cbd6068..b4cf704391a4d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_sum_distinct.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_tan.json b/connector/connect/common/src/test/resources/query-tests/queries/function_tan.json index 73442dc5b6948..ead160a7e3ac2 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_tan.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_tan.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_tan.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_tan.proto.bin index 5849d81e18918..d674dc033b2cd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_tan.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_tan.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.json b/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.json index 6e25719354595..bcd12c664427e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.proto.bin index f17641e49c2fe..21c28c3ef88e6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_tanh.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.json b/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.json index 8d5a686db6159..e6892d17708b3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.proto.bin index c3a483e38701c..102afbdda9021 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_timestamp_seconds.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.json index e06e9f57e1ecf..6b3856f5ac0af 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.proto.bin index fb670fcccee70..a3017643a330a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_csv.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.json index 5d21ca960792f..8b9d50aa578b8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.proto.bin index 6c73117c53695..59178487eef58 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.json index b2f487085d3d9..48ae80d1e70ed 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.proto.bin index e71ebdd9c600b..2641d660ff69f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_date_with_format.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.json index e58801c815eb5..7ceeb9d113cd3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.proto.bin index 6cb8d1290aa91..c9461c1aa961c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_json.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.json index e0f3d6cc0f597..323c57e2ef58a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.proto.bin index 3f854a07963a8..ec6bd64f98187 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.json index 89b91463b6e1f..30f34528319c7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.proto.bin index 81ee545465e3b..9c2d6d354ca73 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_timestamp_with_format.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.json index b826851c2c934..015fbb5cf534a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.proto.bin index 229ab9e87ee12..b2b65089604a2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_to_utc_timestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform.json b/connector/connect/common/src/test/resources/query-tests/queries/function_transform.json index bc8749cc02241..2b357a3577318 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_transform.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_transform.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_transform.proto.bin index 73e5696813117..44b83a9b98c53 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_transform.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_transform.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.json b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.json index 400c2b0cc86e6..0b6a6c24504b6 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.proto.bin index 97533b22067e9..338aa87e01832 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_keys.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.json b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.json index 97a80e4845732..71911ab5ed99b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.proto.bin index 7118b0b15a1fe..10cf8c503f420 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.json b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.json index 7f53846083886..1b296e891bca9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.proto.bin index 41c1878fbf68c..86f29399b9560 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_transform_with_index.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_translate.json b/connector/connect/common/src/test/resources/query-tests/queries/function_translate.json index 314cef73c2b9d..93d155c2857fb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_translate.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_translate.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_translate.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_translate.proto.bin index da9da35e74e71..1ce32c8d2843e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_translate.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_translate.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trim.json b/connector/connect/common/src/test/resources/query-tests/queries/function_trim.json index 7b58028d90433..d2700174bca3d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_trim.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_trim.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trim.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_trim.proto.bin index 7d6b4f38fbf10..d5f4f21510fc6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_trim.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_trim.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.json b/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.json index cc7d4e103b5c8..82b1616ef38ed 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.proto.bin index 70f9b0b39a4cf..6a86e87c9850b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_trim_with_pattern.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.json b/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.json index 2270ecf3c1d2c..4c596cd863261 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.proto.bin index 132e23ec8039d..cdcee95af6344 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_trunc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.json b/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.json index e41a3f0433ed6..6af2a00ed160e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.proto.bin index fe11d1d7845be..f37ceb91bf42b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_unbase64.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.json b/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.json index dff5f2c2edd53..7c409d023f76a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.proto.bin index 493c70a49f748..fbac2821fdb07 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_unhex.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.json index 509a7f9096001..e590f7778f2ea 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.proto.bin index 5db43e06c9afc..cb3d967ae0123 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.json b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.json index adf3b0a4c1ccc..d2e087a5d8a24 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.proto.bin index 54b5642b550ae..ddfcdff63d11a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_unix_timestamp_with_format.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_upper.json b/connector/connect/common/src/test/resources/query-tests/queries/function_upper.json index 91f321d27e831..208ee9231a13c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_upper.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_upper.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_upper.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_upper.proto.bin index 2fc03cc69bbd6..5ddbfce96e71b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_upper.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_upper.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.json b/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.json index 4cf7abc8b8452..9c74ce4a984f8 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.proto.bin index 2646cfadba0a9..7ca6e8d3b811b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_var_pop.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.json b/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.json index 7077feb5c5ef1..979313dd0510d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.proto.bin index 93ac12e8119c5..9bd042ad339e7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_var_samp.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_variance.json b/connector/connect/common/src/test/resources/query-tests/queries/function_variance.json index 61310a665d657..90a97c3becf4d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_variance.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_variance.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_variance.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_variance.proto.bin index fec1298adc2ac..fd494fc496391 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_variance.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_variance.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.json b/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.json index b7c1f68937f6a..3f46a98569e24 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.proto.bin index c0a1601fc2052..ec9b22522360e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_weekofyear.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_window.json b/connector/connect/common/src/test/resources/query-tests/queries/function_window.json index 05322ab654360..bdcb6a398800f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_window.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_window.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_window.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_window.proto.bin index 0226aa0c382ab..8cffcc1e9f673 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_window.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_window.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.json b/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.json index de6b0a38fda26..4809ea21261c4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.json @@ -1,8 +1,17 @@ { + "common": { + "planId": "2" + }, "project": { "input": { + "common": { + "planId": "1" + }, "withColumns": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } @@ -10,7 +19,8 @@ "aliases": [{ "expr": { "unresolvedAttribute": { - "unparsedIdentifier": "wt" + "unparsedIdentifier": "wt", + "planId": "0" } }, "name": ["wt"], diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.proto.bin index e39dd78802c1c..c143520df08ce 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_window_time.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.json b/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.json index fac2a4ed0be7e..c20739d09ff10 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.proto.bin index 6ed2e2a243a87..414c76fc5ce7f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_xxhash64.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_year.json b/connector/connect/common/src/test/resources/query-tests/queries/function_year.json index 502a7b5f1dc40..b8a4ee5a16525 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_year.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_year.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cd:date,t:timestamp,s:string,x:bigint,wt:struct\u003cstart:timestamp,end:timestamp\u003e\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_year.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_year.proto.bin index 74f3e61f8167b..623bc9ac6d81f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_year.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_year.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_years.json b/connector/connect/common/src/test/resources/query-tests/queries/function_years.json index a0b6f4228d06a..2e87307320271 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_years.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_years.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_years.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_years.proto.bin index f1e2a949fb440..30c25423fd563 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_years.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_years.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.json b/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.json index a7c603ed6bbb3..d1d0e7293c8ff 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double,d:struct\u003cid:bigint,a:int,b:double\u003e,e:array\u003cint\u003e,f:map\u003cstring,struct\u003cid:bigint,a:int,b:double\u003e\u003e,g:string\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.proto.bin index 2d6bec136a7cb..c9a6dff84736b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/function_zip_with.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.json index 4cf2ae0c8c289..4a1cfddb0288f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } @@ -16,7 +22,8 @@ "functionName": "max", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "a" + "unparsedIdentifier": "a", + "planId": "0" } }] } @@ -25,7 +32,8 @@ "functionName": "stddev", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } @@ -34,7 +42,8 @@ "functionName": "stddev", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } @@ -43,7 +52,8 @@ "functionName": "avg", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } @@ -52,7 +62,8 @@ "functionName": "avg", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } @@ -61,7 +72,8 @@ "functionName": "avg", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "b" + "unparsedIdentifier": "b", + "planId": "0" } }] } @@ -78,7 +90,8 @@ "functionName": "count", "arguments": [{ "unresolvedAttribute": { - "unparsedIdentifier": "a" + "unparsedIdentifier": "a", + "planId": "0" } }] } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.proto.bin index eed57649c4526..cfd6c2daa84b4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.json index fd2264fd2aecf..e61616786158e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.proto.bin index b12dd5229db4c..d6daa1cc31f7d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_agg_columns.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.json index df4216bdd5191..5785eee2cadb5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.proto.bin index 33cbb49f1fe4c..4a18ea2d82d93 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_avg.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.json index c28c167f21b16..f92e22493e07b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.proto.bin index d3920650eb5f7..5bb539195df9a 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_count.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.json index 262232063dd14..3225a475a9b35 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.proto.bin index e43c9e3e325dc..651274b1afcac 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_max.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.json index df4216bdd5191..5785eee2cadb5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.proto.bin index 33cbb49f1fe4c..4a18ea2d82d93 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_mean.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.json index c6c55dde8b47c..afcc07d2c869c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.proto.bin index c7ad1785cd8b3..6e038bf0b315c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_min.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.json b/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.json index 48d3820dea933..74dd5b045aa57 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.proto.bin index 673b745270338..fe2451ca18fbd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/groupby_sum.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/hint.json b/connector/connect/common/src/test/resources/query-tests/queries/hint.json index 38f3ff1ab7a06..bb5b848b744d0 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/hint.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/hint.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "hint": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/hint.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/hint.proto.bin index 8832794f792a8..8eb4f41203511 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/hint.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/hint.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/intersect.json b/connector/connect/common/src/test/resources/query-tests/queries/intersect.json index cd8167116c0c8..f290397c55ca1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/intersect.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/intersect.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/intersect.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/intersect.proto.bin index 71816354cda75..0ea7edc5cee3d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/intersect.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/intersect.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.json b/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.json index 9fd2a7a37275b..d8fe5fe0b7e79 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.proto.bin index 5e3325c73c134..6df2125682bcb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/intersectAll.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_condition.json b/connector/connect/common/src/test/resources/query-tests/queries/join_condition.json index 94abd7a159f1c..993cd98a7dd16 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_condition.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_condition.json @@ -1,8 +1,17 @@ { + "common": { + "planId": "4" + }, "join": { "left": { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } @@ -11,8 +20,14 @@ } }, "right": { + "common": { + "planId": "3" + }, "subqueryAlias": { "input": { + "common": { + "planId": "2" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_condition.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_condition.proto.bin index 84ddc108103c2..1d11fe5e75bcc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_condition.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_condition.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.json b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.json index 36e203a425614..527338c56ae60 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.json @@ -1,8 +1,17 @@ { + "common": { + "planId": "4" + }, "join": { "left": { + "common": { + "planId": "1" + }, "subqueryAlias": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } @@ -11,8 +20,14 @@ } }, "right": { + "common": { + "planId": "3" + }, "subqueryAlias": { "input": { + "common": { + "planId": "2" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.proto.bin index c1cc916d3275f..5d3de55da9cf8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_condition.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.json b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.json index 0308a128db34d..8c53a193162d7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.proto.bin index 9a269059bf745..44bf1a6793cdc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_no_condition.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.json b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.json index 9f9f1a0cf30e2..42b4eec5d9f1f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.proto.bin index 0e4192d7afce6..98e2a4fe9b58f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_array.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.json b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.json index 9f9f1a0cf30e2..42b4eec5d9f1f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.proto.bin index 0e4192d7afce6..98e2a4fe9b58f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_multiple_col_seq.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.json b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.json index b5137f978a9c4..2c2bde49b190e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.proto.bin index 0708749bd473a..7d4a1aeb11efc 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_inner_using_single_col.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.json b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.json index 4bd0b9ec2c7e0..9b592426cf96b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.proto.bin index 954128f8c1e82..4c4b6ecb20767 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_array.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.json b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.json index 3d06f7ab31f9e..3f1c46f08e813 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.proto.bin index 5878e776d87bf..2a5410fc06316 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_using_multiple_col_seq.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.json b/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.json index b5b8b3a40f9de..46f144de61a99 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "join": { "left": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "right": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.proto.bin index 0c72726a8c227..c2fa60619d705 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/join_using_single_col.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/limit.json b/connector/connect/common/src/test/resources/query-tests/queries/limit.json index e755944a82e4d..acf01c196891d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/limit.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/limit.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "limit": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/limit.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/limit.proto.bin index 71249c1f2c97e..f3f4771fe4deb 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/limit.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/limit.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.json b/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.json index 292adb11b17e2..12db0a5abe368 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "unpivot": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.proto.bin index dc1a40f8d4884..23a6aa1289a99 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/melt_no_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/melt_values.json b/connector/connect/common/src/test/resources/query-tests/queries/melt_values.json index 79d494c3c5d6a..e2a004f46e781 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/melt_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/melt_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "unpivot": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/melt_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/melt_values.proto.bin index 1ac7cb290f848..e021e1110def5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/melt_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/melt_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/offset.json b/connector/connect/common/src/test/resources/query-tests/queries/offset.json index e03d5072ea400..80796160b96d7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/offset.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/offset.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "offset": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/offset.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/offset.proto.bin index 8c7dde8f92c93..6671eebb93183 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/offset.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/offset.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.json b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.json index d935be14ee65a..72ea72d795497 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.proto.bin index bebe09e64a915..00fa9f8b5c02d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_columns.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.json b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.json index 22508b999d38a..e7f63a15c2882 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.proto.bin index 3e7b74ea6b594..a907e66a130d4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/orderBy_strings.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.json b/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.json index 99268661e728f..5ceb1d5a08715 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "sql": { "query": "select 1", "args": { diff --git a/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.proto.bin index fd9304b4e47c8..50bc8457f3170 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/parameterized_sql.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/range.json b/connector/connect/common/src/test/resources/query-tests/queries/range.json index b9d83e3e59409..8afa44fac6cf2 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/range.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/range.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "range": { "start": "1", "end": "10", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/range.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/range.proto.bin index 717b9adab6664..277a02cea558c 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/range.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/range.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read.json b/connector/connect/common/src/test/resources/query-tests/queries/read.json index f5ffb3c961b57..d5580c1321ec4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "csv", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read.proto.bin index ede57af1130c6..c50391bb1a8f7 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_csv.json b/connector/connect/common/src/test/resources/query-tests/queries/read_csv.json index 6095d200f628a..ec1eed1c6cf35 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_csv.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_csv.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "csv", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_csv.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_csv.proto.bin index 9bbab0fe2af6b..d8b5ca93f2f77 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_csv.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_csv.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_json.json b/connector/connect/common/src/test/resources/query-tests/queries/read_json.json index 2e2f83d11915a..63dadc129dc8f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_json.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_json.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "json", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_json.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_json.proto.bin index 22557aca38d66..1d829df6bbcfe 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_json.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_json.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_orc.json b/connector/connect/common/src/test/resources/query-tests/queries/read_orc.json index caa6c951d3ea0..b78d7d6ecd61c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_orc.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_orc.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "orc", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_orc.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_orc.proto.bin index 95d07fd0a9b06..6a67db561dc88 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_orc.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_orc.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.json b/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.json index 05d799fd9cb09..0a201a43c744b 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "parquet", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.proto.bin index 5fc1954428f8d..f16b28dcce01e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_parquet.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_table.json b/connector/connect/common/src/test/resources/query-tests/queries/read_table.json index 634310c27ff23..b2cd4ae0a5bae 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_table.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_table.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "namedTable": { "unparsedIdentifier": "myTable" diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_table.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_table.proto.bin index f6ffaf988e7d4..956da78861d0b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_table.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_table.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_text.json b/connector/connect/common/src/test/resources/query-tests/queries/read_text.json index 8dc1e26a70ec1..de7a306a52fbc 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/read_text.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/read_text.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "dataSource": { "format": "text", diff --git a/connector/connect/common/src/test/resources/query-tests/queries/read_text.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/read_text.proto.bin index 97d167f6e2e9a..3f3bbf8769c4d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/read_text.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/read_text.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition.json b/connector/connect/common/src/test/resources/query-tests/queries/repartition.json index 770b227b70729..163742886c3a5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/repartition.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/repartition.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartition": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/repartition.proto.bin index 03bb478761766..5265e0e6175c4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/repartition.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/repartition.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.json b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.json index deb4c61888595..98bd4c988abc3 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartitionByExpression": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.proto.bin index 531737b7548bb..8ee220833d9e8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_expressions.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.json b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.json index eede8a4b1acd1..604d0330fedd7 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartitionByExpression": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.proto.bin index 8139f2cb39778..a3f1546cca1f8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/repartitionByRange_num_partitions_expressions.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.json b/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.json index c91a30eb0e9c7..81113afea3535 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartitionByExpression": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.proto.bin index c217e9d9d93f3..50ff8c590cda3 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/repartition_expressions.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.json b/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.json index d70380d122860..996beda2253aa 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "repartitionByExpression": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.proto.bin index 47b3ab9daf536..73e22f120ed95 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/repartition_num_partitions_expressions.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.json b/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.json index f976e4ea10f84..1102db18830bd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.proto.bin index 89ef8ff947b4e..64dbb597c3650 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/rollup_column.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.json b/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.json index f976e4ea10f84..1102db18830bd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "aggregate": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.proto.bin index 89ef8ff947b4e..64dbb597c3650 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/rollup_string.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.json b/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.json index 3f4dbedac3ac6..88e80a3f60c6c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sample": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.proto.bin index 7754a5e213d28..546c9c9c69cac 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sample_fraction_seed.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.json b/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.json index 5f9f6f2196692..75d3b2421601d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sample": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.proto.bin index 2e1efe2e5276a..48650897e6762 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sample_withReplacement_fraction_seed.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/select.json b/connector/connect/common/src/test/resources/query-tests/queries/select.json index 8d4b511b1f933..8ef46a6cc2aab 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/select.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/select.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/select.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/select.proto.bin index e926353d8363f..2bc4bd85a5806 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/select.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/select.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.json b/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.json index b38c071d82306..9c2815cffb752 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.proto.bin index 9f203955a8de1..88824d7f896f5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/selectExpr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/select_strings.json b/connector/connect/common/src/test/resources/query-tests/queries/select_strings.json index cde5f0721a342..421b9aa120016 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/select_strings.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/select_strings.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/select_strings.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/select_strings.proto.bin index 507d3c15e6134..f868b46f3e58f 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/select_strings.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/select_strings.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.json b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.json index 08d98935f4007..c45a326a01b47 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.proto.bin index 5c076fa9d120d..49e24e6f6f222 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_columns.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.json b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.json index 6b13151641d5a..dcded7cb32d8c 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.proto.bin index 572abd9c7a0fe..f5ff329823889 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sortWithinPartitions_strings.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.json b/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.json index 65354a1313013..76b4d92d71c1f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.proto.bin index f3f7a40246b2c..9c059d244aecf 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sort_columns.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.json b/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.json index 6d127fa5c3c76..7955221d7d786 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "sort": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.proto.bin index 1c7568f4f34c8..e780d351c8af9 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sort_strings.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sql.json b/connector/connect/common/src/test/resources/query-tests/queries/sql.json index c36812b9791e4..c4bc9b2c08271 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/sql.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/sql.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "sql": { "query": "select 1" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/sql.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/sql.proto.bin index 92499c516c31d..3d4394f23af02 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/sql.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/sql.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/summary.json b/connector/connect/common/src/test/resources/query-tests/queries/summary.json index 48c336fbf7c48..cbfe9bcf7b085 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/summary.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/summary.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "summary": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/summary.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/summary.proto.bin index 69363710ef2e9..a88d61cdc76b2 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/summary.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/summary.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/table.json b/connector/connect/common/src/test/resources/query-tests/queries/table.json index 634310c27ff23..b2cd4ae0a5bae 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/table.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/table.json @@ -1,4 +1,7 @@ { + "common": { + "planId": "0" + }, "read": { "namedTable": { "unparsedIdentifier": "myTable" diff --git a/connector/connect/common/src/test/resources/query-tests/queries/table.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/table.proto.bin index f6ffaf988e7d4..956da78861d0b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/table.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/table.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/to.json b/connector/connect/common/src/test/resources/query-tests/queries/to.json index e09913ff56264..a3e07202c106f 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/to.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/to.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "toSchema": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/to.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/to.proto.bin index ce3c150967360..8e15aa6c2791d 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/to.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/to.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/toDF.json b/connector/connect/common/src/test/resources/query-tests/queries/toDF.json index e753b7d0e3afc..8111bc76a8a81 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/toDF.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/toDF.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "toDf": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/toDF.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/toDF.proto.bin index b88bdf99169d0..3238291e87948 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/toDF.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/toDF.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/union.json b/connector/connect/common/src/test/resources/query-tests/queries/union.json index 170e0f09cf98a..9048133ca6385 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/union.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/union.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/union.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/union.proto.bin index 7c4f869e44fc5..caafd1ef998d6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/union.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/union.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionAll.json b/connector/connect/common/src/test/resources/query-tests/queries/unionAll.json index 170e0f09cf98a..9048133ca6385 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/unionAll.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/unionAll.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionAll.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/unionAll.proto.bin index 7c4f869e44fc5..caafd1ef998d6 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/unionAll.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/unionAll.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionByName.json b/connector/connect/common/src/test/resources/query-tests/queries/unionByName.json index 9446f0127e9a0..9244eb08790d1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/unionByName.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/unionByName.json @@ -1,8 +1,17 @@ { + "common": { + "planId": "4" + }, "setOp": { "leftInput": { + "common": { + "planId": "1" + }, "drop": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } @@ -15,8 +24,14 @@ } }, "rightInput": { + "common": { + "planId": "3" + }, "drop": { "input": { + "common": { + "planId": "2" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionByName.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/unionByName.proto.bin index 522c1bb0a16de..64d9fb901d21b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/unionByName.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/unionByName.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.json b/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.json index 70e770c135fd5..98870ffe7175d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.json @@ -1,11 +1,20 @@ { + "common": { + "planId": "2" + }, "setOp": { "leftInput": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } }, "rightInput": { + "common": { + "planId": "1" + }, "localRelation": { "schema": "struct\u003ca:int,id:bigint,payload:binary\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.proto.bin index 29e0896b6c63d..4facbbc553ea5 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/unionByName_allowMissingColumns.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.json b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.json index 662328af9a756..9f550c0319147 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "unpivot": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.proto.bin index 9f2600404f20e..ac3bad8bd04ed 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_no_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.json b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.json index 3557958fd29da..92bc19d195c6e 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "unpivot": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.proto.bin index 9fb45c9c0c195..7f717cb23517b 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/unpivot_values.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/where_column.json b/connector/connect/common/src/test/resources/query-tests/queries/where_column.json index f8ec863648c98..bef80a7e6ed5a 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/where_column.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/where_column.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "filter": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/where_column.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/where_column.proto.bin index eae5db282caec..e472ed0715b62 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/where_column.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/where_column.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/where_expr.json b/connector/connect/common/src/test/resources/query-tests/queries/where_expr.json index c244ff0e89104..dc7523bcaade4 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/where_expr.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/where_expr.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "filter": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/where_expr.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/where_expr.proto.bin index 63b44b32b6340..380a1763b81ec 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/where_expr.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/where_expr.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/window.json b/connector/connect/common/src/test/resources/query-tests/queries/window.json index 8649a9d6e543c..23fd5c1556ec5 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/window.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/window.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "project": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/window.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/window.proto.bin index caa9d66934c20..a89c0d6a6a3f4 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/window.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/window.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.json index ba7d76aec9965..731cf844afe6d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumnsRenamed": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.proto.bin index 38130a873d827..64fcf7855ecbf 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_java_map.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.json index ee507379fa41f..570bfa32233d9 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumnsRenamed": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.proto.bin index 5a8cfaa51ee42..42df8ea1d1111 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_scala_map.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.json index 8d0bfc254eb72..23b2e1d41d3cb 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumnsRenamed": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.proto.bin index 5c60a64d3ad4e..f46d01646c6f1 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumnRenamed_single.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.json index 5bf8b01d5c432..8863d15f2764d 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumns": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.proto.bin index f6693d6b8b8af..6d53a883a5f40 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumn_single.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.json index 21e75d07aef36..a59f4abd47ce1 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumns": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.proto.bin index f71f62489598d..be381f62594c8 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_java_map.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.json b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.json index aca9ce7db7d6e..99405a73041fa 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumns": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.proto.bin index 52a22ed9cecb8..77ee1900e73fd 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withColumns_scala_map.proto.bin differ diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.json b/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.json index 0f28e7655a4a4..6ba7e5cd55bdd 100644 --- a/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.json +++ b/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.json @@ -1,6 +1,12 @@ { + "common": { + "planId": "1" + }, "withColumns": { "input": { + "common": { + "planId": "0" + }, "localRelation": { "schema": "struct\u003cid:bigint,a:int,b:double\u003e" } @@ -8,7 +14,8 @@ "aliases": [{ "expr": { "unresolvedAttribute": { - "unparsedIdentifier": "id" + "unparsedIdentifier": "id", + "planId": "0" } }, "name": ["id"], diff --git a/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.proto.bin b/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.proto.bin index e9aa65874e4fd..f814b37d0ac2e 100644 Binary files a/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.proto.bin and b/connector/connect/common/src/test/resources/query-tests/queries/withMetadata.proto.bin differ