Return-Path: X-Original-To: apmail-tajo-commits-archive@minotaur.apache.org Delivered-To: apmail-tajo-commits-archive@minotaur.apache.org Received: from mail.apache.org (hermes.apache.org [140.211.11.3]) by minotaur.apache.org (Postfix) with SMTP id 534C318697 for ; Fri, 14 Aug 2015 14:29:44 +0000 (UTC) Received: (qmail 893 invoked by uid 500); 14 Aug 2015 14:29:44 -0000 Delivered-To: apmail-tajo-commits-archive@tajo.apache.org Received: (qmail 775 invoked by uid 500); 14 Aug 2015 14:29:44 -0000 Mailing-List: contact commits-help@tajo.apache.org; run by ezmlm Precedence: bulk List-Help: List-Unsubscribe: List-Post: List-Id: Reply-To: dev@tajo.apache.org Delivered-To: mailing list commits@tajo.apache.org Received: (qmail 97459 invoked by uid 99); 14 Aug 2015 14:29:41 -0000 Received: from git1-us-west.apache.org (HELO git1-us-west.apache.org) (140.211.11.23) by apache.org (qpsmtpd/0.29) with ESMTP; Fri, 14 Aug 2015 14:29:41 +0000 Received: by git1-us-west.apache.org (ASF Mail Server at git1-us-west.apache.org, from userid 33) id 3F8CEE35C6; Fri, 14 Aug 2015 14:29:41 +0000 (UTC) Content-Type: text/plain; charset="us-ascii" MIME-Version: 1.0 Content-Transfer-Encoding: 7bit From: hyunsik@apache.org To: commits@tajo.apache.org Date: Fri, 14 Aug 2015 14:30:30 -0000 Message-Id: <0e93c110488542f386ff1376bfcf0e0b@git.apache.org> In-Reply-To: References: X-Mailer: ASF-Git Admin Mailer Subject: [51/51] [partial] tajo git commit: TAJO-1761: Separate an integration unit test kit into an independent module. TAJO-1761: Separate an integration unit test kit into an independent module. Closes #690 Project: http://git-wip-us.apache.org/repos/asf/tajo/repo Commit: http://git-wip-us.apache.org/repos/asf/tajo/commit/a4106883 Tree: http://git-wip-us.apache.org/repos/asf/tajo/tree/a4106883 Diff: http://git-wip-us.apache.org/repos/asf/tajo/diff/a4106883 Branch: refs/heads/master Commit: a4106883dda73802548dc867ba25e69df630dc9b Parents: ab60d02 Author: Hyunsik Choi Authored: Fri Aug 14 23:20:15 2015 +0900 Committer: Hyunsik Choi Committed: Fri Aug 14 23:20:15 2015 +0900 ---------------------------------------------------------------------- CHANGES | 3 + pom.xml | 2 + tajo-cluster-tests/pom.xml | 302 ++++ .../org/apache/tajo/BackendTestingUtil.java | 71 + .../org/apache/tajo/HBaseTestClusterUtil.java | 184 +++ .../java/org/apache/tajo/IntegrationTest.java | 22 + .../apache/tajo/LocalTajoTestingUtility.java | 169 +++ .../test/java/org/apache/tajo/NamedTest.java | 27 + .../java/org/apache/tajo/QueryTestCaseBase.java | 1030 +++++++++++++ .../org/apache/tajo/TajoTestingCluster.java | 778 ++++++++++ .../test/java/org/apache/tajo/TpchTestBase.java | 113 ++ tajo-core-tests/pom.xml | 356 +++++ tajo-core-tests/src/test/java/log4j.properties | 28 + .../org/apache/tajo/TestQueryIdFactory.java | 58 + .../test/java/org/apache/tajo/TestTajoIds.java | 168 +++ .../org/apache/tajo/benchmark/TestTPCH.java | 68 + .../apache/tajo/cli/tools/TestDDLBuilder.java | 133 ++ .../org/apache/tajo/cli/tools/TestTajoDump.java | 124 ++ .../cli/tsql/TestDefaultCliOutputFormatter.java | 179 +++ .../apache/tajo/cli/tsql/TestSimpleParser.java | 286 ++++ .../org/apache/tajo/cli/tsql/TestTajoCli.java | 472 ++++++ .../tajo/cli/tsql/TestTajoCliNegatives.java | 146 ++ .../commands/TestExecExternalShellCommand.java | 45 + .../tajo/cli/tsql/commands/TestHdfsCommand.java | 47 + .../TestCatalogAdminClientExceptions.java | 102 ++ .../tajo/client/TestQueryClientExceptions.java | 121 ++ .../org/apache/tajo/client/TestTajoClient.java | 775 ++++++++++ .../apache/tajo/client/v2/TestTajoClientV2.java | 274 ++++ .../tajo/cluster/TestWorkerConnectionInfo.java | 36 + .../engine/codegen/TestEvalCodeGenerator.java | 310 ++++ .../engine/codegen/TestGeneratorAdapter.java | 41 + .../apache/tajo/engine/eval/ExprTestBase.java | 341 +++++ .../apache/tajo/engine/eval/TestEvalTree.java | 424 ++++++ .../tajo/engine/eval/TestEvalTreeUtil.java | 374 +++++ .../tajo/engine/eval/TestIntervalType.java | 124 ++ .../apache/tajo/engine/eval/TestPredicates.java | 405 +++++ .../tajo/engine/eval/TestSQLDateTimeTypes.java | 50 + .../tajo/engine/eval/TestSQLExpression.java | 1001 +++++++++++++ .../tajo/engine/function/TestAggFunction.java | 65 + .../engine/function/TestBuiltinFunctions.java | 824 ++++++++++ .../function/TestConditionalExpressions.java | 242 +++ .../engine/function/TestDateTimeFunctions.java | 483 ++++++ .../engine/function/TestFunctionLoader.java | 45 + .../engine/function/TestGeneralFunction.java | 49 + .../tajo/engine/function/TestJsonFunctions.java | 66 + .../tajo/engine/function/TestMathFunctions.java | 470 ++++++ .../function/TestPatternMatchingPredicates.java | 139 ++ .../engine/function/TestPythonFunctions.java | 43 + .../TestStringOperatorsAndFunctions.java | 615 ++++++++ .../tajo/engine/parser/TestSQLAnalyzer.java | 804 ++++++++++ .../engine/planner/TestJoinOrderAlgorithm.java | 184 +++ .../engine/planner/TestLogicalOptimizer.java | 272 ++++ .../tajo/engine/planner/TestLogicalPlan.java | 86 ++ .../tajo/engine/planner/TestLogicalPlanner.java | 1360 +++++++++++++++++ .../tajo/engine/planner/TestPlannerUtil.java | 387 +++++ .../engine/planner/TestQueryValidation.java | 65 + .../planner/TestUniformRangePartition.java | 1143 ++++++++++++++ .../engine/planner/global/TestMasterPlan.java | 53 + .../planner/physical/TestBNLJoinExec.java | 224 +++ .../planner/physical/TestExternalSortExec.java | 187 +++ .../physical/TestFullOuterHashJoinExec.java | 414 +++++ .../physical/TestFullOuterMergeJoinExec.java | 537 +++++++ .../planner/physical/TestHashAntiJoinExec.java | 215 +++ .../planner/physical/TestHashJoinExec.java | 281 ++++ .../planner/physical/TestHashPartitioner.java | 117 ++ .../planner/physical/TestHashSemiJoinExec.java | 220 +++ .../physical/TestLeftOuterHashJoinExec.java | 440 ++++++ .../planner/physical/TestMergeJoinExec.java | 197 +++ .../engine/planner/physical/TestNLJoinExec.java | 208 +++ .../planner/physical/TestPhysicalPlanner.java | 1144 ++++++++++++++ .../physical/TestProgressExternalSortExec.java | 229 +++ .../physical/TestRightOuterHashJoinExec.java | 351 +++++ .../physical/TestRightOuterMergeJoinExec.java | 531 +++++++ .../engine/planner/physical/TestSortExec.java | 179 +++ .../planner/physical/TestSortIntersectExec.java | 293 ++++ .../planner/physical/TestTupleSorter.java | 127 ++ .../tajo/engine/query/TestAlterTable.java | 114 ++ .../tajo/engine/query/TestAlterTablespace.java | 59 + .../apache/tajo/engine/query/TestCTASQuery.java | 281 ++++ .../tajo/engine/query/TestCaseByCases.java | 183 +++ .../tajo/engine/query/TestCreateDatabase.java | 75 + .../tajo/engine/query/TestCreateIndex.java | 112 ++ .../tajo/engine/query/TestCreateTable.java | 643 ++++++++ .../apache/tajo/engine/query/TestDropTable.java | 38 + .../tajo/engine/query/TestGroupByQuery.java | 870 +++++++++++ .../tajo/engine/query/TestHBaseTable.java | 1408 ++++++++++++++++++ .../tajo/engine/query/TestInSubquery.java | 177 +++ .../apache/tajo/engine/query/TestIndexScan.java | 145 ++ .../tajo/engine/query/TestInnerJoinQuery.java | 335 +++++ .../engine/query/TestInnerJoinWithSubQuery.java | 132 ++ .../tajo/engine/query/TestInsertQuery.java | 882 +++++++++++ .../query/TestJoinOnPartitionedTables.java | 341 +++++ .../apache/tajo/engine/query/TestJoinQuery.java | 315 ++++ .../engine/query/TestMultipleJoinTypes.java | 106 ++ .../apache/tajo/engine/query/TestNetTypes.java | 102 ++ .../tajo/engine/query/TestNullValues.java | 322 ++++ .../tajo/engine/query/TestOuterJoinQuery.java | 457 ++++++ .../engine/query/TestOuterJoinWithSubQuery.java | 143 ++ .../engine/query/TestSelectNestedRecord.java | 119 ++ .../tajo/engine/query/TestSelectQuery.java | 778 ++++++++++ .../tajo/engine/query/TestSetSessionQuery.java | 80 + .../apache/tajo/engine/query/TestSortQuery.java | 377 +++++ .../tajo/engine/query/TestTablePartitions.java | 1301 ++++++++++++++++ .../tajo/engine/query/TestTableSubQuery.java | 81 + .../tajo/engine/query/TestTruncateTable.java | 96 ++ .../tajo/engine/query/TestUnionQuery.java | 693 +++++++++ .../tajo/engine/query/TestWindowQuery.java | 465 ++++++ .../apache/tajo/engine/util/TestTableCache.java | 109 ++ .../apache/tajo/engine/util/TestTupleUtil.java | 188 +++ .../apache/tajo/ha/TestHAServiceHDFSImpl.java | 160 ++ .../org/apache/tajo/jdbc/TestResultSet.java | 224 +++ .../java/org/apache/tajo/jdbc/TestSQLState.java | 91 ++ .../tajo/jdbc/TestTajoDatabaseMetaData.java | 504 +++++++ .../java/org/apache/tajo/jdbc/TestTajoJdbc.java | 608 ++++++++ .../tajo/master/TestExecutionBlockCursor.java | 135 ++ .../TestNonForwardQueryResultSystemScanner.java | 41 + .../apache/tajo/master/TestRepartitioner.java | 511 +++++++ .../tajo/master/rule/TestMasterRules.java | 156 ++ .../master/scheduler/TestSimpleScheduler.java | 301 ++++ .../tajo/querymaster/TestIntermediateEntry.java | 53 + .../apache/tajo/querymaster/TestKillQuery.java | 312 ++++ .../tajo/querymaster/TestQueryProgress.java | 77 + .../apache/tajo/querymaster/TestQueryState.java | 99 ++ .../tajo/querymaster/TestTaskStatusUpdate.java | 191 +++ .../org/apache/tajo/resource/TestResources.java | 48 + .../apache/tajo/storage/TestFileFragment.java | 93 ++ .../org/apache/tajo/storage/TestRowFile.java | 146 ++ .../java/org/apache/tajo/util/TestJSPUtil.java | 113 ++ .../util/history/TestHistoryWriterReader.java | 313 ++++ .../tajo/util/metrics/TestMetricsFilter.java | 52 + .../tajo/util/metrics/TestSystemMetrics.java | 143 ++ .../apache/tajo/worker/MockExecutionBlock.java | 42 + .../tajo/worker/MockNodeResourceManager.java | 88 ++ .../tajo/worker/MockNodeStatusUpdater.java | 97 ++ .../apache/tajo/worker/MockTaskExecutor.java | 153 ++ .../org/apache/tajo/worker/MockTaskManager.java | 69 + .../apache/tajo/worker/MockWorkerContext.java | 109 ++ .../apache/tajo/worker/TestDeletionService.java | 61 + .../org/apache/tajo/worker/TestFetcher.java | 236 +++ .../tajo/worker/TestNodeResourceManager.java | 281 ++++ .../tajo/worker/TestNodeStatusUpdater.java | 192 +++ .../apache/tajo/worker/TestTaskExecutor.java | 315 ++++ .../org/apache/tajo/worker/TestTaskManager.java | 184 +++ .../tajo/ws/rs/resources/RestTestUtils.java | 64 + .../ws/rs/resources/TestClusterResource.java | 83 ++ .../ws/rs/resources/TestDatabasesResource.java | 189 +++ .../ws/rs/resources/TestFunctionsResource.java | 78 + .../tajo/ws/rs/resources/TestQueryResource.java | 199 +++ .../rs/resources/TestQueryResultResource.java | 296 ++++ .../ws/rs/resources/TestSessionsResource.java | 263 ++++ .../ws/rs/resources/TestTablesResource.java | 202 +++ .../resources/dataset/TestAlterTable/table1.tbl | 3 + .../resources/dataset/TestAlterTable/table2.tbl | 1 + .../dataset/TestCreateTable/table1/table1.tbl | 3 + .../dataset/TestCreateTable/table2/table2.tbl | 3 + .../resources/dataset/TestDropTable/table1.tbl | 3 + .../dataset/TestHBaseTable/splits.data | 4 + .../dataset/TestJoinQuery/table1/table1.tbl | 5 + .../dataset/TestJoinQuery/table2/table2.tbl | 4 + .../dataset/TestNetTypes/table1/table1.tbl | 5 + .../dataset/TestNetTypes/table2/table2.tbl | 5 + .../TestSelectNestedRecord/sample1/table.json | 3 + .../TestSelectNestedRecord/sample2/sample2.json | 1 + .../TestSelectNestedRecord/tweets/sample1.json | 4 + .../multibytes_delimiter1/table1.tbl | 5 + .../multibytes_delimiter2/table2.tbl | 5 + .../TestSelectQuery/timezoned/table1.tbl | 3 + .../dataset/TestSortQuery/table1/table1.tbl | 5 + .../dataset/TestSortQuery/table2/table2.tbl | 24 + .../TestTablePartitions/lineitemspecial.tbl | 5 + .../dataset/TestTajoJdbc/table1/table1.tbl | 5 + .../truncate_table2/table2.tbl | 4 + .../src/test/resources/log4j.properties | 28 + .../src/test/resources/python/__init__.py | 17 + .../src/test/resources/python/test_funcs.py | 33 + .../src/test/resources/python/test_funcs2.py | 32 + .../src/test/resources/python/test_udaf.py | 76 + .../alter_table_add_new_column_ddl.sql | 1 + .../alter_table_add_partition1.sql | 1 + .../alter_table_add_partition2.sql | 1 + .../alter_table_drop_partition1.sql | 1 + .../alter_table_drop_partition2.sql | 1 + .../alter_table_rename_column_ddl.sql | 1 + .../alter_table_rename_table_ddl.sql | 1 + .../alter_table_set_property_delimiter.sql | 1 + .../alter_table_set_property_timezone.sql | 1 + .../TestAlterTable/create_partitioned_table.sql | 1 + .../queries/TestAlterTable/table1_ddl.sql | 1 + .../queries/TestAlterTable/table2_ddl.sql | 1 + .../testAlterTableSetProperty.sql | 1 + .../testAlterTableSetProperty2.sql | 1 + .../TestBuiltinFunctions/testAvgDouble.sql | 1 + .../queries/TestBuiltinFunctions/testAvgInt.sql | 1 + .../TestBuiltinFunctions/testAvgLong.sql | 1 + .../testAvgLongOverflow.sql | 1 + .../queries/TestBuiltinFunctions/testCount.sql | 1 + .../TestBuiltinFunctions/testMaxLong.sql | 1 + .../TestBuiltinFunctions/testMaxString.sql | 1 + .../TestBuiltinFunctions/testMinLong.sql | 1 + .../TestBuiltinFunctions/testMinString.sql | 1 + .../queries/TestBuiltinFunctions/testRandom.sql | 1 + .../TestBuiltinFunctions/testSplitPart.sql | 1 + .../testSplitPartByString.sql | 1 + .../testSplitPartNested.sql | 1 + .../queries/TestCTASQuery/CtasWithGroupby.sql | 2 + .../queries/TestCTASQuery/CtasWithLimit.sql | 13 + .../TestCTASQuery/CtasWithManagedTable.sql | 12 + .../TestCTASQuery/CtasWithMultipleUnions.sql | 12 + .../queries/TestCTASQuery/CtasWithOptions.sql | 13 + .../queries/TestCTASQuery/CtasWithOrderby.sql | 11 + .../queries/TestCTASQuery/CtasWithStoreType.sql | 12 + .../queries/TestCTASQuery/CtasWithTextFile.sql | 12 + .../queries/TestCTASQuery/CtasWithUnion.sql | 35 + .../resources/queries/TestCTASQuery/check1.sql | 1 + .../resources/queries/TestCTASQuery/check2.sql | 1 + .../testCtasWithColumnedPartition.sql | 2 + .../TestCTASQuery/testCtasWithGroupby.sql | 1 + .../queries/TestCTASQuery/testCtasWithLimit.sql | 1 + .../testCtasWithMultipleUnions.sql | 1 + .../TestCTASQuery/testCtasWithOptions.sql | 1 + .../TestCTASQuery/testCtasWithOrderby.sql | 1 + .../TestCTASQuery/testCtasWithStoreType.sql | 1 + .../TestCTASQuery/testCtasWithTextFile.sql | 1 + .../queries/TestCTASQuery/testCtasWithUnion.sql | 1 + .../testCtasWithoutTableDefinition.sql | 2 + .../TestCaseByCases/testTAJO1224Case1.sql | 1 + .../queries/TestCaseByCases/testTAJO415Case.sql | 36 + .../queries/TestCaseByCases/testTAJO418Case.sql | 29 + .../queries/TestCaseByCases/testTAJO619Case.sql | 4 + .../queries/TestCaseByCases/testTAJO718Case.sql | 10 + .../queries/TestCaseByCases/testTAJO739Case.sql | 5 + .../TestCaseByCases/testTAJO914Case1.sql | 10 + .../TestCaseByCases/testTAJO914Case2.sql | 9 + .../TestCaseByCases/testTAJO914Case3.sql | 10 + .../TestCaseByCases/testTAJO914Case4.sql | 10 + .../TestCaseByCases/testTAJO917Case1.sql | 13 + .../queries/TestCreateIndex/testCreateIndex.sql | 1 + .../testCreateIndexOnExpression.sql | 1 + .../testCreateIndexOnLocation.sql | 1 + .../testCreateIndexOnMultiAttrs.sql | 1 + .../testCreateIndexOnMultiExprs.sql | 1 + .../testCreateIndexWithCondition.sql | 1 + .../create_table_various_types.sql | 50 + ...ate_table_various_types_for_hive_catalog.sql | 50 + .../quoted_identifier_mixed_chars_1.sql | 1 + .../quoted_identifier_mixed_chars_2.sql | 1 + .../quoted_identifier_mixed_chars_3.sql | 22 + .../quoted_identifier_mixed_chars_ddl_1.sql | 1 + .../quoted_identifier_mixed_chars_ddl_2.sql | 1 + .../quoted_identifier_non_ascii_1.sql | 1 + .../quoted_identifier_non_ascii_2.sql | 1 + .../quoted_identifier_non_ascii_3.sql | 1 + .../quoted_identifier_non_ascii_ddl.sql | 1 + .../queries/TestCreateTable/table1_ddl.sql | 1 + .../TestCreateTable/testNestedRecord1.sql | 1 + .../TestCreateTable/testNestedRecord2.sql | 1 + .../queries/TestDropTable/drop_table_ddl.sql | 1 + .../queries/TestDropTable/table1_ddl.sql | 1 + .../TestGroupByQuery/testComplexParameter.sql | 1 + .../TestGroupByQuery/testComplexParameter2.sql | 1 + .../testComplexParameterWithSubQuery.sql | 6 + .../testComplexTargetWithPythonUdaf.sql | 1 + .../testDistinctAggregation1.sql | 1 + .../testDistinctAggregation2.sql | 1 + .../testDistinctAggregation3.sql | 1 + .../testDistinctAggregation4.sql | 1 + .../testDistinctAggregation5.sql | 1 + .../testDistinctAggregation6.sql | 9 + .../testDistinctAggregation7.sql | 6 + .../testDistinctAggregation8.sql | 9 + .../testDistinctAggregationCaseByCase3.sql | 8 + .../testDistinctAggregationCaseByCase4.sql | 7 + .../testDistinctAggregationWithHaving1.sql | 1 + .../testDistinctAggregationWithUnion1.sql | 21 + .../testDistinctAggregation_case1.sql | 7 + .../testDistinctAggregation_case10.sql | 5 + .../testDistinctAggregation_case2.sql | 8 + .../testDistinctAggregation_case3.sql | 9 + .../testDistinctAggregation_case4.sql | 10 + .../testDistinctAggregation_case5.sql | 10 + .../testDistinctAggregation_case6.sql | 12 + .../testDistinctAggregation_case7.sql | 9 + .../testDistinctAggregation_case8.sql | 10 + .../testDistinctAggregation_case9.sql | 11 + .../testDistinctPythonUdafWithUnion1.sql | 21 + .../queries/TestGroupByQuery/testGroupBy.sql | 1 + .../queries/TestGroupByQuery/testGroupBy2.sql | 1 + .../queries/TestGroupByQuery/testGroupBy3.sql | 1 + .../queries/TestGroupByQuery/testGroupBy4.sql | 9 + .../queries/TestGroupByQuery/testGroupBy5.sql | 1 + .../TestGroupByQuery/testGroupByNested1.sql | 8 + .../TestGroupByQuery/testGroupByNested2.sql | 10 + .../testGroupByWithConstantKeys1.sql | 1 + .../testGroupByWithConstantKeys2.sql | 1 + .../testGroupByWithConstantKeys3.sql | 8 + .../testGroupByWithConstantKeys4.sql | 12 + .../testGroupByWithConstantKeys5.sql | 13 + .../testGroupByWithExpressionKeys1.sql | 1 + .../testGroupByWithExpressionKeys2.sql | 1 + .../testGroupByWithNullData1.sql | 1 + .../testGroupByWithNullData10.sql | 3 + .../testGroupByWithNullData11.sql | 5 + .../testGroupByWithNullData12.sql | 29 + .../testGroupByWithNullData2.sql | 1 + .../testGroupByWithNullData3.sql | 3 + .../testGroupByWithNullData4.sql | 3 + .../testGroupByWithNullData5.sql | 1 + .../testGroupByWithNullData6.sql | 1 + .../testGroupByWithNullData7.sql | 1 + .../testGroupByWithNullData8.sql | 1 + .../testGroupByWithNullData9.sql | 4 + .../testGroupByWithSameConstantKeys1.sql | 1 + .../testGroupByWithSameExprs1.sql | 8 + .../testGroupByWithSameExprs2.sql | 8 + .../TestGroupByQuery/testGroupbyWithJson.json | 127 ++ .../TestGroupByQuery/testGroupbyWithLimit1.sql | 1 + .../TestGroupByQuery/testGroupbyWithLimit2.sql | 1 + .../TestGroupByQuery/testGroupbyWithLimit3.sql | 1 + .../testGroupbyWithPythonFunc.sql | 1 + .../testGroupbyWithPythonFunc2.sql | 1 + .../testHavingWithAggFunction.sql | 1 + .../testHavingWithNamedTarget.sql | 13 + .../queries/TestGroupByQuery/testPythonUdaf.sql | 1 + .../TestGroupByQuery/testPythonUdaf2.sql | 1 + .../TestGroupByQuery/testPythonUdaf3.sql | 1 + .../testPythonUdafWithHaving.sql | 3 + .../testPythonUdafWithNullData.sql | 4 + .../TestInSubquery/testInAndNotInSubQuery.sql | 3 + .../queries/TestInSubquery/testInSubQuery.sql | 1 + .../queries/TestInSubquery/testInSubQuery2.sql | 2 + .../TestInSubquery/testInSubQueryWithJoin.sql | 2 + .../testInSubQueryWithOtherConditions.sql | 2 + .../testInSubQueryWithTableSubQuery.sql | 2 + .../TestInSubquery/testMultipleInSubQuery.sql | 5 + .../testMultipleNotInSubQuery.sql | 3 + .../testNestedInAndNotInSubQuery.sql | 5 + .../TestInSubquery/testNestedInSubQuery.sql | 4 + .../TestInSubquery/testNestedInSubQuery2.sql | 4 + .../TestInSubquery/testNestedNotInSubQuery.sql | 4 + .../TestInSubquery/testNotInSubQuery.sql | 1 + .../testSameKeyNameOfOuterAndInnerQueries.sql | 22 + .../TestInSubquery/testWithAsteriskAndJoin.sql | 7 + .../testBroadcastTwoPartJoin.sql | 19 + .../testCrossJoinAndCaseWhen.sql | 18 + .../testCrossJoinWithAsterisk1.sql | 1 + .../testCrossJoinWithAsterisk2.sql | 1 + .../testCrossJoinWithAsterisk3.sql | 1 + .../testCrossJoinWithAsterisk4.sql | 1 + .../testBroadcastSubquery.sql | 12 + .../testBroadcastSubquery2.sql | 19 + .../testThetaJoinKeyPairs.sql | 20 + .../TestInsertQuery/full_table_csv_ddl.sql | 1 + .../TestInsertQuery/full_table_parquet_ddl.sql | 1 + .../TestInsertQuery/lineitem_year_month_ddl.sql | 18 + .../load_to_lineitem_year_month.sql | 1 + .../TestInsertQuery/nation_diff_col_order.ddl | 1 + .../queries/TestInsertQuery/table1_ddl.sql | 1 + .../queries/TestInsertQuery/test1_ddl.sql | 1 + .../TestInsertQuery/test1_nolength_ddl.sql | 1 + .../queries/TestInsertQuery/testInsertInto.sql | 1 + .../testInsertIntoSelectWithFixedSizeChar.sql | 4 + ...tIntoSelectWithFixedSizeCharWithNoLength.sql | 2 + .../TestInsertQuery/testInsertOverwrite.sql | 1 + .../testInsertOverwriteLocation.sql | 1 + ...stInsertOverwriteLocationWithCompression.sql | 1 + .../testInsertOverwriteLocationWithUnion.sql | 4 + ...verwriteLocationWithUnionDifferenceAlias.sql | 4 + .../testInsertOverwriteSmallerColumns.sql | 1 + .../testInsertOverwriteWithAsterisk.sql | 1 + .../testInsertOverwriteWithAsteriskAndMore.sql | 1 + .../testInsertOverwriteWithCompression.sql | 1 + .../testInsertOverwriteWithCompression_ddl.sql | 4 + .../testInsertOverwriteWithDatabase.sql | 1 + .../testInsertOverwriteWithTargetColumns.sql | 1 + .../testInsertOverwriteWithUnion.sql | 4 + ...stInsertOverwriteWithUnionDifferentAlias.sql | 4 + .../testInsertWithDifferentColumnOrder.sql | 1 + .../selfJoinOfPartitionedTable.sql | 9 + .../testBroadcastPartitionTable.sql | 16 + ...estFilterPushDownPartitionColumnCaseWhen.sql | 6 + ...rtitionedBroadcastDataFileWithZeroLength.sql | 3 + ...titionedBroadcastDataFileWithZeroLength2.sql | 5 + .../testNoProjectionJoinQual.sql | 1 + .../testPartialFilterPushDown.sql | 9 + .../testPartialFilterPushDownOuterJoin.sql | 4 + .../testPartialFilterPushDownOuterJoin2.sql | 5 + .../testPartitionTableJoinSmallTable.sql | 11 + .../TestJoinQuery/create_customer_large_ddl.sql | 7 + .../TestJoinQuery/create_lineitem_large_ddl.sql | 7 + .../TestJoinQuery/create_orders_large_ddl.sql | 7 + .../TestJoinQuery/customer_partition_ddl.sql | 9 + .../TestJoinQuery/insert_into_customer.sql | 11 + .../insert_into_customer_partition.sql | 11 + .../TestJoinQuery/nation_multifile_ddl.sql | 5 + .../queries/TestJoinQuery/oj_table1_ddl.sql | 3 + .../queries/TestJoinQuery/oj_table2_ddl.sql | 3 + .../TestJoinQuery/orders_multifile_ddl.sql | 5 + .../TestJoinQuery/partitioned_customer_ddl.sql | 19 + .../queries/TestJoinQuery/table1_int4_ddl.sql | 3 + .../queries/TestJoinQuery/table1_int8_ddl.sql | 3 + .../TestJoinQuery/testComplexJoinCondition1.sql | 6 + .../TestJoinQuery/testComplexJoinCondition2.sql | 6 + .../TestJoinQuery/testComplexJoinCondition3.sql | 6 + .../TestJoinQuery/testComplexJoinCondition4.sql | 6 + .../TestJoinQuery/testComplexJoinCondition5.sql | 6 + .../TestJoinQuery/testComplexJoinCondition6.sql | 6 + .../TestJoinQuery/testComplexJoinCondition7.sql | 6 + .../testComplexJoinsWithCaseWhen.sql | 11 + .../testComplexJoinsWithCaseWhen2.sql | 9 + .../testCrossJoinWithEmptyTable1.sql | 8 + ...stCrossJoinWithThetaJoinConditionInWhere.sql | 2 + .../testDifferentTypesJoinCondition.sql | 1 + .../TestJoinQuery/testFullOuterJoin1.sql | 8 + .../testFullOuterJoinWithEmptyTable1.sql | 8 + .../TestJoinQuery/testInnerJoinAndCaseWhen.sql | 18 + .../testInnerJoinWithEmptyTable.sql | 8 + ...stInnerJoinWithThetaJoinConditionInWhere.sql | 3 + .../queries/TestJoinQuery/testJoinAsterisk.sql | 3 + .../TestJoinQuery/testJoinCoReferredEvals1.sql | 11 + .../testJoinCoReferredEvalsFilterPushdown.sql | 13 + .../testJoinCoReferredEvalsWithSameExprs1.sql | 14 + .../testJoinCoReferredEvalsWithSameExprs2.sql | 22 + .../testJoinFilterOfRowPreservedTable1.sql | 8 + .../testJoinOnMultipleDatabases.sql | 25 + .../testJoinOnMultipleDatabasesWithJson.json | 210 +++ .../queries/TestJoinQuery/testJoinWithJson.json | 92 ++ .../TestJoinQuery/testJoinWithJson2.json | 219 +++ .../testJoinWithMultipleJoinQual1.sql | 20 + .../testJoinWithMultipleJoinQual2.sql | 8 + .../testJoinWithMultipleJoinQual3.sql | 9 + .../testJoinWithMultipleJoinQual4.sql | 10 + .../testJoinWithMultipleJoinTypes.sql | 4 + .../TestJoinQuery/testJoinWithOrPredicates.sql | 6 + .../TestJoinQuery/testLeftOuterJoin1.sql | 9 + .../testLeftOuterJoinWithConstantExpr1.sql | 9 + .../testLeftOuterJoinWithConstantExpr2.sql | 9 + .../testLeftOuterJoinWithConstantExpr3.sql | 17 + .../testLeftOuterJoinWithConstantExpr4.sql | 6 + .../testLeftOuterJoinWithConstantExpr5.sql | 9 + .../testLeftOuterJoinWithEmptyTable1.sql | 9 + .../testLeftOuterJoinWithEmptyTable2.sql | 9 + .../testLeftOuterJoinWithEmptyTable3.sql | 14 + .../testLeftOuterJoinWithEmptyTable4.sql | 17 + .../testLeftOuterJoinWithEmptyTable5.sql | 11 + .../testLeftOuterJoinWithNull1.sql | 10 + .../testLeftOuterJoinWithNull2.sql | 11 + .../testLeftOuterJoinWithNull3.sql | 10 + ...ftOuterJoinWithThetaJoinConditionInWhere.sql | 3 + .../queries/TestJoinQuery/testNaturalJoin.sql | 3 + .../TestJoinQuery/testOuterJoinAndCaseWhen1.sql | 12 + .../TestJoinQuery/testRightOuterJoin1.sql | 8 + .../testRightOuterJoinWithEmptyTable1.sql | 8 + ...htOuterJoinWithThetaJoinConditionInWhere.sql | 3 + .../queries/TestJoinQuery/testTPCHQ2Join.sql | 25 + .../TestJoinQuery/testWhereClauseJoin1.sql | 11 + .../TestJoinQuery/testWhereClauseJoin2.sql | 9 + .../TestJoinQuery/testWhereClauseJoin3.sql | 10 + .../TestJoinQuery/testWhereClauseJoin4.sql | 9 + .../TestJoinQuery/testWhereClauseJoin5.sql | 15 + .../TestJoinQuery/testWhereClauseJoin6.sql | 19 + .../queries/TestLogicalPlanner/window1.sql | 5 + .../queries/TestNetTypes/table1_ddl.sql | 4 + .../queries/TestNetTypes/table2_ddl.sql | 4 + .../queries/TestNetTypes/testGroupby.sql | 8 + .../queries/TestNetTypes/testGroupby2.sql | 9 + .../resources/queries/TestNetTypes/testJoin.sql | 1 + .../queries/TestNetTypes/testSelect.sql | 1 + .../resources/queries/TestNetTypes/testSort.sql | 1 + .../queries/TestNetTypes/testSort2.sql | 1 + .../TestOuterJoinQuery/testLeftOuterJoin2.sql | 5 + .../TestOuterJoinQuery/testLeftOuterJoin3.sql | 7 + ...tMultipleBroadcastDataFileWithZeroLength.sql | 3 + ...MultipleBroadcastDataFileWithZeroLength2.sql | 5 + .../TestQueryValidation/error_groupby_1.sql | 1 + .../TestQueryValidation/error_groupby_2.sql | 1 + .../TestQueryValidation/invalid_casewhen_1.sql | 15 + .../TestQueryValidation/invalid_limit_1.sql | 1 + .../invalid_store_format.sql | 1 + .../TestQueryValidation/valid_groupby_1.sql | 1 + .../TestQueryValidation/valid_limit_1.sql | 1 + .../TestSQLAnalyzer/create_table_nested_1.sql | 1 + .../TestSQLAnalyzer/create_table_nested_2.sql | 1 + .../queries/TestSQLAnalyzer/setcatalog1.sql | 1 + .../queries/TestSQLAnalyzer/setcatalog2.sql | 1 + .../queries/TestSQLAnalyzer/setsession1.sql | 1 + .../queries/TestSQLAnalyzer/setsession2.sql | 1 + .../queries/TestSQLAnalyzer/setsession3.sql | 1 + .../queries/TestSQLAnalyzer/setsession4.sql | 1 + .../queries/TestSQLAnalyzer/setsession5.sql | 1 + .../queries/TestSQLAnalyzer/setsession6.sql | 1 + .../queries/TestSQLAnalyzer/setsession7.sql | 1 + .../queries/TestSQLAnalyzer/settimezone1.sql | 1 + .../queries/TestSQLAnalyzer/settimezone2.sql | 1 + .../queries/TestSQLAnalyzer/settimezone3.sql | 1 + .../queries/TestSQLAnalyzer/window1.sql | 5 + .../queries/TestSQLAnalyzer/window2.sql | 5 + .../queries/TestSQLAnalyzer/window3.sql | 5 + .../queries/TestSQLAnalyzer/window4.sql | 5 + .../queries/TestSQLAnalyzer/window5.sql | 6 + .../queries/TestSQLAnalyzer/window6.sql | 6 + .../queries/TestSQLAnalyzer/window7.sql | 6 + .../queries/TestSQLAnalyzer/window8.sql | 6 + .../queries/TestSQLAnalyzer/window9.sql | 9 + .../TestSelectNestedRecord/sample0_ddl.sql | 1 + .../TestSelectNestedRecord/sample1_ddl.sql | 7 + .../TestSelectNestedRecord/sample2_ddl.sql | 23 + .../testNestedFieldAsGroupbyKey1.sql | 9 + .../testNestedFieldAsJoinKey1.sql | 7 + .../TestSelectNestedRecord/testSelect0.sql | 1 + .../TestSelectNestedRecord/testSelect1.sql | 1 + .../TestSelectNestedRecord/testSelect2.sql | 61 + .../TestSelectNestedRecord/testSelect3.sql | 1 + .../TestSelectNestedRecord/tweets_ddl.sql | 74 + .../queries/TestSelectQuery/customer_ddl.sql | 9 + .../TestSelectQuery/datetime_table_ddl.sql | 4 + .../datetime_table_timezoned_ddl.sql | 4 + .../TestSelectQuery/insert_into_customer.sql | 11 + .../multibytes_delimiter_table1_ddl.sql | 3 + .../multibytes_delimiter_table2_ddl.sql | 3 + .../multibytes_delimiter_table3_ddl.sql | 3 + .../multibytes_delimiter_table4_ddl.sql | 3 + .../queries/TestSelectQuery/testCaseWhen.sql | 11 + .../TestSelectQuery/testCaseWhenRound.sql | 8 + .../TestSelectQuery/testCaseWhenWithoutElse.sql | 10 + .../testColumnEqualityButNotJoinCondition1.sql | 7 + .../testColumnEqualityButNotJoinCondition2.sql | 7 + .../TestSelectQuery/testCreateAfterSelect.sql | 1 + .../TestSelectQuery/testDatabaseRef1.sql | 1 + .../TestSelectQuery/testDatabaseRef2.sql | 1 + .../TestSelectQuery/testDatabaseRef3.sql | 1 + .../TestSelectQuery/testExplainSelect.sql | 1 + .../queries/TestSelectQuery/testInClause.sql | 1 + .../queries/TestSelectQuery/testInStrClause.sql | 1 + .../queries/TestSelectQuery/testLikeClause.sql | 1 + .../queries/TestSelectQuery/testLimit.sql | 1 + .../testMultiBytesDelimiter1.sql | 1 + .../testMultiBytesDelimiter2.sql | 1 + .../testMultiBytesDelimiter3.sql | 1 + .../testMultiBytesDelimiter4.sql | 1 + .../testNestedPythonFunction.sql | 1 + .../TestSelectQuery/testNonFromSelect1.sql | 1 + .../TestSelectQuery/testNonQualifiedNames.sql | 1 + .../queries/TestSelectQuery/testNotEqual.sql | 1 + .../queries/TestSelectQuery/testNotInClause.sql | 1 + .../TestSelectQuery/testNotInStrClause.sql | 1 + .../TestSelectQuery/testRealValueCompare.sql | 1 + .../queries/TestSelectQuery/testSelect.sql | 1 + .../queries/TestSelectQuery/testSelect2.sql | 1 + .../queries/TestSelectQuery/testSelect3.sql | 1 + .../TestSelectQuery/testSelectAsterik.sql | 1 + .../TestSelectQuery/testSelectAsterisk1.sql | 1 + .../TestSelectQuery/testSelectAsterisk2.sql | 1 + .../TestSelectQuery/testSelectAsterisk3.sql | 1 + .../TestSelectQuery/testSelectAsterisk4.sql | 1 + .../TestSelectQuery/testSelectAsterisk5.sql | 1 + .../TestSelectQuery/testSelectColumnAlias1.sql | 1 + ...testSelectColumnAliasExistingInRelation1.sql | 1 + ...testSelectColumnAliasExistingInRelation2.sql | 1 + ...testSelectColumnAliasExistingInRelation3.sql | 19 + .../TestSelectQuery/testSelectDistinct.sql | 7 + .../testSelectOnSessionTable.sql | 1 + .../TestSelectQuery/testSelectPythonFuncs.sql | 2 + ...tSelectSameConstantsWithDifferentAliases.sql | 1 + ...SelectSameConstantsWithDifferentAliases2.sql | 1 + ...SelectSameConstantsWithDifferentAliases3.sql | 10 + .../testSelectSameExprsWithDifferentAliases.sql | 1 + .../TestSelectQuery/testSelectWithJson.json | 74 + .../testSelectWithParentheses1.sql | 1 + .../testSelectWithParentheses2.sql | 1 + .../testSelectWithPredicateOnPythonFunc.sql | 1 + .../queries/TestSelectQuery/testSimpleQuery.sql | 1 + .../testSimpleQueryWithLimit.sql | 1 + ...testSimpleQueryWithLimitPartitionedTable.sql | 1 + .../TestSelectQuery/testStringCompare.sql | 1 + .../TestSelectQuery/testSumFloatOverflow.sql | 1 + .../TestSelectQuery/testSumIntOverflow.sql | 1 + .../TestSelectQuery/testTimezonedTable1.sql | 1 + .../TestSelectQuery/testTimezonedTable2.sql | 2 + .../TestSelectQuery/testTimezonedTable3.sql | 1 + .../TestSelectQuery/testTimezonedTable4.sql | 2 + .../TestSelectQuery/testTimezonedTable5.sql | 2 + .../queries/TestSelectQuery/testWhereCond1.sql | 1 + .../queries/TestSelectQuery/testWhereCond2.sql | 9 + .../TestSelectQuery/testWhereCondWithAlias1.sql | 1 + .../TestSelectQuery/testWhereCondWithAlias2.sql | 1 + .../create_table_with_asc_desc_keys.sql | 1 + .../create_table_with_date_ddl.sql | 10 + .../queries/TestSortQuery/testAsterisk.sql | 1 + .../queries/TestSortQuery/testSort.sql | 1 + .../TestSortQuery/testSortAfterGroupby.sql | 1 + .../testSortAfterGroupbyWithAlias.sql | 1 + .../queries/TestSortQuery/testSortDesc.sql | 1 + .../queries/TestSortQuery/testSortFirstDesc.sql | 1 + .../TestSortQuery/testSortOnNullColumn.sql | 13 + .../TestSortQuery/testSortOnUnicodeTextAsc.sql | 6 + .../TestSortQuery/testSortOnUnicodeTextDesc.sql | 6 + .../TestSortQuery/testSortWithAlias1.sql | 1 + .../TestSortQuery/testSortWithAlias2.sql | 9 + .../TestSortQuery/testSortWithAlias3.sql | 11 + .../testSortWithAliasButOriginalName.sql | 1 + .../TestSortQuery/testSortWithAscDescKeys.sql | 1 + .../TestSortQuery/testSortWithConstKeys.sql | 10 + .../queries/TestSortQuery/testSortWithDate.sql | 1 + .../queries/TestSortQuery/testSortWithExpr1.sql | 1 + .../queries/TestSortQuery/testSortWithExpr2.sql | 1 + .../queries/TestSortQuery/testSortWithJson.json | 65 + .../testSubQuerySortAfterGroupMultiBlocks.sql | 5 + .../queries/TestSortQuery/testTopK.sql | 1 + .../queries/TestSortQuery/testTopkWithJson.json | 51 + .../queries/TestTPCH/testFirstJoinInQ7.sql | 13 + .../queries/TestTPCH/testQ1OrderBy.sql | 12 + .../queries/TestTPCH/testQ2FourJoins.sql | 18 + .../queries/TestTPCH/testTPCH14Expr.sql | 12 + .../resources/queries/TestTPCH/testTPCHQ5.sql | 24 + .../queries/TestTablePartitions/case1.sql | 16 + .../queries/TestTablePartitions/case10.sql | 1 + .../queries/TestTablePartitions/case11.sql | 1 + .../queries/TestTablePartitions/case12.sql | 7 + .../queries/TestTablePartitions/case13.sql | 11 + .../queries/TestTablePartitions/case14.sql | 3 + .../queries/TestTablePartitions/case15.sql | 3 + .../queries/TestTablePartitions/case2.sql | 31 + .../queries/TestTablePartitions/case3.sql | 8 + .../queries/TestTablePartitions/case4.sql | 1 + .../queries/TestTablePartitions/case5.sql | 1 + .../queries/TestTablePartitions/case6.sql | 1 + .../queries/TestTablePartitions/case7.sql | 1 + .../queries/TestTablePartitions/case8.sql | 1 + .../queries/TestTablePartitions/case9.sql | 1 + .../TestTablePartitions/lineitemspecial_ddl.sql | 3 + .../TestTableSubQuery/testGroupBySubQuery.sql | 1 + .../testGroupbySubqueryWithJson.json | 59 + .../TestTableSubQuery/testJoinSubQuery.sql | 5 + .../TestTableSubQuery/testJoinSubQuery2.sql | 4 + .../testJoinSubqueryWithJson.json | 108 ++ .../TestTableSubQuery/testTableSubquery1.sql | 1 + .../TestTajoJdbc/create_table_with_date_ddl.sql | 10 + .../queries/TestTaskStatusUpdate/case1.sql | 1 + .../queries/TestTaskStatusUpdate/case2.sql | 5 + .../queries/TestTaskStatusUpdate/case3.sql | 10 + .../queries/TestTruncateTable/table1_ddl.sql | 1 + .../queries/TestTruncateTable/table2_ddl.sql | 1 + .../TestUnionQuery/testComplexUnion1.sql | 27 + .../TestUnionQuery/testComplexUnion2.sql | 35 + .../queries/TestUnionQuery/testUnion1.sql | 19 + .../queries/TestUnionQuery/testUnion10.sql | 158 ++ .../queries/TestUnionQuery/testUnion11.sql | 8 + .../queries/TestUnionQuery/testUnion12.sql | 14 + .../queries/TestUnionQuery/testUnion13.sql | 15 + .../queries/TestUnionQuery/testUnion14.sql | 8 + .../queries/TestUnionQuery/testUnion15.sql | 15 + .../queries/TestUnionQuery/testUnion16.sql | 15 + .../queries/TestUnionQuery/testUnion2.sql | 18 + .../queries/TestUnionQuery/testUnion3.sql | 19 + .../queries/TestUnionQuery/testUnion4.sql | 16 + .../queries/TestUnionQuery/testUnion5.sql | 20 + .../queries/TestUnionQuery/testUnion6.sql | 15 + .../queries/TestUnionQuery/testUnion7.sql | 18 + .../queries/TestUnionQuery/testUnion8.sql | 24 + .../queries/TestUnionQuery/testUnion9.sql | 29 + .../queries/TestUnionQuery/testUnionAll1.sql | 19 + .../queries/TestUnionQuery/testUnionAll10.sql | 158 ++ .../queries/TestUnionQuery/testUnionAll11.sql | 8 + .../queries/TestUnionQuery/testUnionAll12.sql | 13 + .../queries/TestUnionQuery/testUnionAll13.sql | 14 + .../queries/TestUnionQuery/testUnionAll14.sql | 8 + .../queries/TestUnionQuery/testUnionAll15.sql | 15 + .../queries/TestUnionQuery/testUnionAll16.sql | 15 + .../queries/TestUnionQuery/testUnionAll2.sql | 18 + .../queries/TestUnionQuery/testUnionAll3.sql | 19 + .../queries/TestUnionQuery/testUnionAll4.sql | 16 + .../queries/TestUnionQuery/testUnionAll5.sql | 20 + .../queries/TestUnionQuery/testUnionAll6.sql | 15 + .../queries/TestUnionQuery/testUnionAll7.sql | 18 + .../queries/TestUnionQuery/testUnionAll8.sql | 24 + .../queries/TestUnionQuery/testUnionAll9.sql | 29 + .../testUnionAllWithDifferentAlias.sql | 29 + ...estUnionAllWithDifferentAliasAndFunction.sql | 29 + .../testUnionAllWithSameAliasNames.sql | 25 + .../testUnionWithDifferentAlias.sql | 29 + .../testUnionWithDifferentAliasAndFunction.sql | 29 + .../testUnionWithSameAliasNames.sql | 25 + .../TestWindowQuery/testComplexOrderBy1.sql | 5 + .../queries/TestWindowQuery/testFirstValue1.sql | 18 + .../queries/TestWindowQuery/testLag1.sql | 18 + .../TestWindowQuery/testLagWithDefault.sql | 18 + .../TestWindowQuery/testLagWithNoArgs.sql | 18 + .../queries/TestWindowQuery/testLastValue1.sql | 18 + .../queries/TestWindowQuery/testLead1.sql | 18 + .../TestWindowQuery/testLeadWithDefault.sql | 18 + .../TestWindowQuery/testLeadWithNoArgs.sql | 18 + .../queries/TestWindowQuery/testRowNumber1.sql | 5 + .../queries/TestWindowQuery/testRowNumber2.sql | 5 + .../queries/TestWindowQuery/testRowNumber3.sql | 7 + .../queries/TestWindowQuery/testStdDevPop1.sql | 14 + .../queries/TestWindowQuery/testStdDevSamp1.sql | 14 + .../queries/TestWindowQuery/testWindow1.sql | 1 + .../queries/TestWindowQuery/testWindow2.sql | 1 + .../queries/TestWindowQuery/testWindow3.sql | 1 + .../queries/TestWindowQuery/testWindow4.sql | 1 + .../queries/TestWindowQuery/testWindow5.sql | 1 + .../queries/TestWindowQuery/testWindow6.sql | 1 + .../queries/TestWindowQuery/testWindow7.sql | 1 + .../queries/TestWindowQuery/testWindow8.sql | 7 + .../TestWindowQuery/testWindowBeforeLimit.sql | 6 + .../testWindowWithAggregation1.sql | 4 + .../testWindowWithAggregation2.sql | 7 + .../testWindowWithAggregation3.sql | 5 + .../testWindowWithAggregation4.sql | 8 + .../testWindowWithAggregation5.sql | 9 + .../testWindowWithAggregation6.sql | 10 + .../TestWindowQuery/testWindowWithOrderBy1.sql | 6 + .../TestWindowQuery/testWindowWithOrderBy2.sql | 6 + .../TestWindowQuery/testWindowWithOrderBy3.sql | 6 + .../TestWindowQuery/testWindowWithOrderBy4.sql | 7 + .../TestWindowQuery/testWindowWithOrderBy5.sql | 9 + .../TestWindowQuery/testWindowWithSubQuery.sql | 14 + .../TestWindowQuery/testWindowWithSubQuery2.sql | 15 + .../TestWindowQuery/testWindowWithSubQuery3.sql | 14 + .../TestWindowQuery/testWindowWithSubQuery4.sql | 14 + .../TestWindowQuery/testWindowWithSubQuery5.sql | 11 + .../TestWindowQuery/testWindowWithSubQuery6.sql | 9 + .../default/alter_table_add_partition_1.sql | 1 + .../default/alter_table_add_partition_2.sql | 1 + .../default/alter_table_add_partition_3.sql | 2 + .../default/alter_table_add_partition_4.sql | 1 + .../default/alter_table_add_partition_5.sql | 1 + .../default/alter_table_drop_partition_1.sql | 1 + .../default/alter_table_drop_partition_2.sql | 1 + .../default/alter_table_drop_partition_3.sql | 1 + .../default/alter_table_drop_partition_4.sql | 1 + .../default/alter_table_set_property_1.sql | 1 + .../default/alter_table_set_property_2.sql | 1 + .../default/alter_table_set_property_3.sql | 1 + .../resources/queries/default/asterisk_1.sql | 1 + .../resources/queries/default/asterisk_2.sql | 1 + .../resources/queries/default/asterisk_3.sql | 1 + .../resources/queries/default/asterisk_4.sql | 1 + .../create_partitioned_table_as_select.sql | 17 + .../queries/default/create_table_1.hiveql | 1 + .../queries/default/create_table_1.sql | 1 + .../queries/default/create_table_10.sql | 1 + .../queries/default/create_table_11.hiveql | 3 + .../queries/default/create_table_11.sql | 3 + .../queries/default/create_table_12.hiveql | 4 + .../queries/default/create_table_12.sql | 3 + .../queries/default/create_table_2.hiveql | 1 + .../queries/default/create_table_2.sql | 1 + .../queries/default/create_table_3.sql | 1 + .../queries/default/create_table_4.sql | 1 + .../queries/default/create_table_5.sql | 1 + .../queries/default/create_table_6.sql | 1 + .../queries/default/create_table_7.sql | 1 + .../queries/default/create_table_8.sql | 48 + .../queries/default/create_table_9.sql | 1 + .../queries/default/create_table_like_1.sql | 1 + .../create_table_partition_by_column.sql | 4 + .../create_table_partition_by_hash_1.sql | 3 + .../create_table_partition_by_hash_2.sql | 7 + .../default/create_table_partition_by_list.sql | 8 + .../default/create_table_partition_by_range.sql | 9 + .../resources/queries/default/drop_table.sql | 1 + .../queries/default/exists_predicate_1.sql | 1 + .../queries/default/exists_predicate_2.sql | 1 + .../resources/queries/default/groupby_1.sql | 1 + .../resources/queries/default/groupby_2.sql | 1 + .../resources/queries/default/groupby_3.sql | 1 + .../resources/queries/default/groupby_4.sql | 1 + .../resources/queries/default/groupby_5.sql | 1 + .../resources/queries/default/in_subquery_1.sql | 1 + .../resources/queries/default/in_subquery_2.sql | 1 + .../queries/default/insert_into_select_1.sql | 1 + .../queries/default/insert_into_select_2.sql | 1 + .../queries/default/insert_into_select_3.sql | 1 + .../default/insert_overwrite_into_select_1.sql | 1 + .../insert_overwrite_into_select_2.hiveql | 1 + .../default/insert_overwrite_into_select_2.sql | 1 + .../default/insert_overwrite_into_select_3.sql | 1 + .../test/resources/queries/default/join_1.sql | 1 + .../test/resources/queries/default/join_10.sql | 1 + .../test/resources/queries/default/join_11.sql | 1 + .../test/resources/queries/default/join_12.sql | 1 + .../test/resources/queries/default/join_13.sql | 13 + .../test/resources/queries/default/join_14.sql | 1 + .../resources/queries/default/join_15.hiveql | 1 + .../test/resources/queries/default/join_15.sql | 1 + .../test/resources/queries/default/join_2.sql | 1 + .../test/resources/queries/default/join_3.sql | 1 + .../test/resources/queries/default/join_4.sql | 1 + .../test/resources/queries/default/join_5.sql | 1 + .../test/resources/queries/default/join_6.sql | 1 + .../test/resources/queries/default/join_7.sql | 1 + .../test/resources/queries/default/join_8.sql | 13 + .../test/resources/queries/default/join_9.sql | 5 + .../test/resources/queries/default/select_1.sql | 1 + .../resources/queries/default/select_10.hiveql | 5 + .../resources/queries/default/select_10.sql | 5 + .../resources/queries/default/select_11.hiveql | 4 + .../resources/queries/default/select_11.sql | 6 + .../resources/queries/default/select_12.hiveql | 3 + .../resources/queries/default/select_13.hiveql | 2 + .../resources/queries/default/select_13.sql | 2 + .../resources/queries/default/select_14.sql | 2 + .../resources/queries/default/select_15.hiveql | 1 + .../resources/queries/default/select_15.sql | 1 + .../test/resources/queries/default/select_2.sql | 1 + .../test/resources/queries/default/select_3.sql | 1 + .../test/resources/queries/default/select_4.sql | 1 + .../test/resources/queries/default/select_5.sql | 1 + .../test/resources/queries/default/select_6.sql | 1 + .../test/resources/queries/default/select_7.sql | 1 + .../test/resources/queries/default/select_8.sql | 1 + .../resources/queries/default/select_9.hiveql | 4 + .../test/resources/queries/default/select_9.sql | 4 + .../test/resources/queries/default/set_1.sql | 1 + .../test/resources/queries/default/set_2.sql | 1 + .../test/resources/queries/default/set_3.sql | 1 + .../test/resources/queries/default/set_4.sql | 36 + .../queries/default/table_subquery1.sql | 19 + .../queries/default/table_subquery2.sql | 21 + .../resources/queries/default/union_1.hiveql | 14 + .../after_set_property_delimiter.result | 3 + .../before_set_property_delimiter.result | 3 + .../TestBuiltinFunctions/testAvgDouble.result | 5 + .../TestBuiltinFunctions/testAvgInt.result | 3 + .../TestBuiltinFunctions/testAvgLong.result | 3 + .../testAvgLongOverflow.result | 3 + .../TestBuiltinFunctions/testCount.result | 3 + .../TestBuiltinFunctions/testMaxLong.result | 3 + .../TestBuiltinFunctions/testMaxString.result | 3 + .../TestBuiltinFunctions/testMinLong.result | 3 + .../TestBuiltinFunctions/testMinString.result | 3 + .../TestBuiltinFunctions/testSplitPart.result | 7 + .../testSplitPartByString.result | 7 + .../testSplitPartNested.result | 7 + .../TestCTASQuery/testCtasWithGroupby.result | 7 + .../TestCTASQuery/testCtasWithLimit.result | 5 + .../TestCTASQuery/testCtasWithOptions.result | 5 + .../TestCTASQuery/testCtasWithOrderby.result | 7 + .../TestCTASQuery/testCtasWithStoreType.result | 5 + .../TestCTASQuery/testCtasWithTextFile.result | 5 + .../TestCTASQuery/testCtasWithUnion.result | 8 + .../TestCaseByCases/testTAJO1224Case1.result | 3 + .../TestCaseByCases/testTAJO415Case.result | 7 + .../TestCaseByCases/testTAJO418Case.result | 4 + .../TestCaseByCases/testTAJO619Case.result | 3 + .../TestCaseByCases/testTAJO718Case.result | 5 + .../TestCaseByCases/testTAJO739Case.result | 7 + .../TestCaseByCases/testTAJO914Case1.result | 5 + .../TestCaseByCases/testTAJO914Case2.result | 5 + .../TestCaseByCases/testTAJO914Case3.result | 5 + .../TestCaseByCases/testTAJO914Case4.result | 5 + .../TestCaseByCases/testTAJO917Case1.result | 7 + .../quoted_identifier_mixed_chars_1.result | 5 + .../quoted_identifier_mixed_chars_2.result | 5 + .../quoted_identifier_mixed_chars_3.result | 8 + .../quoted_identifier_non_ascii_1.result | 5 + .../quoted_identifier_non_ascii_2.result | 5 + .../quoted_identifier_non_ascii_3.result | 5 + .../testFindScalarFunctions.result | 2 + .../testComplexParameter.result | 3 + .../testComplexParameter2.result | 3 + .../testComplexParameterWithSubQuery.result | 3 + .../testComplexTargetWithPythonUdaf.result | 3 + .../testDistinctAggregation1.result | 5 + .../testDistinctAggregation2.result | 5 + .../testDistinctAggregation3.result | 3 + .../testDistinctAggregation4.result | 4 + .../testDistinctAggregation5.result | 4 + .../testDistinctAggregation6.result | 5 + .../testDistinctAggregation7.result | 3 + .../testDistinctAggregation8.result | 7 + .../testDistinctAggregationCaseByCase3.result | 3 + .../testDistinctAggregationCaseByCase4.result | 3 + .../testDistinctAggregationWithHaving1.result | 3 + .../testDistinctAggregationWithUnion1.result | 4 + .../testDistinctAggregation_case1.result | 4 + .../testDistinctAggregation_case10.result | 3 + .../testDistinctAggregation_case2.result | 4 + .../testDistinctAggregation_case3.result | 4 + .../testDistinctAggregation_case4.result | 5 + .../testDistinctAggregation_case5.result | 5 + .../testDistinctAggregation_case6.result | 5 + .../testDistinctAggregation_case7.result | 5 + .../testDistinctAggregation_case8.result | 6 + .../testDistinctAggregation_case9.result | 6 + .../testDistinctPythonUdafWithUnion1.result | 4 + .../results/TestGroupByQuery/testGroupBy.result | 3 + .../TestGroupByQuery/testGroupBy2.result | 4 + .../TestGroupByQuery/testGroupBy3.result | 5 + .../TestGroupByQuery/testGroupBy4.result | 5 + .../TestGroupByQuery/testGroupBy5.result | 5 + .../TestGroupByQuery/testGroupByNested1.result | 6 + .../TestGroupByQuery/testGroupByNested2.result | 6 + .../testGroupByWithConstantKeys1.result | 3 + .../testGroupByWithConstantKeys2.result | 5 + .../testGroupByWithConstantKeys3.result | 3 + .../testGroupByWithConstantKeys4.result | 5 + .../testGroupByWithConstantKeys5.result | 5 + .../testGroupByWithExpressionKeys1.result | 5 + .../testGroupByWithExpressionKeys2.result | 5 + .../testGroupByWithNullData1.result | 3 + .../testGroupByWithNullData10.result | 3 + .../testGroupByWithNullData11.result | 2 + .../testGroupByWithNullData12.result | 2 + .../testGroupByWithNullData2.result | 3 + .../testGroupByWithNullData3.result | 3 + .../testGroupByWithNullData4.result | 3 + .../testGroupByWithNullData5.result | 3 + .../testGroupByWithNullData6.result | 3 + .../testGroupByWithNullData7.result | 3 + .../testGroupByWithNullData8.result | 3 + .../testGroupByWithNullData9.result | 2 + .../testGroupByWithSameConstantKeys1.result | 5 + .../testGroupByWithSameExprs1.result | 6 + .../testGroupByWithSameExprs2.result | 6 + .../TestGroupByQuery/testGroupbyWithJson.result | 5 + .../testGroupbyWithLimit1.result | 3 + .../testGroupbyWithLimit2.result | 3 + .../testGroupbyWithLimit3.result | 3 + .../testGroupbyWithPythonFunc.result | 7 + .../testGroupbyWithPythonFunc2.result | 7 + .../testHavingWithAggFunction.result | 4 + .../testHavingWithNamedTarget.result | 5 + .../TestGroupByQuery/testPythonUdaf.result | 3 + .../TestGroupByQuery/testPythonUdaf2.result | 4 + .../TestGroupByQuery/testPythonUdaf3.result | 5 + .../testPythonUdafWithHaving.result | 4 + .../testPythonUdafWithNullData.result | 2 + .../TestHBaseTable/testBinaryMappedQuery.result | 81 + .../results/TestHBaseTable/testCTAS.result | 100 ++ .../testColumnKeyValueSelectQuery.result | 12 + .../TestHBaseTable/testIndexPredication.result | 38 + .../TestHBaseTable/testInsertInto.result | 3 + .../testInsertIntoBinaryMultiRegion.result | 100 ++ .../testInsertIntoColumnKeyValue.result | 21 + .../testInsertIntoMultiRegion.result | 100 ++ .../testInsertIntoMultiRegion2.result | 100 ++ ...stInsertIntoMultiRegionMultiRowFields.result | 100 ++ ...estInsertIntoMultiRegionWithSplitFile.result | 100 ++ .../testInsertIntoRowField.result | 4 + .../testInsertIntoUsingPut.result | 3 + .../TestHBaseTable/testInsertValues1.result | 4 + .../results/TestHBaseTable/testJoin.result | 7 + .../TestHBaseTable/testNonForwardQuery.result | 102 ++ .../testRowFieldSelectQuery.result | 88 ++ .../TestHBaseTable/testSimpleSelectQuery.result | 88 ++ .../testInAndNotInSubQuery.result | 24 + .../TestInSubquery/testInSubQuery.result | 27 + .../TestInSubquery/testInSubQuery2.result | 3 + .../testInSubQueryWithJoin.result | 5 + .../testInSubQueryWithOtherConditions.result | 25 + .../testInSubQueryWithTableSubQuery.result | 4 + .../testMultipleInSubQuery.result | 5 + .../testMultipleNotInSubQuery.result | 20 + .../testNestedInAndNotInSubQuery.result | 3 + .../TestInSubquery/testNestedInSubQuery.result | 3 + .../TestInSubquery/testNestedInSubQuery2.result | 3 + .../testNestedNotInSubQuery.result | 7 + .../TestInSubquery/testNotInSubQuery.result | 22 + ...testSameKeyNameOfOuterAndInnerQueries.result | 3 + .../testWithAsteriskAndJoin.result | 6 + .../TestIndexScan/testOnMultipleExprs.result | 3 + .../TestIndexScan/testOnMultipleKeys.result | 3 + .../TestIndexScan/testOnMultipleKeys2.result | 3 + .../testOnSortedNonUniqueKeys.result | 4 + .../TestIndexScan/testOnUnsortedTextKeys.result | 3 + .../TestIndexScan/testWithGroupBy.result | 3 + .../results/TestIndexScan/testWithJoin.result | 4 + .../results/TestIndexScan/testWithSort.result | 4 + .../testBroadcastTwoPartJoin.Hash.plan | 135 ++ ...stBroadcastTwoPartJoin.Hash_NoBroadcast.plan | 249 ++++ .../testBroadcastTwoPartJoin.Sort.plan | 135 ++ ...stBroadcastTwoPartJoin.Sort_NoBroadcast.plan | 249 ++++ .../testBroadcastTwoPartJoin.result | 7 + .../testComplexJoinCondition1.Hash.plan | 78 + ...tComplexJoinCondition1.Hash_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition1.Sort.plan | 78 + ...tComplexJoinCondition1.Sort_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition1.result | 27 + .../testComplexJoinCondition2.Hash.plan | 78 + ...tComplexJoinCondition2.Hash_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition2.Sort.plan | 78 + ...tComplexJoinCondition2.Sort_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition2.result | 27 + .../testComplexJoinCondition3.Hash.plan | 78 + ...tComplexJoinCondition3.Hash_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition3.Sort.plan | 78 + ...tComplexJoinCondition3.Sort_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition3.result | 27 + .../testComplexJoinCondition4.Hash.plan | 78 + ...tComplexJoinCondition4.Hash_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition4.Sort.plan | 78 + ...tComplexJoinCondition4.Sort_NoBroadcast.plan | 105 ++ .../testComplexJoinCondition4.result | 29 + .../testCrossJoin.1.Hash.plan | 76 + .../testCrossJoin.1.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoin.1.Sort.plan | 76 + .../testCrossJoin.1.Sort_NoBroadcast.plan | 103 ++ .../TestInnerJoinQuery/testCrossJoin.1.result | 127 ++ .../testCrossJoin.2.Hash.plan | 51 + .../testCrossJoin.2.Hash_NoBroadcast.plan | 78 + .../testCrossJoin.2.Sort.plan | 51 + .../testCrossJoin.2.Sort_NoBroadcast.plan | 78 + .../TestInnerJoinQuery/testCrossJoin.2.result | 27 + .../testCrossJoin.3.Hash.plan | 51 + .../testCrossJoin.3.Hash_NoBroadcast.plan | 78 + .../testCrossJoin.3.Sort.plan | 51 + .../testCrossJoin.3.Sort_NoBroadcast.plan | 78 + .../TestInnerJoinQuery/testCrossJoin.3.result | 27 + .../testCrossJoin.4.Hash.plan | 51 + .../testCrossJoin.4.Hash_NoBroadcast.plan | 78 + .../testCrossJoin.4.Sort.plan | 51 + .../testCrossJoin.4.Sort_NoBroadcast.plan | 78 + .../TestInnerJoinQuery/testCrossJoin.4.result | 27 + .../testCrossJoin.5.Hash.plan | 76 + .../testCrossJoin.5.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoin.5.Sort.plan | 76 + .../testCrossJoin.5.Sort_NoBroadcast.plan | 103 ++ .../TestInnerJoinQuery/testCrossJoin.5.result | 27 + .../testCrossJoinAndCaseWhen.Hash.plan | 78 + ...stCrossJoinAndCaseWhen.Hash_NoBroadcast.plan | 105 ++ .../testCrossJoinAndCaseWhen.Sort.plan | 78 + ...stCrossJoinAndCaseWhen.Sort_NoBroadcast.plan | 105 ++ .../testCrossJoinAndCaseWhen.result | 27 + .../testCrossJoinWithAsterisk1.Hash.plan | 76 + ...CrossJoinWithAsterisk1.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk1.Sort.plan | 76 + ...CrossJoinWithAsterisk1.Sort_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk1.result | 27 + .../testCrossJoinWithAsterisk2.Hash.plan | 76 + ...CrossJoinWithAsterisk2.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk2.Sort.plan | 76 + ...CrossJoinWithAsterisk2.Sort_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk2.result | 27 + .../testCrossJoinWithAsterisk3.Hash.plan | 76 + ...CrossJoinWithAsterisk3.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk3.Sort.plan | 76 + ...CrossJoinWithAsterisk3.Sort_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk3.result | 27 + .../testCrossJoinWithAsterisk4.Hash.plan | 76 + ...CrossJoinWithAsterisk4.Hash_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk4.Sort.plan | 76 + ...CrossJoinWithAsterisk4.Sort_NoBroadcast.plan | 103 ++ .../testCrossJoinWithAsterisk4.result | 27 + .../testCrossJoinWithEmptyTable1.Hash.plan | 78 + ...ossJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 ++ .../testCrossJoinWithEmptyTable1.Sort.plan | 78 + ...ossJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 ++ .../testCrossJoinWithEmptyTable1.result | 2 + ...sJoinWithThetaJoinConditionInWhere.Hash.plan | 63 + ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 90 ++ ...sJoinWithThetaJoinConditionInWhere.Sort.plan | 63 + ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 90 ++ ...rossJoinWithThetaJoinConditionInWhere.result | 12 + .../testDifferentTypesJoinCondition.Hash.plan | 53 + ...rentTypesJoinCondition.Hash_NoBroadcast.plan | 80 + .../testDifferentTypesJoinCondition.Sort.plan | 53 + ...rentTypesJoinCondition.Sort_NoBroadcast.plan | 80 + .../testDifferentTypesJoinCondition.result | 7 + .../testInnerJoinAndCaseWhen.Hash.plan | 78 + ...stInnerJoinAndCaseWhen.Hash_NoBroadcast.plan | 105 ++ .../testInnerJoinAndCaseWhen.Sort.plan | 78 + ...stInnerJoinAndCaseWhen.Sort_NoBroadcast.plan | 105 ++ .../testInnerJoinAndCaseWhen.result | 27 + .../testInnerJoinWithEmptyTable.Hash.plan | 78 + ...nnerJoinWithEmptyTable.Hash_NoBroadcast.plan | 105 ++ .../testInnerJoinWithEmptyTable.Sort.plan | 78 + ...nnerJoinWithEmptyTable.Sort_NoBroadcast.plan | 105 ++ .../testInnerJoinWithEmptyTable.result | 2 + ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 + ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 ++ ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 + ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 ++ ...nnerJoinWithThetaJoinConditionInWhere.result | 7 + .../testJoinAsterisk.Hash.plan | 53 + .../testJoinAsterisk.Hash_NoBroadcast.plan | 80 + .../testJoinAsterisk.Sort.plan | 53 + .../testJoinAsterisk.Sort_NoBroadcast.plan | 80 + .../TestInnerJoinQuery/testJoinAsterisk.result | 7 + .../testJoinCoReferredEvals1.Hash.plan | 78 + ...stJoinCoReferredEvals1.Hash_NoBroadcast.plan | 105 ++ .../testJoinCoReferredEvals1.Sort.plan | 78 + ...stJoinCoReferredEvals1.Sort_NoBroadcast.plan | 105 ++ .../testJoinCoReferredEvals1.result | 27 + ...tJoinCoReferredEvalsWithSameExprs1.Hash.plan | 88 ++ ...redEvalsWithSameExprs1.Hash_NoBroadcast.plan | 115 ++ ...tJoinCoReferredEvalsWithSameExprs1.Sort.plan | 88 ++ ...redEvalsWithSameExprs1.Sort_NoBroadcast.plan | 115 ++ ...testJoinCoReferredEvalsWithSameExprs1.result | 22 + ...tJoinCoReferredEvalsWithSameExprs2.Hash.plan | 119 ++ ...redEvalsWithSameExprs2.Hash_NoBroadcast.plan | 146 ++ ...tJoinCoReferredEvalsWithSameExprs2.Sort.plan | 119 ++ ...redEvalsWithSameExprs2.Sort_NoBroadcast.plan | 146 ++ ...testJoinCoReferredEvalsWithSameExprs2.result | 22 + .../testJoinOnMultipleDatabases.Hash.plan | 135 ++ ...oinOnMultipleDatabases.Hash_NoBroadcast.plan | 249 ++++ .../testJoinOnMultipleDatabases.Sort.plan | 135 ++ ...oinOnMultipleDatabases.Sort_NoBroadcast.plan | 249 ++++ .../testJoinOnMultipleDatabases.result | 5 + .../testJoinOnMultipleDatabasesWithJson.result | 5 + .../TestInnerJoinQuery/testJoinWithJson.result | 27 + .../testJoinWithMultipleJoinQual1.Hash.plan | 135 ++ ...nWithMultipleJoinQual1.Hash_NoBroadcast.plan | 249 ++++ .../testJoinWithMultipleJoinQual1.Sort.plan | 135 ++ ...nWithMultipleJoinQual1.Sort_NoBroadcast.plan | 249 ++++ .../testJoinWithMultipleJoinQual1.result | 2 + .../testJoinWithOrPredicates.Hash.plan | 90 ++ ...stJoinWithOrPredicates.Hash_NoBroadcast.plan | 117 ++ .../testJoinWithOrPredicates.Sort.plan | 90 ++ ...stJoinWithOrPredicates.Sort_NoBroadcast.plan | 117 ++ .../testJoinWithOrPredicates.result | 4 + .../testNaturalJoin.Hash.plan | 78 + .../testNaturalJoin.Hash_NoBroadcast.plan | 105 ++ .../testNaturalJoin.Sort.plan | 78 + .../testNaturalJoin.Sort_NoBroadcast.plan | 105 ++ .../TestInnerJoinQuery/testNaturalJoin.result | 27 + .../TestInnerJoinQuery/testTPCHQ2Join.Hash.plan | 135 ++ .../testTPCHQ2Join.Hash_NoBroadcast.plan | 249 ++++ .../TestInnerJoinQuery/testTPCHQ2Join.Sort.plan | 135 ++ .../testTPCHQ2Join.Sort_NoBroadcast.plan | 249 ++++ .../TestInnerJoinQuery/testTPCHQ2Join.result | 5 + .../testWhereClauseJoin1.Hash.plan | 78 + .../testWhereClauseJoin1.Hash_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin1.Sort.plan | 78 + .../testWhereClauseJoin1.Sort_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin1.result | 27 + .../testWhereClauseJoin2.Hash.plan | 78 + .../testWhereClauseJoin2.Hash_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin2.Sort.plan | 78 + .../testWhereClauseJoin2.Sort_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin2.result | 27 + .../testWhereClauseJoin3.Hash.plan | 78 + .../testWhereClauseJoin3.Hash_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin3.Sort.plan | 78 + .../testWhereClauseJoin3.Sort_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin3.result | 27 + .../testWhereClauseJoin4.Hash.plan | 78 + .../testWhereClauseJoin4.Hash_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin4.Sort.plan | 78 + .../testWhereClauseJoin4.Sort_NoBroadcast.plan | 105 ++ .../testWhereClauseJoin4.result | 27 + .../testWhereClauseJoin5.Hash.plan | 97 ++ .../testWhereClauseJoin5.Hash_NoBroadcast.plan | 153 ++ .../testWhereClauseJoin5.Sort.plan | 97 ++ .../testWhereClauseJoin5.Sort_NoBroadcast.plan | 153 ++ .../testWhereClauseJoin5.result | 5 + .../testWhereClauseJoin6.Hash.plan | 116 ++ .../testWhereClauseJoin6.Hash_NoBroadcast.plan | 201 +++ .../testWhereClauseJoin6.Sort.plan | 116 ++ .../testWhereClauseJoin6.Sort_NoBroadcast.plan | 201 +++ .../testWhereClauseJoin6.result | 5 + .../testBroadcastSubquery.Hash.plan | 109 ++ .../testBroadcastSubquery.Hash_NoBroadcast.plan | 165 ++ .../testBroadcastSubquery.Sort.plan | 109 ++ .../testBroadcastSubquery.Sort_NoBroadcast.plan | 165 ++ .../testBroadcastSubquery.result | 7 + .../testBroadcastSubquery2.Hash.plan | 216 +++ ...testBroadcastSubquery2.Hash_NoBroadcast.plan | 328 ++++ .../testBroadcastSubquery2.Sort.plan | 216 +++ ...testBroadcastSubquery2.Sort_NoBroadcast.plan | 328 ++++ .../testBroadcastSubquery2.result | 3 + .../testComplexJoinCondition5.Hash.plan | 90 ++ ...tComplexJoinCondition5.Hash_NoBroadcast.plan | 117 ++ .../testComplexJoinCondition5.Sort.plan | 90 ++ ...tComplexJoinCondition5.Sort_NoBroadcast.plan | 117 ++ .../testComplexJoinCondition5.result | 29 + .../testComplexJoinCondition6.Hash.plan | 109 ++ ...tComplexJoinCondition6.Hash_NoBroadcast.plan | 145 ++ .../testComplexJoinCondition6.Sort.plan | 109 ++ ...tComplexJoinCondition6.Sort_NoBroadcast.plan | 145 ++ .../testComplexJoinCondition6.result | 56 + .../testComplexJoinCondition7.Hash.plan | 109 ++ ...tComplexJoinCondition7.Hash_NoBroadcast.plan | 145 ++ .../testComplexJoinCondition7.Sort.plan | 109 ++ ...tComplexJoinCondition7.Sort_NoBroadcast.plan | 145 ++ .../testComplexJoinCondition7.result | 56 + .../testJoinWithJson2.result | 5 + .../testJoinWithMultipleJoinQual2.Hash.plan | 86 ++ ...nWithMultipleJoinQual2.Hash_NoBroadcast.plan | 142 ++ .../testJoinWithMultipleJoinQual2.Sort.plan | 86 ++ ...nWithMultipleJoinQual2.Sort_NoBroadcast.plan | 142 ++ .../testJoinWithMultipleJoinQual2.result | 3 + .../testJoinWithMultipleJoinQual3.Hash.plan | 105 ++ ...nWithMultipleJoinQual3.Hash_NoBroadcast.plan | 190 +++ .../testJoinWithMultipleJoinQual3.Sort.plan | 105 ++ ...nWithMultipleJoinQual3.Sort_NoBroadcast.plan | 190 +++ .../testJoinWithMultipleJoinQual3.result | 5 + .../testJoinWithMultipleJoinQual4.Hash.plan | 109 ++ ...nWithMultipleJoinQual4.Hash_NoBroadcast.plan | 194 +++ .../testJoinWithMultipleJoinQual4.Sort.plan | 109 ++ ...nWithMultipleJoinQual4.Sort_NoBroadcast.plan | 194 +++ .../testJoinWithMultipleJoinQual4.result | 4 + .../testThetaJoinKeyPairs.Hash.plan | 146 ++ .../testThetaJoinKeyPairs.Hash_NoBroadcast.plan | 200 +++ .../testThetaJoinKeyPairs.Sort.plan | 146 ++ .../testThetaJoinKeyPairs.Sort_NoBroadcast.plan | 200 +++ .../testThetaJoinKeyPairs.result | 21 + ...estInsertOverwriteWithAsteriskAndMore.result | 7 + ...sertOverwriteWithAsteriskUsingParquet.result | 4 + ...ertOverwriteWithAsteriskUsingParquet2.result | 4 + .../testInsertWithDifferentColumnOrder.result | 27 + .../selfJoinOfPartitionedTable.result | 7 + .../testBroadcastPartitionTable.result | 5 + ...FilterPushDownPartitionColumnCaseWhen.result | 4 + ...tionedBroadcastDataFileWithZeroLength.result | 7 + ...ionedBroadcastDataFileWithZeroLength2.result | 7 + .../testNoProjectionJoinQual.result | 3 + .../testPartialFilterPushDown.result | 3 + .../testPartialFilterPushDownOuterJoin.result | 27 + .../testPartialFilterPushDownOuterJoin2.result | 27 + ...estPartitionMultiplePartitionFilter.1.result | 2 + .../testPartitionTableJoinSmallTable.result | 7 + .../TestJoinQuery/testWhereClauseJoin6.result | 5 + .../testComplexJoinsWithCaseWhen.Hash.plan | 97 ++ ...mplexJoinsWithCaseWhen.Hash_NoBroadcast.plan | 153 ++ .../testComplexJoinsWithCaseWhen.Sort.plan | 97 ++ ...mplexJoinsWithCaseWhen.Sort_NoBroadcast.plan | 153 ++ .../testComplexJoinsWithCaseWhen.result | 27 + .../testComplexJoinsWithCaseWhen2.Hash.plan | 109 ++ ...plexJoinsWithCaseWhen2.Hash_NoBroadcast.plan | 165 ++ .../testComplexJoinsWithCaseWhen2.Sort.plan | 109 ++ ...plexJoinsWithCaseWhen2.Sort_NoBroadcast.plan | 165 ++ .../testComplexJoinsWithCaseWhen2.result | 27 + .../testInnerAndOuterWithEmpty.1.Hash.plan | 74 + ...nerAndOuterWithEmpty.1.Hash_NoBroadcast.plan | 130 ++ .../testInnerAndOuterWithEmpty.1.Sort.plan | 74 + ...nerAndOuterWithEmpty.1.Sort_NoBroadcast.plan | 130 ++ .../testInnerAndOuterWithEmpty.1.result | 7 + .../testJoinWithMultipleJoinTypes.Hash.plan | 84 ++ ...nWithMultipleJoinTypes.Hash_NoBroadcast.plan | 140 ++ .../testJoinWithMultipleJoinTypes.Sort.plan | 84 ++ ...nWithMultipleJoinTypes.Sort_NoBroadcast.plan | 140 ++ .../testJoinWithMultipleJoinTypes.result | 6 + .../results/TestNetTypes/testGroupby.result | 7 + .../results/TestNetTypes/testGroupby2.result | 5 + .../results/TestNetTypes/testJoin.result | 6 + .../results/TestNetTypes/testSelect.result | 7 + .../results/TestNetTypes/testSort.result | 7 + .../results/TestNetTypes/testSort2.result | 7 + .../testGetClusterDetails.result | 4 + .../testGetNextRowsForAggregateFunction.result | 3 + .../testGetNextRowsForTable.result | 5 + .../testFullOuterJoin1.Hash.plan | 105 ++ .../testFullOuterJoin1.Hash_NoBroadcast.plan | 105 ++ .../testFullOuterJoin1.Sort.plan | 105 ++ .../testFullOuterJoin1.Sort_NoBroadcast.plan | 105 ++ .../testFullOuterJoin1.result | 7 + ...lOuterJoinPredicationCaseByCase1.1.Hash.plan | 153 ++ ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 153 ++ ...lOuterJoinPredicationCaseByCase1.1.Sort.plan | 153 ++ ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 153 ++ ...FullOuterJoinPredicationCaseByCase1.1.result | 9 + .../testFullOuterJoinWithEmptyTable1.Hash.plan | 105 ++ ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 ++ .../testFullOuterJoinWithEmptyTable1.Sort.plan | 105 ++ ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 ++ .../testFullOuterJoinWithEmptyTable1.result | 7 + ...testJoinFilterOfRowPreservedTable1.Hash.plan | 78 + ...erOfRowPreservedTable1.Hash_NoBroadcast.plan | 105 ++ ...testJoinFilterOfRowPreservedTable1.Sort.plan | 78 + ...erOfRowPreservedTable1.Sort_NoBroadcast.plan | 105 ++ .../testJoinFilterOfRowPreservedTable1.result | 15 + .../testLeftOuterJoin1.Hash.plan | 78 + .../testLeftOuterJoin1.Hash_NoBroadcast.plan | 105 ++ .../testLeftOuterJoin1.Sort.plan | 78 + .../testLeftOuterJoin1.Sort_NoBroadcast.plan | 105 ++ .../testLeftOuterJoin1.result | 7 + .../testLeftOuterJoin2.Hash.plan | 91 ++ .../testLeftOuterJoin2.Hash_NoBroadcast.plan | 176 +++ .../testLeftOuterJoin2.Sort.plan | 91 ++ .../testLeftOuterJoin2.Sort_NoBroadcast.plan | 176 +++ .../testLeftOuterJoin2.result | 7 + .../testLeftOuterJoin3.Hash.plan | 160 ++ .../testLeftOuterJoin3.Hash_NoBroadcast.plan | 272 ++++ .../testLeftOuterJoin3.Sort.plan | 160 ++ .../testLeftOuterJoin3.Sort_NoBroadcast.plan | 272 ++++ .../testLeftOuterJoin3.result | 9 + ...tLeftOuterJoinLeftSideSmallTable.1.Hash.plan | 105 ++ ...inLeftSideSmallTable.1.Hash_NoBroadcast.plan | 105 ++ ...tLeftOuterJoinLeftSideSmallTable.1.Sort.plan | 105 ++ ...inLeftSideSmallTable.1.Sort_NoBroadcast.plan | 105 ++ ...testLeftOuterJoinLeftSideSmallTable.1.result | 7 + ...tOuterJoinPredicationCaseByCase1.1.Hash.plan | 72 + ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 128 ++ ...tOuterJoinPredicationCaseByCase1.1.Sort.plan | 72 + ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 128 ++ ...LeftOuterJoinPredicationCaseByCase1.1.result | 7 + ...tOuterJoinPredicationCaseByCase2.1.Hash.plan | 122 ++ ...edicationCaseByCase2.1.Hash_NoBroadcast.plan | 176 +++ ...tOuterJoinPredicationCaseByCase2.1.Sort.plan | 122 ++ ...edicationCaseByCase2.1.Sort_NoBroadcast.plan | 176 +++ ...LeftOuterJoinPredicationCaseByCase2.1.result | 4 + ...uterJoinPredicationCaseByCase2_1.1.Hash.plan | 97 ++ ...icationCaseByCase2_1.1.Hash_NoBroadcast.plan | 182 +++ ...uterJoinPredicationCaseByCase2_1.1.Sort.plan | 97 ++ ...icationCaseByCase2_1.1.Sort_NoBroadcast.plan | 182 +++ ...ftOuterJoinPredicationCaseByCase2_1.1.result | 5 + ...tOuterJoinPredicationCaseByCase3.1.Hash.plan | 72 + ...edicationCaseByCase3.1.Hash_NoBroadcast.plan | 128 ++ ...tOuterJoinPredicationCaseByCase3.1.Sort.plan | 72 + ...edicationCaseByCase3.1.Sort_NoBroadcast.plan | 128 ++ ...LeftOuterJoinPredicationCaseByCase3.1.result | 7 + ...tOuterJoinPredicationCaseByCase4.1.Hash.plan | 74 + ...edicationCaseByCase4.1.Hash_NoBroadcast.plan | 130 ++ ...tOuterJoinPredicationCaseByCase4.1.Sort.plan | 74 + ...edicationCaseByCase4.1.Sort_NoBroadcast.plan | 130 ++ ...LeftOuterJoinPredicationCaseByCase4.1.result | 7 + ...tOuterJoinPredicationCaseByCase5.1.Hash.plan | 74 + ...edicationCaseByCase5.1.Hash_NoBroadcast.plan | 130 ++ ...tOuterJoinPredicationCaseByCase5.1.Sort.plan | 74 + ...edicationCaseByCase5.1.Sort_NoBroadcast.plan | 130 ++ ...LeftOuterJoinPredicationCaseByCase5.1.result | 6 + ...tOuterJoinPredicationCaseByCase6.1.Hash.plan | 76 + ...edicationCaseByCase6.1.Hash_NoBroadcast.plan | 132 ++ ...tOuterJoinPredicationCaseByCase6.1.Sort.plan | 76 + ...edicationCaseByCase6.1.Sort_NoBroadcast.plan | 132 ++ ...LeftOuterJoinPredicationCaseByCase6.1.result | 3 + ...testLeftOuterJoinWithConstantExpr1.Hash.plan | 86 ++ ...rJoinWithConstantExpr1.Hash_NoBroadcast.plan | 113 ++ ...testLeftOuterJoinWithConstantExpr1.Sort.plan | 86 ++ ...rJoinWithConstantExpr1.Sort_NoBroadcast.plan | 113 ++ .../testLeftOuterJoinWithConstantExpr1.result | 7 + ...testLeftOuterJoinWithConstantExpr4.Hash.plan | 63 + ...rJoinWithConstantExpr4.Hash_NoBroadcast.plan | 90 ++ ...testLeftOuterJoinWithConstantExpr4.Sort.plan | 63 + ...rJoinWithConstantExpr4.Sort_NoBroadcast.plan | 90 ++ .../testLeftOuterJoinWithConstantExpr4.result | 7 + ...testLeftOuterJoinWithConstantExpr5.Hash.plan | 65 + ...rJoinWithConstantExpr5.Hash_NoBroadcast.plan | 92 ++ ...testLeftOuterJoinWithConstantExpr5.Sort.plan | 65 + ...rJoinWithConstantExpr5.Sort_NoBroadcast.plan | 92 ++ .../testLeftOuterJoinWithConstantExpr5.result | 6 + .../testLeftOuterJoinWithEmptyTable1.Hash.plan | 78 + ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 ++ .../testLeftOuterJoinWithEmptyTable1.Sort.plan | 78 + ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 ++ .../testLeftOuterJoinWithEmptyTable1.result | 7 + .../testLeftOuterJoinWithEmptyTable2.Hash.plan | 109 ++ ...terJoinWithEmptyTable2.Hash_NoBroadcast.plan | 136 ++ .../testLeftOuterJoinWithEmptyTable2.Sort.plan | 109 ++ ...terJoinWithEmptyTable2.Sort_NoBroadcast.plan | 136 ++ .../testLeftOuterJoinWithEmptyTable2.result | 7 + .../testLeftOuterJoinWithEmptyTable3.Hash.plan | 160 ++ ...terJoinWithEmptyTable3.Hash_NoBroadcast.plan | 187 +++ .../testLeftOuterJoinWithEmptyTable3.Sort.plan | 160 ++ ...terJoinWithEmptyTable3.Sort_NoBroadcast.plan | 187 +++ .../testLeftOuterJoinWithEmptyTable3.result | 7 + .../testLeftOuterJoinWithEmptyTable4.Hash.plan | 160 ++ ...terJoinWithEmptyTable4.Hash_NoBroadcast.plan | 214 +++ .../testLeftOuterJoinWithEmptyTable4.Sort.plan | 160 ++ ...terJoinWithEmptyTable4.Sort_NoBroadcast.plan | 214 +++ .../testLeftOuterJoinWithEmptyTable4.result | 4 + .../testLeftOuterJoinWithEmptyTable5.Hash.plan | 109 ++ ...terJoinWithEmptyTable5.Hash_NoBroadcast.plan | 136 ++ .../testLeftOuterJoinWithEmptyTable5.Sort.plan | 109 ++ ...terJoinWithEmptyTable5.Sort_NoBroadcast.plan | 136 ++ .../testLeftOuterJoinWithEmptyTable5.result | 4 + .../testLeftOuterJoinWithNull1.Hash.plan | 82 + ...LeftOuterJoinWithNull1.Hash_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull1.Sort.plan | 82 + ...LeftOuterJoinWithNull1.Sort_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull1.result | 4 + .../testLeftOuterJoinWithNull2.Hash.plan | 82 + ...LeftOuterJoinWithNull2.Hash_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull2.Sort.plan | 82 + ...LeftOuterJoinWithNull2.Sort_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull2.result | 4 + .../testLeftOuterJoinWithNull3.Hash.plan | 82 + ...LeftOuterJoinWithNull3.Hash_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull3.Sort.plan | 82 + ...LeftOuterJoinWithNull3.Sort_NoBroadcast.plan | 109 ++ .../testLeftOuterJoinWithNull3.result | 2 + ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 + ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 ++ ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 + ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 ++ ...uterJoinWithThetaJoinConditionInWhere.result | 4 + .../testLeftOuterWithEmptyTable.1.Hash.plan | 53 + ...tOuterWithEmptyTable.1.Hash_NoBroadcast.plan | 80 + .../testLeftOuterWithEmptyTable.1.Sort.plan | 53 + ...tOuterWithEmptyTable.1.Sort_NoBroadcast.plan | 80 + .../testLeftOuterWithEmptyTable.1.result | 7 + ...pleBroadcastDataFileWithZeroLength.Hash.plan | 57 + ...DataFileWithZeroLength.Hash_NoBroadcast.plan | 84 ++ ...pleBroadcastDataFileWithZeroLength.Sort.plan | 57 + ...DataFileWithZeroLength.Sort_NoBroadcast.plan | 84 ++ ...ltipleBroadcastDataFileWithZeroLength.result | 2 + ...leBroadcastDataFileWithZeroLength2.Hash.plan | 76 + ...ataFileWithZeroLength2.Hash_NoBroadcast.plan | 132 ++ ...leBroadcastDataFileWithZeroLength2.Sort.plan | 76 + ...ataFileWithZeroLength2.Sort_NoBroadcast.plan | 132 ++ ...tipleBroadcastDataFileWithZeroLength2.result | 7 + .../testOuterJoinAndCaseWhen1.Hash.plan | 126 ++ ...tOuterJoinAndCaseWhen1.Hash_NoBroadcast.plan | 153 ++ .../testOuterJoinAndCaseWhen1.Sort.plan | 126 ++ ...tOuterJoinAndCaseWhen1.Sort_NoBroadcast.plan | 153 ++ .../testOuterJoinAndCaseWhen1.result | 7 + .../testRightOuterJoin1.Hash.plan | 78 + .../testRightOuterJoin1.Hash_NoBroadcast.plan | 105 ++ .../testRightOuterJoin1.Sort.plan | 78 + .../testRightOuterJoin1.Sort_NoBroadcast.plan | 105 ++ .../testRightOuterJoin1.result | 7 + ...tOuterJoinPredicationCaseByCase1.1.Hash.plan | 101 ++ ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 128 ++ ...tOuterJoinPredicationCaseByCase1.1.Sort.plan | 101 ++ ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 128 ++ ...ightOuterJoinPredicationCaseByCase1.1.result | 4 + ...tOuterJoinPredicationCaseByCase2.1.Hash.plan | 76 + ...edicationCaseByCase2.1.Hash_NoBroadcast.plan | 132 ++ ...tOuterJoinPredicationCaseByCase2.1.Sort.plan | 76 + ...edicationCaseByCase2.1.Sort_NoBroadcast.plan | 132 ++ ...ightOuterJoinPredicationCaseByCase2.1.result | 4 + ...tOuterJoinPredicationCaseByCase3.1.Hash.plan | 101 ++ ...edicationCaseByCase3.1.Hash_NoBroadcast.plan | 128 ++ ...tOuterJoinPredicationCaseByCase3.1.Sort.plan | 101 ++ ...edicationCaseByCase3.1.Sort_NoBroadcast.plan | 128 ++ ...ightOuterJoinPredicationCaseByCase3.1.result | 4 + .../testRightOuterJoinWithEmptyTable1.Hash.plan | 78 + ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 ++ .../testRightOuterJoinWithEmptyTable1.Sort.plan | 78 + ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 ++ .../testRightOuterJoinWithEmptyTable1.result | 7 + ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 + ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 ++ ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 + ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 ++ ...uterJoinWithThetaJoinConditionInWhere.result | 4 + ...terJoinWithEmptyIntermediateData.1.Hash.plan | 108 ++ ...mptyIntermediateData.1.Hash_NoBroadcast.plan | 108 ++ ...terJoinWithEmptyIntermediateData.1.Sort.plan | 108 ++ ...mptyIntermediateData.1.Sort_NoBroadcast.plan | 108 ++ ...lOuterJoinWithEmptyIntermediateData.1.result | 2 + .../testJoinWithDifferentShuffleKey.1.Hash.plan | 199 +++ ...hDifferentShuffleKey.1.Hash_NoBroadcast.plan | 199 +++ .../testJoinWithDifferentShuffleKey.1.Sort.plan | 199 +++ ...hDifferentShuffleKey.1.Sort_NoBroadcast.plan | 199 +++ .../testJoinWithDifferentShuffleKey.1.result | 3 + ...testLeftOuterJoinWithConstantExpr2.Hash.plan | 98 ++ ...rJoinWithConstantExpr2.Hash_NoBroadcast.plan | 125 ++ ...testLeftOuterJoinWithConstantExpr2.Sort.plan | 98 ++ ...rJoinWithConstantExpr2.Sort_NoBroadcast.plan | 125 ++ .../testLeftOuterJoinWithConstantExpr2.result | 7 + ...testLeftOuterJoinWithConstantExpr3.Hash.plan | 156 ++ ...rJoinWithConstantExpr3.Hash_NoBroadcast.plan | 156 ++ ...testLeftOuterJoinWithConstantExpr3.Sort.plan | 156 ++ ...rJoinWithConstantExpr3.Sort_NoBroadcast.plan | 156 ++ .../testLeftOuterJoinWithConstantExpr3.result | 7 + ...tLeftOuterJoinWithEmptySubquery1.1.Hash.plan | 111 ++ ...inWithEmptySubquery1.1.Hash_NoBroadcast.plan | 167 +++ ...tLeftOuterJoinWithEmptySubquery1.1.Sort.plan | 111 ++ ...inWithEmptySubquery1.1.Sort_NoBroadcast.plan | 167 +++ ...testLeftOuterJoinWithEmptySubquery1.1.result | 7 + ...tLeftOuterJoinWithEmptySubquery2.1.Hash.plan | 86 ++ ...inWithEmptySubquery2.1.Hash_NoBroadcast.plan | 142 ++ ...tLeftOuterJoinWithEmptySubquery2.1.Sort.plan | 86 ++ ...inWithEmptySubquery2.1.Sort_NoBroadcast.plan | 142 ++ ...testLeftOuterJoinWithEmptySubquery2.1.result | 2 + .../TestQueryUnitStatusUpdate/case3.result | 4 + .../create_table_nested_1.result | 40 + .../create_table_nested_2.result | 57 + .../results/TestSQLAnalyzer/setcatalog1.result | 5 + .../results/TestSQLAnalyzer/setcatalog2.result | 5 + .../results/TestSQLAnalyzer/setsession1.result | 5 + .../results/TestSQLAnalyzer/setsession2.result | 5 + .../results/TestSQLAnalyzer/setsession3.result | 5 + .../results/TestSQLAnalyzer/setsession4.result | 5 + .../results/TestSQLAnalyzer/setsession5.result | 5 + .../results/TestSQLAnalyzer/setsession6.result | 5 + .../results/TestSQLAnalyzer/setsession7.result | 5 + .../results/TestSQLAnalyzer/settimezone1.result | 5 + .../results/TestSQLAnalyzer/settimezone2.result | 5 + .../results/TestSQLAnalyzer/settimezone3.result | 4 + .../results/TestSQLAnalyzer/window1.result | 37 + .../results/TestSQLAnalyzer/window2.result | 44 + .../results/TestSQLAnalyzer/window3.result | 50 + .../results/TestSQLAnalyzer/window4.result | 48 + .../results/TestSQLAnalyzer/window5.result | 77 + .../results/TestSQLAnalyzer/window6.result | 83 ++ .../results/TestSQLAnalyzer/window7.result | 81 + .../results/TestSQLAnalyzer/window8.result | 86 ++ .../results/TestSQLAnalyzer/window9.result | 56 + .../testInsertType1.result | 5 + .../testInsertType2.result | 5 + .../testNestedFieldAsGroupbyKey1.result | 6 + .../testNestedFieldAsJoinKey1.result | 6 + .../TestSelectNestedRecord/testSelect0.result | 5 + .../TestSelectNestedRecord/testSelect1.result | 5 + .../TestSelectNestedRecord/testSelect2.result | 6 + .../TestSelectNestedRecord/testSelect3.result | 3 + .../results/TestSelectQuery/testCaseWhen.result | 7 + .../TestSelectQuery/testCaseWhenRound.result | 22 + .../testCaseWhenWithoutElse.result | 7 + ...estColumnEqualityButNotJoinCondition1.result | 3 + ...estColumnEqualityButNotJoinCondition2.result | 6 + .../TestSelectQuery/testDatabaseRef.result | 7 + .../TestSelectQuery/testExplainSelect.result | 6 + .../testExplainSelectPhysical.1.result | 26 + .../testExplainSelectPhysical.2.result | 88 ++ .../testExplainSelectPhysical.3.result | 89 ++ .../results/TestSelectQuery/testInClause.result | 5 + .../TestSelectQuery/testInStrClause.result | 4 + .../TestSelectQuery/testLikeClause.result | 9 + .../results/TestSelectQuery/testLimit.result | 5 + .../testMultiBytesDelimiter1.result | 7 + .../testMultiBytesDelimiter2.result | 7 + .../testMultiBytesDelimiter3.result | 7 + .../testMultiBytesDelimiter4.result | 7 + .../testNestedPythonFunction.result | 7 + .../TestSelectQuery/testNonFromSelect1.result | 3 + .../testNonQualifiedNames.result | 7 + .../results/TestSelectQuery/testNotEqual.result | 5 + .../TestSelectQuery/testNotInClause.result | 4 + .../TestSelectQuery/testNotInStrClause.result | 4 + .../TestSelectQuery/testRealValueCompare.result | 3 + .../results/TestSelectQuery/testSelect.result | 7 + .../results/TestSelectQuery/testSelect2.result | 7 + .../results/TestSelectQuery/testSelect3.result | 7 + .../TestSelectQuery/testSelectAsterisk1.result | 7 + .../TestSelectQuery/testSelectAsterisk2.result | 3 + .../TestSelectQuery/testSelectAsterisk3.result | 3 + .../TestSelectQuery/testSelectAsterisk4.result | 7 + .../TestSelectQuery/testSelectAsterisk5.result | 3 + .../testSelectColumnAlias1.result | 7 + ...tSelectColumnAliasExistingInRelation1.result | 4 + ...tSelectColumnAliasExistingInRelation2.result | 7 + ...tSelectColumnAliasExistingInRelation3.result | 11 + .../TestSelectQuery/testSelectDistinct.result | 7 + .../testSelectOnSessionTable.result | 3 + .../testSelectPythonFuncs.result | 7 + ...lectSameConstantsWithDifferentAliases.result | 7 + ...ectSameConstantsWithDifferentAliases2.result | 7 + ...ectSameConstantsWithDifferentAliases3.result | 7 + ...stSelectSameExprsWithDifferentAliases.result | 7 + .../testSelectWithCommonQuals1.1.plan | 7 + .../testSelectWithCommonQuals1.1.result | 27 + .../testSelectWithCommonQuals2.1.plan | 7 + .../testSelectWithCommonQuals2.1.result | 27 + .../testSelectWithCommonQuals3.1.plan | 7 + .../testSelectWithCommonQuals3.1.result | 7 + .../TestSelectQuery/testSelectWithJson.result | 7 + .../testSelectWithParentheses1.result | 3 + .../testSelectWithParentheses2.result | 3 + .../testSelectWithPredicateOnPythonFunc.result | 17 + .../TestSelectQuery/testSimpleQuery.result | 7 + .../testSimpleQueryWithLimit.result | 5 + ...tSimpleQueryWithLimitPartitionedTable.result | 12 + .../TestSelectQuery/testStringCompare.result | 5 + .../TestSelectQuery/testSumFloatOverflow.result | 3 + .../TestSelectQuery/testSumIntOverflow.result | 3 + .../TestSelectQuery/testTimezonedTable1.result | 5 + .../TestSelectQuery/testTimezonedTable2.result | 5 + .../TestSelectQuery/testTimezonedTable3.result | 5 + .../results/TestSelectQuery/testUnion1.result | 10 + .../results/TestSelectQuery/testUnion2.result | 12 + .../TestSelectQuery/testWhereCond1.result | 3 + .../TestSelectQuery/testWhereCond2.result | 3 + .../testWhereCondWithAlias1.result | 4 + .../testWhereCondWithAlias2.result | 4 + .../results/TestSortQuery/testAsterisk.result | 7 + .../results/TestSortQuery/testSort.result | 7 + .../TestSortQuery/testSortAfterGroupby.result | 5 + .../testSortAfterGroupbyWithAlias.result | 5 + .../results/TestSortQuery/testSortDesc.result | 7 + .../TestSortQuery/testSortFirstDesc.result | 10 + .../TestSortQuery/testSortOnNullColumn.result | 6 + .../testSortOnUnicodeTextAsc.result | 6 + .../testSortOnUnicodeTextDesc.result | 6 + .../TestSortQuery/testSortWithAlias1.result | 7 + .../TestSortQuery/testSortWithAlias2.result | 5 + .../TestSortQuery/testSortWithAlias3.result | 7 + .../testSortWithAliasButOriginalName.result | 7 + .../testSortWithAscDescKeys.result | 26 + .../TestSortQuery/testSortWithConstKeys.result | 7 + .../TestSortQuery/testSortWithDate.result | 7 + .../TestSortQuery/testSortWithExpr1.result | 7 + .../TestSortQuery/testSortWithExpr2.result | 7 + .../TestSortQuery/testSortWithJson.result | 5 + .../testSubQuerySortAfterGroupMultiBlocks.plan | 112 ++ ...testSubQuerySortAfterGroupMultiBlocks.result | 5 + .../results/TestSortQuery/testTopK.result | 5 + .../TestSortQuery/testTopkWithJson.result | 5 + .../results/TestTPCH/testFirstJoinInQ7.plan | 156 ++ .../results/TestTPCH/testFirstJoinInQ7.result | 4 + .../results/TestTPCH/testQ1OrderBy.plan | 88 ++ .../results/TestTPCH/testQ1OrderBy.result | 4 + .../results/TestTPCH/testQ2FourJoins.plan | 228 +++ .../results/TestTPCH/testQ2FourJoins.result | 3 + .../results/TestTPCH/testTPCH14Expr.plan | 119 ++ .../results/TestTPCH/testTPCH14Expr.result | 3 + .../resources/results/TestTPCH/testTPCHQ5.plan | 332 +++++ .../results/TestTPCH/testTPCHQ5.result | 2 + .../TestSpecialCharPartitionKeys1.result | 4 + .../TestSpecialCharPartitionKeys2.result | 3 + .../results/TestTablePartitions/case1.result | 4 + .../results/TestTablePartitions/case10.result | 7 + .../results/TestTablePartitions/case11.result | 7 + .../results/TestTablePartitions/case12.result | 7 + .../results/TestTablePartitions/case13.result | 7 + .../results/TestTablePartitions/case14.result | 3 + .../results/TestTablePartitions/case15.result | 3 + .../results/TestTablePartitions/case2.result | 6 + .../results/TestTablePartitions/case3.result | 5 + .../results/TestTablePartitions/case4.result | 7 + .../results/TestTablePartitions/case5.result | 7 + .../results/TestTablePartitions/case6.result | 7 + .../results/TestTablePartitions/case7.result | 5 + .../results/TestTablePartitions/case8.result | 7 + .../results/TestTablePartitions/case9.result | 7 + ...rtitionedTableWithSmallerExpressions5.result | 7 + ...rtitionedTableWithSmallerExpressions6.result | 4 + .../testGroupBySubQuery.result | 3 + .../testGroupbySubqueryWithJson.result | 3 + .../TestTableSubQuery/testJoinSubQuery.result | 4 + .../TestTableSubQuery/testJoinSubQuery2.result | 4 + .../testJoinSubqueryWithJson.result | 4 + .../TestTableSubQuery/testTableSubquery1.result | 7 + .../testAlterTableAddDropPartition.result | 9 + .../results/TestTajoCli/testDescTable.result | 27 + .../testDescTableForNestedSchema.result | 29 + .../TestTajoCli/testHelpSessionVars.result | 44 + .../testLocalQueryWithoutFrom.result | 8 + .../TestTajoCli/testNonForwardQueryPause.result | 6 + .../testSelectResultWithNullFalse.result | 8 + .../testSelectResultWithNullTrue.result | 8 + ...estSelectResultWithNullTrueDeprecated.result | 9 + .../results/TestTajoCli/testSetTimezone1.result | 4 + .../TestTajoCli/testStopWhenError.result | 5 + .../testStopWhenErrorDeprecated.result | 6 + .../testQueryFailure.result | 0 .../TestTajoCliNegatives/testQuerySyntax.result | 3 + .../testExecuteQueryAsync.result | 7 + .../testExecuteQueryAsyncWithListener.result | 2 + .../testExecuteQueryType1.result | 7 + .../testExecuteQueryType2.result | 4 + .../testExecuteQueryType3.result | 4 + .../TestTajoDatabaseMetaData/getSchemas1.result | 3 + .../TestTajoDatabaseMetaData/getSchemas2.result | 3 + .../getTableTypes.result | 3 + .../TestTajoDatabaseMetaData/getTables1.result | 4 + .../TestTajoDatabaseMetaData/getTables2.result | 4 + .../results/TestTajoDump/testDump1.result | 16 + .../results/TestTajoDump/testDump2.result | 16 + .../results/TestTajoDump/testDump3.result | 20 + .../TestTajoJdbc/testSortWithDateTime.result | 7 + .../TestUnionQuery/testComplexUnion1.plan | 80 + .../TestUnionQuery/testComplexUnion1.result | 6 + .../TestUnionQuery/testComplexUnion2.plan | 116 ++ .../TestUnionQuery/testComplexUnion2.result | 7 + .../results/TestUnionQuery/testUnion1.result | 7 + .../results/TestUnionQuery/testUnion10.result | 7 + .../results/TestUnionQuery/testUnion11.result | 3 + .../results/TestUnionQuery/testUnion12.result | 7 + .../results/TestUnionQuery/testUnion13.result | 7 + .../results/TestUnionQuery/testUnion14.result | 9 + .../results/TestUnionQuery/testUnion15.result | 5 + .../results/TestUnionQuery/testUnion16.result | 5 + .../results/TestUnionQuery/testUnion2.result | 5 + .../results/TestUnionQuery/testUnion3.result | 4 + .../results/TestUnionQuery/testUnion4.result | 3 + .../results/TestUnionQuery/testUnion5.result | 3 + .../results/TestUnionQuery/testUnion6.result | 3 + .../results/TestUnionQuery/testUnion7.result | 5 + .../results/TestUnionQuery/testUnion8.result | 3 + .../results/TestUnionQuery/testUnion9.result | 7 + .../results/TestUnionQuery/testUnionAll1.result | 10 + .../TestUnionQuery/testUnionAll10.result | 22 + .../TestUnionQuery/testUnionAll11.result | 3 + .../TestUnionQuery/testUnionAll12.result | 7 + .../TestUnionQuery/testUnionAll13.result | 7 + .../TestUnionQuery/testUnionAll14.result | 9 + .../TestUnionQuery/testUnionAll15.result | 5 + .../TestUnionQuery/testUnionAll16.result | 5 + .../results/TestUnionQuery/testUnionAll2.result | 12 + .../results/TestUnionQuery/testUnionAll3.result | 4 + .../results/TestUnionQuery/testUnionAll4.result | 3 + .../results/TestUnionQuery/testUnionAll5.result | 3 + .../results/TestUnionQuery/testUnionAll6.result | 3 + .../results/TestUnionQuery/testUnionAll7.result | 12 + .../results/TestUnionQuery/testUnionAll8.result | 3 + .../results/TestUnionQuery/testUnionAll9.result | 7 + .../testUnionAllWithDifferentAlias.result | 4 + ...UnionAllWithDifferentAliasAndFunction.result | 7 + .../testUnionAllWithSameAliasNames.result | 12 + .../testUnionWithDifferentAlias.result | 4 + ...estUnionWithDifferentAliasAndFunction.result | 7 + .../testUnionWithSameAliasNames.result | 5 + .../TestWindowQuery/testComplexOrderBy1.result | 7 + .../TestWindowQuery/testFirstValue1.result | 7 + .../results/TestWindowQuery/testLag1.result | 7 + .../TestWindowQuery/testLagWithDefault.result | 7 + .../TestWindowQuery/testLagWithNoArgs.result | 7 + .../TestWindowQuery/testLastValue1.result | 7 + .../results/TestWindowQuery/testLead1.result | 7 + .../TestWindowQuery/testLeadWithDefault.result | 7 + .../TestWindowQuery/testLeadWithNoArgs.result | 7 + .../TestWindowQuery/testRowNumber1.result | 7 + .../TestWindowQuery/testRowNumber2.result | 7 + .../TestWindowQuery/testRowNumber3.result | 7 + .../TestWindowQuery/testStdDevPop1.result | 7 + .../TestWindowQuery/testStdDevSamp1.result | 7 + .../results/TestWindowQuery/testWindow1.result | 7 + .../results/TestWindowQuery/testWindow2.result | 7 + .../results/TestWindowQuery/testWindow3.result | 7 + .../results/TestWindowQuery/testWindow4.result | 7 + .../results/TestWindowQuery/testWindow5.result | 7 + .../results/TestWindowQuery/testWindow6.result | 7 + .../results/TestWindowQuery/testWindow7.result | 7 + .../results/TestWindowQuery/testWindow8.result | 7 + .../testWindowBeforeLimit.result | 5 + .../testWindowWithAggregation1.result | 3 + .../testWindowWithAggregation2.result | 5 + .../testWindowWithAggregation3.result | 3 + .../testWindowWithAggregation4.result | 5 + .../testWindowWithAggregation5.result | 5 + .../testWindowWithAggregation6.result | 5 + .../testWindowWithOrderBy1.result | 7 + .../testWindowWithOrderBy2.result | 7 + .../testWindowWithOrderBy3.result | 7 + .../testWindowWithOrderBy4.result | 7 + .../testWindowWithOrderBy5.result | 7 + .../testWindowWithSubQuery.result | 7 + .../testWindowWithSubQuery2.result | 5 + .../testWindowWithSubQuery3.result | 7 + .../testWindowWithSubQuery4.result | 7 + .../testWindowWithSubQuery5.result | 5 + .../testWindowWithSubQuery6.result | 3 + .../testBuildDDLForBaseTable.result | 4 + .../testBuildDDLForExternalTable.result | 5 + .../testBuildDDLQuotedTableName1.result | 5 + .../testBuildDDLQuotedTableName2.result | 4 + .../src/test/resources/yarn-site.xml | 25 + tajo-core-tests/src/test/tpch/customer.tbl | 5 + tajo-core-tests/src/test/tpch/empty_orders.tbl | 0 tajo-core-tests/src/test/tpch/lineitem.tbl | 5 + tajo-core-tests/src/test/tpch/nation.tbl | 25 + tajo-core-tests/src/test/tpch/orders.tbl | 3 + tajo-core-tests/src/test/tpch/part.tbl | 4 + tajo-core-tests/src/test/tpch/partsupp.tbl | 3 + tajo-core-tests/src/test/tpch/region.tbl | 5 + tajo-core-tests/src/test/tpch/supplier.tbl | 3 + tajo-core/pom.xml | 173 --- tajo-core/src/test/java/log4j.properties | 28 - .../org/apache/tajo/BackendTestingUtil.java | 74 - .../org/apache/tajo/HBaseTestClusterUtil.java | 184 --- .../java/org/apache/tajo/IntegrationTest.java | 22 - .../apache/tajo/LocalTajoTestingUtility.java | 169 --- .../test/java/org/apache/tajo/NamedTest.java | 27 - .../java/org/apache/tajo/QueryTestCaseBase.java | 1030 ------------- .../org/apache/tajo/TajoTestingCluster.java | 778 ---------- .../org/apache/tajo/TestQueryIdFactory.java | 58 - .../test/java/org/apache/tajo/TestTajoIds.java | 168 --- .../test/java/org/apache/tajo/TpchTestBase.java | 113 -- .../org/apache/tajo/benchmark/TestTPCH.java | 70 - .../apache/tajo/cli/tools/TestDDLBuilder.java | 133 -- .../org/apache/tajo/cli/tools/TestTajoDump.java | 124 -- .../cli/tsql/TestDefaultCliOutputFormatter.java | 181 --- .../apache/tajo/cli/tsql/TestSimpleParser.java | 286 ---- .../org/apache/tajo/cli/tsql/TestTajoCli.java | 472 ------ .../tajo/cli/tsql/TestTajoCliNegatives.java | 146 -- .../commands/TestExecExternalShellCommand.java | 45 - .../tajo/cli/tsql/commands/TestHdfsCommand.java | 47 - .../TestCatalogAdminClientExceptions.java | 103 -- .../tajo/client/TestQueryClientExceptions.java | 126 -- .../org/apache/tajo/client/TestTajoClient.java | 777 ---------- .../apache/tajo/client/v2/TestTajoClientV2.java | 274 ---- .../tajo/cluster/TestWorkerConnectionInfo.java | 36 - .../engine/codegen/TestEvalCodeGenerator.java | 310 ---- .../engine/codegen/TestGeneratorAdapter.java | 41 - .../apache/tajo/engine/eval/ExprTestBase.java | 341 ----- .../apache/tajo/engine/eval/TestEvalTree.java | 424 ------ .../tajo/engine/eval/TestEvalTreeUtil.java | 374 ----- .../tajo/engine/eval/TestIntervalType.java | 124 -- .../apache/tajo/engine/eval/TestPredicates.java | 407 ----- .../tajo/engine/eval/TestSQLDateTimeTypes.java | 50 - .../tajo/engine/eval/TestSQLExpression.java | 1001 ------------- .../tajo/engine/function/TestAggFunction.java | 65 - .../engine/function/TestBuiltinFunctions.java | 824 ---------- .../function/TestConditionalExpressions.java | 242 --- .../engine/function/TestDateTimeFunctions.java | 483 ------ .../engine/function/TestFunctionLoader.java | 45 - .../engine/function/TestGeneralFunction.java | 49 - .../tajo/engine/function/TestJsonFunctions.java | 66 - .../tajo/engine/function/TestMathFunctions.java | 470 ------ .../function/TestPatternMatchingPredicates.java | 139 -- .../engine/function/TestPythonFunctions.java | 45 - .../TestStringOperatorsAndFunctions.java | 615 -------- .../tajo/engine/parser/TestSQLAnalyzer.java | 804 ---------- .../engine/planner/TestJoinOrderAlgorithm.java | 185 --- .../engine/planner/TestLogicalOptimizer.java | 272 ---- .../tajo/engine/planner/TestLogicalPlan.java | 86 -- .../tajo/engine/planner/TestLogicalPlanner.java | 1360 ----------------- .../tajo/engine/planner/TestPlannerUtil.java | 387 ----- .../engine/planner/TestQueryValidation.java | 66 - .../planner/TestUniformRangePartition.java | 1143 -------------- .../engine/planner/global/TestMasterPlan.java | 53 - .../planner/physical/TestBNLJoinExec.java | 224 --- .../planner/physical/TestExternalSortExec.java | 187 --- .../physical/TestFullOuterHashJoinExec.java | 414 ----- .../physical/TestFullOuterMergeJoinExec.java | 537 ------- .../planner/physical/TestHashAntiJoinExec.java | 215 --- .../planner/physical/TestHashJoinExec.java | 281 ---- .../planner/physical/TestHashPartitioner.java | 117 -- .../planner/physical/TestHashSemiJoinExec.java | 220 --- .../physical/TestLeftOuterHashJoinExec.java | 440 ------ .../planner/physical/TestMergeJoinExec.java | 197 --- .../engine/planner/physical/TestNLJoinExec.java | 208 --- .../planner/physical/TestPhysicalPlanner.java | 1144 -------------- .../physical/TestProgressExternalSortExec.java | 229 --- .../physical/TestRightOuterHashJoinExec.java | 351 ----- .../physical/TestRightOuterMergeJoinExec.java | 531 ------- .../engine/planner/physical/TestSortExec.java | 179 --- .../planner/physical/TestSortIntersectExec.java | 293 ---- .../planner/physical/TestTupleSorter.java | 127 -- .../tajo/engine/query/TestAlterTable.java | 114 -- .../tajo/engine/query/TestAlterTablespace.java | 59 - .../apache/tajo/engine/query/TestCTASQuery.java | 281 ---- .../tajo/engine/query/TestCaseByCases.java | 183 --- .../tajo/engine/query/TestCreateDatabase.java | 75 - .../tajo/engine/query/TestCreateIndex.java | 113 -- .../tajo/engine/query/TestCreateTable.java | 643 -------- .../apache/tajo/engine/query/TestDropTable.java | 38 - .../tajo/engine/query/TestGroupByQuery.java | 870 ----------- .../tajo/engine/query/TestHBaseTable.java | 1404 ----------------- .../tajo/engine/query/TestInSubquery.java | 177 --- .../apache/tajo/engine/query/TestIndexScan.java | 145 -- .../tajo/engine/query/TestInnerJoinQuery.java | 335 ----- .../engine/query/TestInnerJoinWithSubQuery.java | 132 -- .../tajo/engine/query/TestInsertQuery.java | 882 ----------- .../query/TestJoinOnPartitionedTables.java | 340 ----- .../apache/tajo/engine/query/TestJoinQuery.java | 315 ---- .../engine/query/TestMultipleJoinTypes.java | 106 -- .../apache/tajo/engine/query/TestNetTypes.java | 102 -- .../tajo/engine/query/TestNullValues.java | 322 ---- .../tajo/engine/query/TestOuterJoinQuery.java | 457 ------ .../engine/query/TestOuterJoinWithSubQuery.java | 144 -- .../engine/query/TestSelectNestedRecord.java | 119 -- .../tajo/engine/query/TestSelectQuery.java | 778 ---------- .../tajo/engine/query/TestSetSessionQuery.java | 81 - .../apache/tajo/engine/query/TestSortQuery.java | 378 ----- .../tajo/engine/query/TestTablePartitions.java | 1301 ---------------- .../tajo/engine/query/TestTableSubQuery.java | 81 - .../tajo/engine/query/TestTruncateTable.java | 96 -- .../tajo/engine/query/TestUnionQuery.java | 693 --------- .../tajo/engine/query/TestWindowQuery.java | 465 ------ .../apache/tajo/engine/util/TestTableCache.java | 109 -- .../apache/tajo/engine/util/TestTupleUtil.java | 188 --- .../apache/tajo/ha/TestHAServiceHDFSImpl.java | 160 -- .../org/apache/tajo/jdbc/TestResultSet.java | 224 --- .../java/org/apache/tajo/jdbc/TestSQLState.java | 91 -- .../tajo/jdbc/TestTajoDatabaseMetaData.java | 504 ------- .../java/org/apache/tajo/jdbc/TestTajoJdbc.java | 608 -------- .../tajo/master/TestExecutionBlockCursor.java | 135 -- .../TestNonForwardQueryResultSystemScanner.java | 41 - .../apache/tajo/master/TestRepartitioner.java | 511 ------- .../tajo/master/rule/TestMasterRules.java | 156 -- .../master/scheduler/TestSimpleScheduler.java | 301 ---- .../tajo/querymaster/TestIntermediateEntry.java | 53 - .../apache/tajo/querymaster/TestKillQuery.java | 312 ---- .../tajo/querymaster/TestQueryProgress.java | 77 - .../apache/tajo/querymaster/TestQueryState.java | 99 -- .../tajo/querymaster/TestTaskStatusUpdate.java | 191 --- .../org/apache/tajo/resource/TestResources.java | 48 - .../apache/tajo/storage/TestFileFragment.java | 93 -- .../org/apache/tajo/storage/TestRowFile.java | 146 -- .../java/org/apache/tajo/util/TestJSPUtil.java | 113 -- .../util/history/TestHistoryWriterReader.java | 313 ---- .../tajo/util/metrics/TestMetricsFilter.java | 52 - .../tajo/util/metrics/TestSystemMetrics.java | 143 -- .../apache/tajo/worker/MockExecutionBlock.java | 42 - .../tajo/worker/MockNodeResourceManager.java | 88 -- .../tajo/worker/MockNodeStatusUpdater.java | 97 -- .../apache/tajo/worker/MockTaskExecutor.java | 153 -- .../org/apache/tajo/worker/MockTaskManager.java | 69 - .../apache/tajo/worker/MockWorkerContext.java | 109 -- .../apache/tajo/worker/TestDeletionService.java | 61 - .../org/apache/tajo/worker/TestFetcher.java | 236 --- .../tajo/worker/TestNodeResourceManager.java | 281 ---- .../tajo/worker/TestNodeStatusUpdater.java | 192 --- .../apache/tajo/worker/TestTaskExecutor.java | 315 ---- .../org/apache/tajo/worker/TestTaskManager.java | 184 --- .../tajo/ws/rs/resources/RestTestUtils.java | 64 - .../ws/rs/resources/TestClusterResource.java | 84 -- .../ws/rs/resources/TestDatabasesResource.java | 189 --- .../ws/rs/resources/TestFunctionsResource.java | 78 - .../tajo/ws/rs/resources/TestQueryResource.java | 199 --- .../rs/resources/TestQueryResultResource.java | 297 ---- .../ws/rs/resources/TestSessionsResource.java | 263 ---- .../ws/rs/resources/TestTablesResource.java | 204 --- .../resources/dataset/TestAlterTable/table1.tbl | 3 - .../resources/dataset/TestAlterTable/table2.tbl | 1 - .../dataset/TestCreateTable/table1/table1.tbl | 3 - .../dataset/TestCreateTable/table2/table2.tbl | 3 - .../resources/dataset/TestDropTable/table1.tbl | 3 - .../dataset/TestHBaseTable/splits.data | 4 - .../dataset/TestJoinQuery/table1/table1.tbl | 5 - .../dataset/TestJoinQuery/table2/table2.tbl | 4 - .../dataset/TestNetTypes/table1/table1.tbl | 5 - .../dataset/TestNetTypes/table2/table2.tbl | 5 - .../TestSelectNestedRecord/sample1/table.json | 3 - .../TestSelectNestedRecord/sample2/sample2.json | 1 - .../TestSelectNestedRecord/tweets/sample1.json | 4 - .../multibytes_delimiter1/table1.tbl | 5 - .../multibytes_delimiter2/table2.tbl | 5 - .../TestSelectQuery/timezoned/table1.tbl | 3 - .../dataset/TestSortQuery/table1/table1.tbl | 5 - .../dataset/TestSortQuery/table2/table2.tbl | 24 - .../TestTablePartitions/lineitemspecial.tbl | 5 - .../dataset/TestTajoJdbc/table1/table1.tbl | 5 - .../truncate_table2/table2.tbl | 4 - tajo-core/src/test/resources/log4j.properties | 28 - tajo-core/src/test/resources/python/__init__.py | 17 - .../src/test/resources/python/test_funcs.py | 33 - .../src/test/resources/python/test_funcs2.py | 32 - .../src/test/resources/python/test_udaf.py | 76 - .../alter_table_add_new_column_ddl.sql | 1 - .../alter_table_add_partition1.sql | 1 - .../alter_table_add_partition2.sql | 1 - .../alter_table_drop_partition1.sql | 1 - .../alter_table_drop_partition2.sql | 1 - .../alter_table_rename_column_ddl.sql | 1 - .../alter_table_rename_table_ddl.sql | 1 - .../alter_table_set_property_delimiter.sql | 1 - .../alter_table_set_property_timezone.sql | 1 - .../TestAlterTable/create_partitioned_table.sql | 1 - .../queries/TestAlterTable/table1_ddl.sql | 1 - .../queries/TestAlterTable/table2_ddl.sql | 1 - .../testAlterTableSetProperty.sql | 1 - .../testAlterTableSetProperty2.sql | 1 - .../TestBuiltinFunctions/testAvgDouble.sql | 1 - .../queries/TestBuiltinFunctions/testAvgInt.sql | 1 - .../TestBuiltinFunctions/testAvgLong.sql | 1 - .../testAvgLongOverflow.sql | 1 - .../queries/TestBuiltinFunctions/testCount.sql | 1 - .../TestBuiltinFunctions/testMaxLong.sql | 1 - .../TestBuiltinFunctions/testMaxString.sql | 1 - .../TestBuiltinFunctions/testMinLong.sql | 1 - .../TestBuiltinFunctions/testMinString.sql | 1 - .../queries/TestBuiltinFunctions/testRandom.sql | 1 - .../TestBuiltinFunctions/testSplitPart.sql | 1 - .../testSplitPartByString.sql | 1 - .../testSplitPartNested.sql | 1 - .../queries/TestCTASQuery/CtasWithGroupby.sql | 2 - .../queries/TestCTASQuery/CtasWithLimit.sql | 13 - .../TestCTASQuery/CtasWithManagedTable.sql | 12 - .../TestCTASQuery/CtasWithMultipleUnions.sql | 12 - .../queries/TestCTASQuery/CtasWithOptions.sql | 13 - .../queries/TestCTASQuery/CtasWithOrderby.sql | 11 - .../queries/TestCTASQuery/CtasWithStoreType.sql | 12 - .../queries/TestCTASQuery/CtasWithTextFile.sql | 12 - .../queries/TestCTASQuery/CtasWithUnion.sql | 35 - .../resources/queries/TestCTASQuery/check1.sql | 1 - .../resources/queries/TestCTASQuery/check2.sql | 1 - .../testCtasWithColumnedPartition.sql | 2 - .../TestCTASQuery/testCtasWithGroupby.sql | 1 - .../queries/TestCTASQuery/testCtasWithLimit.sql | 1 - .../testCtasWithMultipleUnions.sql | 1 - .../TestCTASQuery/testCtasWithOptions.sql | 1 - .../TestCTASQuery/testCtasWithOrderby.sql | 1 - .../TestCTASQuery/testCtasWithStoreType.sql | 1 - .../TestCTASQuery/testCtasWithTextFile.sql | 1 - .../queries/TestCTASQuery/testCtasWithUnion.sql | 1 - .../testCtasWithoutTableDefinition.sql | 2 - .../TestCaseByCases/testTAJO1224Case1.sql | 1 - .../queries/TestCaseByCases/testTAJO415Case.sql | 36 - .../queries/TestCaseByCases/testTAJO418Case.sql | 29 - .../queries/TestCaseByCases/testTAJO619Case.sql | 4 - .../queries/TestCaseByCases/testTAJO718Case.sql | 10 - .../queries/TestCaseByCases/testTAJO739Case.sql | 5 - .../TestCaseByCases/testTAJO914Case1.sql | 10 - .../TestCaseByCases/testTAJO914Case2.sql | 9 - .../TestCaseByCases/testTAJO914Case3.sql | 10 - .../TestCaseByCases/testTAJO914Case4.sql | 10 - .../TestCaseByCases/testTAJO917Case1.sql | 13 - .../queries/TestCreateIndex/testCreateIndex.sql | 1 - .../testCreateIndexOnExpression.sql | 1 - .../testCreateIndexOnLocation.sql | 1 - .../testCreateIndexOnMultiAttrs.sql | 1 - .../testCreateIndexOnMultiExprs.sql | 1 - .../testCreateIndexWithCondition.sql | 1 - .../create_table_various_types.sql | 50 - ...ate_table_various_types_for_hive_catalog.sql | 50 - .../quoted_identifier_mixed_chars_1.sql | 1 - .../quoted_identifier_mixed_chars_2.sql | 1 - .../quoted_identifier_mixed_chars_3.sql | 22 - .../quoted_identifier_mixed_chars_ddl_1.sql | 1 - .../quoted_identifier_mixed_chars_ddl_2.sql | 1 - .../quoted_identifier_non_ascii_1.sql | 1 - .../quoted_identifier_non_ascii_2.sql | 1 - .../quoted_identifier_non_ascii_3.sql | 1 - .../quoted_identifier_non_ascii_ddl.sql | 1 - .../queries/TestCreateTable/table1_ddl.sql | 1 - .../TestCreateTable/testNestedRecord1.sql | 1 - .../TestCreateTable/testNestedRecord2.sql | 1 - .../queries/TestDropTable/drop_table_ddl.sql | 1 - .../queries/TestDropTable/table1_ddl.sql | 1 - .../TestGroupByQuery/testComplexParameter.sql | 1 - .../TestGroupByQuery/testComplexParameter2.sql | 1 - .../testComplexParameterWithSubQuery.sql | 6 - .../testComplexTargetWithPythonUdaf.sql | 1 - .../testDistinctAggregation1.sql | 1 - .../testDistinctAggregation2.sql | 1 - .../testDistinctAggregation3.sql | 1 - .../testDistinctAggregation4.sql | 1 - .../testDistinctAggregation5.sql | 1 - .../testDistinctAggregation6.sql | 9 - .../testDistinctAggregation7.sql | 6 - .../testDistinctAggregation8.sql | 9 - .../testDistinctAggregationCaseByCase3.sql | 8 - .../testDistinctAggregationCaseByCase4.sql | 7 - .../testDistinctAggregationWithHaving1.sql | 1 - .../testDistinctAggregationWithUnion1.sql | 21 - .../testDistinctAggregation_case1.sql | 7 - .../testDistinctAggregation_case10.sql | 5 - .../testDistinctAggregation_case2.sql | 8 - .../testDistinctAggregation_case3.sql | 9 - .../testDistinctAggregation_case4.sql | 10 - .../testDistinctAggregation_case5.sql | 10 - .../testDistinctAggregation_case6.sql | 12 - .../testDistinctAggregation_case7.sql | 9 - .../testDistinctAggregation_case8.sql | 10 - .../testDistinctAggregation_case9.sql | 11 - .../testDistinctPythonUdafWithUnion1.sql | 21 - .../queries/TestGroupByQuery/testGroupBy.sql | 1 - .../queries/TestGroupByQuery/testGroupBy2.sql | 1 - .../queries/TestGroupByQuery/testGroupBy3.sql | 1 - .../queries/TestGroupByQuery/testGroupBy4.sql | 9 - .../queries/TestGroupByQuery/testGroupBy5.sql | 1 - .../TestGroupByQuery/testGroupByNested1.sql | 8 - .../TestGroupByQuery/testGroupByNested2.sql | 10 - .../testGroupByWithConstantKeys1.sql | 1 - .../testGroupByWithConstantKeys2.sql | 1 - .../testGroupByWithConstantKeys3.sql | 8 - .../testGroupByWithConstantKeys4.sql | 12 - .../testGroupByWithConstantKeys5.sql | 13 - .../testGroupByWithExpressionKeys1.sql | 1 - .../testGroupByWithExpressionKeys2.sql | 1 - .../testGroupByWithNullData1.sql | 1 - .../testGroupByWithNullData10.sql | 3 - .../testGroupByWithNullData11.sql | 5 - .../testGroupByWithNullData12.sql | 29 - .../testGroupByWithNullData2.sql | 1 - .../testGroupByWithNullData3.sql | 3 - .../testGroupByWithNullData4.sql | 3 - .../testGroupByWithNullData5.sql | 1 - .../testGroupByWithNullData6.sql | 1 - .../testGroupByWithNullData7.sql | 1 - .../testGroupByWithNullData8.sql | 1 - .../testGroupByWithNullData9.sql | 4 - .../testGroupByWithSameConstantKeys1.sql | 1 - .../testGroupByWithSameExprs1.sql | 8 - .../testGroupByWithSameExprs2.sql | 8 - .../TestGroupByQuery/testGroupbyWithJson.json | 127 -- .../TestGroupByQuery/testGroupbyWithLimit1.sql | 1 - .../TestGroupByQuery/testGroupbyWithLimit2.sql | 1 - .../TestGroupByQuery/testGroupbyWithLimit3.sql | 1 - .../testGroupbyWithPythonFunc.sql | 1 - .../testGroupbyWithPythonFunc2.sql | 1 - .../testHavingWithAggFunction.sql | 1 - .../testHavingWithNamedTarget.sql | 13 - .../queries/TestGroupByQuery/testPythonUdaf.sql | 1 - .../TestGroupByQuery/testPythonUdaf2.sql | 1 - .../TestGroupByQuery/testPythonUdaf3.sql | 1 - .../testPythonUdafWithHaving.sql | 3 - .../testPythonUdafWithNullData.sql | 4 - .../TestInSubquery/testInAndNotInSubQuery.sql | 3 - .../queries/TestInSubquery/testInSubQuery.sql | 1 - .../queries/TestInSubquery/testInSubQuery2.sql | 2 - .../TestInSubquery/testInSubQueryWithJoin.sql | 2 - .../testInSubQueryWithOtherConditions.sql | 2 - .../testInSubQueryWithTableSubQuery.sql | 2 - .../TestInSubquery/testMultipleInSubQuery.sql | 5 - .../testMultipleNotInSubQuery.sql | 3 - .../testNestedInAndNotInSubQuery.sql | 5 - .../TestInSubquery/testNestedInSubQuery.sql | 4 - .../TestInSubquery/testNestedInSubQuery2.sql | 4 - .../TestInSubquery/testNestedNotInSubQuery.sql | 4 - .../TestInSubquery/testNotInSubQuery.sql | 1 - .../testSameKeyNameOfOuterAndInnerQueries.sql | 22 - .../TestInSubquery/testWithAsteriskAndJoin.sql | 7 - .../testBroadcastTwoPartJoin.sql | 19 - .../testCrossJoinAndCaseWhen.sql | 18 - .../testCrossJoinWithAsterisk1.sql | 1 - .../testCrossJoinWithAsterisk2.sql | 1 - .../testCrossJoinWithAsterisk3.sql | 1 - .../testCrossJoinWithAsterisk4.sql | 1 - .../testBroadcastSubquery.sql | 12 - .../testBroadcastSubquery2.sql | 19 - .../testThetaJoinKeyPairs.sql | 20 - .../TestInsertQuery/full_table_csv_ddl.sql | 1 - .../TestInsertQuery/full_table_parquet_ddl.sql | 1 - .../TestInsertQuery/lineitem_year_month_ddl.sql | 18 - .../load_to_lineitem_year_month.sql | 1 - .../TestInsertQuery/nation_diff_col_order.ddl | 1 - .../queries/TestInsertQuery/table1_ddl.sql | 1 - .../queries/TestInsertQuery/test1_ddl.sql | 1 - .../TestInsertQuery/test1_nolength_ddl.sql | 1 - .../queries/TestInsertQuery/testInsertInto.sql | 1 - .../testInsertIntoSelectWithFixedSizeChar.sql | 4 - ...tIntoSelectWithFixedSizeCharWithNoLength.sql | 2 - .../TestInsertQuery/testInsertOverwrite.sql | 1 - .../testInsertOverwriteLocation.sql | 1 - ...stInsertOverwriteLocationWithCompression.sql | 1 - .../testInsertOverwriteLocationWithUnion.sql | 4 - ...verwriteLocationWithUnionDifferenceAlias.sql | 4 - .../testInsertOverwriteSmallerColumns.sql | 1 - .../testInsertOverwriteWithAsterisk.sql | 1 - .../testInsertOverwriteWithAsteriskAndMore.sql | 1 - .../testInsertOverwriteWithCompression.sql | 1 - .../testInsertOverwriteWithCompression_ddl.sql | 4 - .../testInsertOverwriteWithDatabase.sql | 1 - .../testInsertOverwriteWithTargetColumns.sql | 1 - .../testInsertOverwriteWithUnion.sql | 4 - ...stInsertOverwriteWithUnionDifferentAlias.sql | 4 - .../testInsertWithDifferentColumnOrder.sql | 1 - .../selfJoinOfPartitionedTable.sql | 9 - .../testBroadcastPartitionTable.sql | 16 - ...estFilterPushDownPartitionColumnCaseWhen.sql | 6 - ...rtitionedBroadcastDataFileWithZeroLength.sql | 3 - ...titionedBroadcastDataFileWithZeroLength2.sql | 5 - .../testNoProjectionJoinQual.sql | 1 - .../testPartialFilterPushDown.sql | 9 - .../testPartialFilterPushDownOuterJoin.sql | 4 - .../testPartialFilterPushDownOuterJoin2.sql | 5 - .../testPartitionTableJoinSmallTable.sql | 11 - .../TestJoinQuery/create_customer_large_ddl.sql | 7 - .../TestJoinQuery/create_lineitem_large_ddl.sql | 7 - .../TestJoinQuery/create_orders_large_ddl.sql | 7 - .../TestJoinQuery/customer_partition_ddl.sql | 9 - .../TestJoinQuery/insert_into_customer.sql | 11 - .../insert_into_customer_partition.sql | 11 - .../TestJoinQuery/nation_multifile_ddl.sql | 5 - .../queries/TestJoinQuery/oj_table1_ddl.sql | 3 - .../queries/TestJoinQuery/oj_table2_ddl.sql | 3 - .../TestJoinQuery/orders_multifile_ddl.sql | 5 - .../TestJoinQuery/partitioned_customer_ddl.sql | 19 - .../queries/TestJoinQuery/table1_int4_ddl.sql | 3 - .../queries/TestJoinQuery/table1_int8_ddl.sql | 3 - .../TestJoinQuery/testComplexJoinCondition1.sql | 6 - .../TestJoinQuery/testComplexJoinCondition2.sql | 6 - .../TestJoinQuery/testComplexJoinCondition3.sql | 6 - .../TestJoinQuery/testComplexJoinCondition4.sql | 6 - .../TestJoinQuery/testComplexJoinCondition5.sql | 6 - .../TestJoinQuery/testComplexJoinCondition6.sql | 6 - .../TestJoinQuery/testComplexJoinCondition7.sql | 6 - .../testComplexJoinsWithCaseWhen.sql | 11 - .../testComplexJoinsWithCaseWhen2.sql | 9 - .../testCrossJoinWithEmptyTable1.sql | 8 - ...stCrossJoinWithThetaJoinConditionInWhere.sql | 2 - .../testDifferentTypesJoinCondition.sql | 1 - .../TestJoinQuery/testFullOuterJoin1.sql | 8 - .../testFullOuterJoinWithEmptyTable1.sql | 8 - .../TestJoinQuery/testInnerJoinAndCaseWhen.sql | 18 - .../testInnerJoinWithEmptyTable.sql | 8 - ...stInnerJoinWithThetaJoinConditionInWhere.sql | 3 - .../queries/TestJoinQuery/testJoinAsterisk.sql | 3 - .../TestJoinQuery/testJoinCoReferredEvals1.sql | 11 - .../testJoinCoReferredEvalsFilterPushdown.sql | 13 - .../testJoinCoReferredEvalsWithSameExprs1.sql | 14 - .../testJoinCoReferredEvalsWithSameExprs2.sql | 22 - .../testJoinFilterOfRowPreservedTable1.sql | 8 - .../testJoinOnMultipleDatabases.sql | 25 - .../testJoinOnMultipleDatabasesWithJson.json | 210 --- .../queries/TestJoinQuery/testJoinWithJson.json | 92 -- .../TestJoinQuery/testJoinWithJson2.json | 219 --- .../testJoinWithMultipleJoinQual1.sql | 20 - .../testJoinWithMultipleJoinQual2.sql | 8 - .../testJoinWithMultipleJoinQual3.sql | 9 - .../testJoinWithMultipleJoinQual4.sql | 10 - .../testJoinWithMultipleJoinTypes.sql | 4 - .../TestJoinQuery/testJoinWithOrPredicates.sql | 6 - .../TestJoinQuery/testLeftOuterJoin1.sql | 9 - .../testLeftOuterJoinWithConstantExpr1.sql | 9 - .../testLeftOuterJoinWithConstantExpr2.sql | 9 - .../testLeftOuterJoinWithConstantExpr3.sql | 17 - .../testLeftOuterJoinWithConstantExpr4.sql | 6 - .../testLeftOuterJoinWithConstantExpr5.sql | 9 - .../testLeftOuterJoinWithEmptyTable1.sql | 9 - .../testLeftOuterJoinWithEmptyTable2.sql | 9 - .../testLeftOuterJoinWithEmptyTable3.sql | 14 - .../testLeftOuterJoinWithEmptyTable4.sql | 17 - .../testLeftOuterJoinWithEmptyTable5.sql | 11 - .../testLeftOuterJoinWithNull1.sql | 10 - .../testLeftOuterJoinWithNull2.sql | 11 - .../testLeftOuterJoinWithNull3.sql | 10 - ...ftOuterJoinWithThetaJoinConditionInWhere.sql | 3 - .../queries/TestJoinQuery/testNaturalJoin.sql | 3 - .../TestJoinQuery/testOuterJoinAndCaseWhen1.sql | 12 - .../TestJoinQuery/testRightOuterJoin1.sql | 8 - .../testRightOuterJoinWithEmptyTable1.sql | 8 - ...htOuterJoinWithThetaJoinConditionInWhere.sql | 3 - .../queries/TestJoinQuery/testTPCHQ2Join.sql | 25 - .../TestJoinQuery/testWhereClauseJoin1.sql | 11 - .../TestJoinQuery/testWhereClauseJoin2.sql | 9 - .../TestJoinQuery/testWhereClauseJoin3.sql | 10 - .../TestJoinQuery/testWhereClauseJoin4.sql | 9 - .../TestJoinQuery/testWhereClauseJoin5.sql | 15 - .../TestJoinQuery/testWhereClauseJoin6.sql | 19 - .../queries/TestLogicalPlanner/window1.sql | 5 - .../queries/TestNetTypes/table1_ddl.sql | 4 - .../queries/TestNetTypes/table2_ddl.sql | 4 - .../queries/TestNetTypes/testGroupby.sql | 8 - .../queries/TestNetTypes/testGroupby2.sql | 9 - .../resources/queries/TestNetTypes/testJoin.sql | 1 - .../queries/TestNetTypes/testSelect.sql | 1 - .../resources/queries/TestNetTypes/testSort.sql | 1 - .../queries/TestNetTypes/testSort2.sql | 1 - .../TestOuterJoinQuery/testLeftOuterJoin2.sql | 5 - .../TestOuterJoinQuery/testLeftOuterJoin3.sql | 7 - ...tMultipleBroadcastDataFileWithZeroLength.sql | 3 - ...MultipleBroadcastDataFileWithZeroLength2.sql | 5 - .../TestQueryValidation/error_groupby_1.sql | 1 - .../TestQueryValidation/error_groupby_2.sql | 1 - .../TestQueryValidation/invalid_casewhen_1.sql | 15 - .../TestQueryValidation/invalid_limit_1.sql | 1 - .../invalid_store_format.sql | 1 - .../TestQueryValidation/valid_groupby_1.sql | 1 - .../TestQueryValidation/valid_limit_1.sql | 1 - .../TestSQLAnalyzer/create_table_nested_1.sql | 1 - .../TestSQLAnalyzer/create_table_nested_2.sql | 1 - .../queries/TestSQLAnalyzer/setcatalog1.sql | 1 - .../queries/TestSQLAnalyzer/setcatalog2.sql | 1 - .../queries/TestSQLAnalyzer/setsession1.sql | 1 - .../queries/TestSQLAnalyzer/setsession2.sql | 1 - .../queries/TestSQLAnalyzer/setsession3.sql | 1 - .../queries/TestSQLAnalyzer/setsession4.sql | 1 - .../queries/TestSQLAnalyzer/setsession5.sql | 1 - .../queries/TestSQLAnalyzer/setsession6.sql | 1 - .../queries/TestSQLAnalyzer/setsession7.sql | 1 - .../queries/TestSQLAnalyzer/settimezone1.sql | 1 - .../queries/TestSQLAnalyzer/settimezone2.sql | 1 - .../queries/TestSQLAnalyzer/settimezone3.sql | 1 - .../queries/TestSQLAnalyzer/window1.sql | 5 - .../queries/TestSQLAnalyzer/window2.sql | 5 - .../queries/TestSQLAnalyzer/window3.sql | 5 - .../queries/TestSQLAnalyzer/window4.sql | 5 - .../queries/TestSQLAnalyzer/window5.sql | 6 - .../queries/TestSQLAnalyzer/window6.sql | 6 - .../queries/TestSQLAnalyzer/window7.sql | 6 - .../queries/TestSQLAnalyzer/window8.sql | 6 - .../queries/TestSQLAnalyzer/window9.sql | 9 - .../TestSelectNestedRecord/sample0_ddl.sql | 1 - .../TestSelectNestedRecord/sample1_ddl.sql | 7 - .../TestSelectNestedRecord/sample2_ddl.sql | 23 - .../testNestedFieldAsGroupbyKey1.sql | 9 - .../testNestedFieldAsJoinKey1.sql | 7 - .../TestSelectNestedRecord/testSelect0.sql | 1 - .../TestSelectNestedRecord/testSelect1.sql | 1 - .../TestSelectNestedRecord/testSelect2.sql | 61 - .../TestSelectNestedRecord/testSelect3.sql | 1 - .../TestSelectNestedRecord/tweets_ddl.sql | 74 - .../queries/TestSelectQuery/customer_ddl.sql | 9 - .../TestSelectQuery/datetime_table_ddl.sql | 4 - .../datetime_table_timezoned_ddl.sql | 4 - .../TestSelectQuery/insert_into_customer.sql | 11 - .../multibytes_delimiter_table1_ddl.sql | 3 - .../multibytes_delimiter_table2_ddl.sql | 3 - .../multibytes_delimiter_table3_ddl.sql | 3 - .../multibytes_delimiter_table4_ddl.sql | 3 - .../queries/TestSelectQuery/testCaseWhen.sql | 11 - .../TestSelectQuery/testCaseWhenRound.sql | 8 - .../TestSelectQuery/testCaseWhenWithoutElse.sql | 10 - .../testColumnEqualityButNotJoinCondition1.sql | 7 - .../testColumnEqualityButNotJoinCondition2.sql | 7 - .../TestSelectQuery/testCreateAfterSelect.sql | 1 - .../TestSelectQuery/testDatabaseRef1.sql | 1 - .../TestSelectQuery/testDatabaseRef2.sql | 1 - .../TestSelectQuery/testDatabaseRef3.sql | 1 - .../TestSelectQuery/testExplainSelect.sql | 1 - .../queries/TestSelectQuery/testInClause.sql | 1 - .../queries/TestSelectQuery/testInStrClause.sql | 1 - .../queries/TestSelectQuery/testLikeClause.sql | 1 - .../queries/TestSelectQuery/testLimit.sql | 1 - .../testMultiBytesDelimiter1.sql | 1 - .../testMultiBytesDelimiter2.sql | 1 - .../testMultiBytesDelimiter3.sql | 1 - .../testMultiBytesDelimiter4.sql | 1 - .../testNestedPythonFunction.sql | 1 - .../TestSelectQuery/testNonFromSelect1.sql | 1 - .../TestSelectQuery/testNonQualifiedNames.sql | 1 - .../queries/TestSelectQuery/testNotEqual.sql | 1 - .../queries/TestSelectQuery/testNotInClause.sql | 1 - .../TestSelectQuery/testNotInStrClause.sql | 1 - .../TestSelectQuery/testRealValueCompare.sql | 1 - .../queries/TestSelectQuery/testSelect.sql | 1 - .../queries/TestSelectQuery/testSelect2.sql | 1 - .../queries/TestSelectQuery/testSelect3.sql | 1 - .../TestSelectQuery/testSelectAsterik.sql | 1 - .../TestSelectQuery/testSelectAsterisk1.sql | 1 - .../TestSelectQuery/testSelectAsterisk2.sql | 1 - .../TestSelectQuery/testSelectAsterisk3.sql | 1 - .../TestSelectQuery/testSelectAsterisk4.sql | 1 - .../TestSelectQuery/testSelectAsterisk5.sql | 1 - .../TestSelectQuery/testSelectColumnAlias1.sql | 1 - ...testSelectColumnAliasExistingInRelation1.sql | 1 - ...testSelectColumnAliasExistingInRelation2.sql | 1 - ...testSelectColumnAliasExistingInRelation3.sql | 19 - .../TestSelectQuery/testSelectDistinct.sql | 7 - .../testSelectOnSessionTable.sql | 1 - .../TestSelectQuery/testSelectPythonFuncs.sql | 2 - ...tSelectSameConstantsWithDifferentAliases.sql | 1 - ...SelectSameConstantsWithDifferentAliases2.sql | 1 - ...SelectSameConstantsWithDifferentAliases3.sql | 10 - .../testSelectSameExprsWithDifferentAliases.sql | 1 - .../TestSelectQuery/testSelectWithJson.json | 74 - .../testSelectWithParentheses1.sql | 1 - .../testSelectWithParentheses2.sql | 1 - .../testSelectWithPredicateOnPythonFunc.sql | 1 - .../queries/TestSelectQuery/testSimpleQuery.sql | 1 - .../testSimpleQueryWithLimit.sql | 1 - ...testSimpleQueryWithLimitPartitionedTable.sql | 1 - .../TestSelectQuery/testStringCompare.sql | 1 - .../TestSelectQuery/testSumFloatOverflow.sql | 1 - .../TestSelectQuery/testSumIntOverflow.sql | 1 - .../TestSelectQuery/testTimezonedTable1.sql | 1 - .../TestSelectQuery/testTimezonedTable2.sql | 2 - .../TestSelectQuery/testTimezonedTable3.sql | 1 - .../TestSelectQuery/testTimezonedTable4.sql | 2 - .../TestSelectQuery/testTimezonedTable5.sql | 2 - .../queries/TestSelectQuery/testWhereCond1.sql | 1 - .../queries/TestSelectQuery/testWhereCond2.sql | 9 - .../TestSelectQuery/testWhereCondWithAlias1.sql | 1 - .../TestSelectQuery/testWhereCondWithAlias2.sql | 1 - .../create_table_with_asc_desc_keys.sql | 1 - .../create_table_with_date_ddl.sql | 10 - .../queries/TestSortQuery/testAsterisk.sql | 1 - .../queries/TestSortQuery/testSort.sql | 1 - .../TestSortQuery/testSortAfterGroupby.sql | 1 - .../testSortAfterGroupbyWithAlias.sql | 1 - .../queries/TestSortQuery/testSortDesc.sql | 1 - .../queries/TestSortQuery/testSortFirstDesc.sql | 1 - .../TestSortQuery/testSortOnNullColumn.sql | 13 - .../TestSortQuery/testSortOnUnicodeTextAsc.sql | 6 - .../TestSortQuery/testSortOnUnicodeTextDesc.sql | 6 - .../TestSortQuery/testSortWithAlias1.sql | 1 - .../TestSortQuery/testSortWithAlias2.sql | 9 - .../TestSortQuery/testSortWithAlias3.sql | 11 - .../testSortWithAliasButOriginalName.sql | 1 - .../TestSortQuery/testSortWithAscDescKeys.sql | 1 - .../TestSortQuery/testSortWithConstKeys.sql | 10 - .../queries/TestSortQuery/testSortWithDate.sql | 1 - .../queries/TestSortQuery/testSortWithExpr1.sql | 1 - .../queries/TestSortQuery/testSortWithExpr2.sql | 1 - .../queries/TestSortQuery/testSortWithJson.json | 65 - .../testSubQuerySortAfterGroupMultiBlocks.sql | 5 - .../queries/TestSortQuery/testTopK.sql | 1 - .../queries/TestSortQuery/testTopkWithJson.json | 51 - .../queries/TestTPCH/testFirstJoinInQ7.sql | 13 - .../queries/TestTPCH/testQ1OrderBy.sql | 12 - .../queries/TestTPCH/testQ2FourJoins.sql | 18 - .../queries/TestTPCH/testTPCH14Expr.sql | 12 - .../resources/queries/TestTPCH/testTPCHQ5.sql | 24 - .../queries/TestTablePartitions/case1.sql | 16 - .../queries/TestTablePartitions/case10.sql | 1 - .../queries/TestTablePartitions/case11.sql | 1 - .../queries/TestTablePartitions/case12.sql | 7 - .../queries/TestTablePartitions/case13.sql | 11 - .../queries/TestTablePartitions/case14.sql | 3 - .../queries/TestTablePartitions/case15.sql | 3 - .../queries/TestTablePartitions/case2.sql | 31 - .../queries/TestTablePartitions/case3.sql | 8 - .../queries/TestTablePartitions/case4.sql | 1 - .../queries/TestTablePartitions/case5.sql | 1 - .../queries/TestTablePartitions/case6.sql | 1 - .../queries/TestTablePartitions/case7.sql | 1 - .../queries/TestTablePartitions/case8.sql | 1 - .../queries/TestTablePartitions/case9.sql | 1 - .../TestTablePartitions/lineitemspecial_ddl.sql | 3 - .../TestTableSubQuery/testGroupBySubQuery.sql | 1 - .../testGroupbySubqueryWithJson.json | 59 - .../TestTableSubQuery/testJoinSubQuery.sql | 5 - .../TestTableSubQuery/testJoinSubQuery2.sql | 4 - .../testJoinSubqueryWithJson.json | 108 -- .../TestTableSubQuery/testTableSubquery1.sql | 1 - .../TestTajoJdbc/create_table_with_date_ddl.sql | 10 - .../queries/TestTaskStatusUpdate/case1.sql | 1 - .../queries/TestTaskStatusUpdate/case2.sql | 5 - .../queries/TestTaskStatusUpdate/case3.sql | 10 - .../queries/TestTruncateTable/table1_ddl.sql | 1 - .../queries/TestTruncateTable/table2_ddl.sql | 1 - .../TestUnionQuery/testComplexUnion1.sql | 27 - .../TestUnionQuery/testComplexUnion2.sql | 35 - .../queries/TestUnionQuery/testUnion1.sql | 19 - .../queries/TestUnionQuery/testUnion10.sql | 158 -- .../queries/TestUnionQuery/testUnion11.sql | 8 - .../queries/TestUnionQuery/testUnion12.sql | 14 - .../queries/TestUnionQuery/testUnion13.sql | 15 - .../queries/TestUnionQuery/testUnion14.sql | 8 - .../queries/TestUnionQuery/testUnion15.sql | 15 - .../queries/TestUnionQuery/testUnion16.sql | 15 - .../queries/TestUnionQuery/testUnion2.sql | 18 - .../queries/TestUnionQuery/testUnion3.sql | 19 - .../queries/TestUnionQuery/testUnion4.sql | 16 - .../queries/TestUnionQuery/testUnion5.sql | 20 - .../queries/TestUnionQuery/testUnion6.sql | 15 - .../queries/TestUnionQuery/testUnion7.sql | 18 - .../queries/TestUnionQuery/testUnion8.sql | 24 - .../queries/TestUnionQuery/testUnion9.sql | 29 - .../queries/TestUnionQuery/testUnionAll1.sql | 19 - .../queries/TestUnionQuery/testUnionAll10.sql | 158 -- .../queries/TestUnionQuery/testUnionAll11.sql | 8 - .../queries/TestUnionQuery/testUnionAll12.sql | 13 - .../queries/TestUnionQuery/testUnionAll13.sql | 14 - .../queries/TestUnionQuery/testUnionAll14.sql | 8 - .../queries/TestUnionQuery/testUnionAll15.sql | 15 - .../queries/TestUnionQuery/testUnionAll16.sql | 15 - .../queries/TestUnionQuery/testUnionAll2.sql | 18 - .../queries/TestUnionQuery/testUnionAll3.sql | 19 - .../queries/TestUnionQuery/testUnionAll4.sql | 16 - .../queries/TestUnionQuery/testUnionAll5.sql | 20 - .../queries/TestUnionQuery/testUnionAll6.sql | 15 - .../queries/TestUnionQuery/testUnionAll7.sql | 18 - .../queries/TestUnionQuery/testUnionAll8.sql | 24 - .../queries/TestUnionQuery/testUnionAll9.sql | 29 - .../testUnionAllWithDifferentAlias.sql | 29 - ...estUnionAllWithDifferentAliasAndFunction.sql | 29 - .../testUnionAllWithSameAliasNames.sql | 25 - .../testUnionWithDifferentAlias.sql | 29 - .../testUnionWithDifferentAliasAndFunction.sql | 29 - .../testUnionWithSameAliasNames.sql | 25 - .../TestWindowQuery/testComplexOrderBy1.sql | 5 - .../queries/TestWindowQuery/testFirstValue1.sql | 18 - .../queries/TestWindowQuery/testLag1.sql | 18 - .../TestWindowQuery/testLagWithDefault.sql | 18 - .../TestWindowQuery/testLagWithNoArgs.sql | 18 - .../queries/TestWindowQuery/testLastValue1.sql | 18 - .../queries/TestWindowQuery/testLead1.sql | 18 - .../TestWindowQuery/testLeadWithDefault.sql | 18 - .../TestWindowQuery/testLeadWithNoArgs.sql | 18 - .../queries/TestWindowQuery/testRowNumber1.sql | 5 - .../queries/TestWindowQuery/testRowNumber2.sql | 5 - .../queries/TestWindowQuery/testRowNumber3.sql | 7 - .../queries/TestWindowQuery/testStdDevPop1.sql | 14 - .../queries/TestWindowQuery/testStdDevSamp1.sql | 14 - .../queries/TestWindowQuery/testWindow1.sql | 1 - .../queries/TestWindowQuery/testWindow2.sql | 1 - .../queries/TestWindowQuery/testWindow3.sql | 1 - .../queries/TestWindowQuery/testWindow4.sql | 1 - .../queries/TestWindowQuery/testWindow5.sql | 1 - .../queries/TestWindowQuery/testWindow6.sql | 1 - .../queries/TestWindowQuery/testWindow7.sql | 1 - .../queries/TestWindowQuery/testWindow8.sql | 7 - .../TestWindowQuery/testWindowBeforeLimit.sql | 6 - .../testWindowWithAggregation1.sql | 4 - .../testWindowWithAggregation2.sql | 7 - .../testWindowWithAggregation3.sql | 5 - .../testWindowWithAggregation4.sql | 8 - .../testWindowWithAggregation5.sql | 9 - .../testWindowWithAggregation6.sql | 10 - .../TestWindowQuery/testWindowWithOrderBy1.sql | 6 - .../TestWindowQuery/testWindowWithOrderBy2.sql | 6 - .../TestWindowQuery/testWindowWithOrderBy3.sql | 6 - .../TestWindowQuery/testWindowWithOrderBy4.sql | 7 - .../TestWindowQuery/testWindowWithOrderBy5.sql | 9 - .../TestWindowQuery/testWindowWithSubQuery.sql | 14 - .../TestWindowQuery/testWindowWithSubQuery2.sql | 15 - .../TestWindowQuery/testWindowWithSubQuery3.sql | 14 - .../TestWindowQuery/testWindowWithSubQuery4.sql | 14 - .../TestWindowQuery/testWindowWithSubQuery5.sql | 11 - .../TestWindowQuery/testWindowWithSubQuery6.sql | 9 - .../default/alter_table_add_partition_1.sql | 1 - .../default/alter_table_add_partition_2.sql | 1 - .../default/alter_table_add_partition_3.sql | 2 - .../default/alter_table_add_partition_4.sql | 1 - .../default/alter_table_add_partition_5.sql | 1 - .../default/alter_table_drop_partition_1.sql | 1 - .../default/alter_table_drop_partition_2.sql | 1 - .../default/alter_table_drop_partition_3.sql | 1 - .../default/alter_table_drop_partition_4.sql | 1 - .../default/alter_table_set_property_1.sql | 1 - .../default/alter_table_set_property_2.sql | 1 - .../default/alter_table_set_property_3.sql | 1 - .../resources/queries/default/asterisk_1.sql | 1 - .../resources/queries/default/asterisk_2.sql | 1 - .../resources/queries/default/asterisk_3.sql | 1 - .../resources/queries/default/asterisk_4.sql | 1 - .../create_partitioned_table_as_select.sql | 17 - .../queries/default/create_table_1.hiveql | 1 - .../queries/default/create_table_1.sql | 1 - .../queries/default/create_table_10.sql | 1 - .../queries/default/create_table_11.hiveql | 3 - .../queries/default/create_table_11.sql | 3 - .../queries/default/create_table_12.hiveql | 4 - .../queries/default/create_table_12.sql | 3 - .../queries/default/create_table_2.hiveql | 1 - .../queries/default/create_table_2.sql | 1 - .../queries/default/create_table_3.sql | 1 - .../queries/default/create_table_4.sql | 1 - .../queries/default/create_table_5.sql | 1 - .../queries/default/create_table_6.sql | 1 - .../queries/default/create_table_7.sql | 1 - .../queries/default/create_table_8.sql | 48 - .../queries/default/create_table_9.sql | 1 - .../queries/default/create_table_like_1.sql | 1 - .../create_table_partition_by_column.sql | 4 - .../create_table_partition_by_hash_1.sql | 3 - .../create_table_partition_by_hash_2.sql | 7 - .../default/create_table_partition_by_list.sql | 8 - .../default/create_table_partition_by_range.sql | 9 - .../resources/queries/default/drop_table.sql | 1 - .../queries/default/exists_predicate_1.sql | 1 - .../queries/default/exists_predicate_2.sql | 1 - .../resources/queries/default/groupby_1.sql | 1 - .../resources/queries/default/groupby_2.sql | 1 - .../resources/queries/default/groupby_3.sql | 1 - .../resources/queries/default/groupby_4.sql | 1 - .../resources/queries/default/groupby_5.sql | 1 - .../resources/queries/default/in_subquery_1.sql | 1 - .../resources/queries/default/in_subquery_2.sql | 1 - .../queries/default/insert_into_select_1.sql | 1 - .../queries/default/insert_into_select_2.sql | 1 - .../queries/default/insert_into_select_3.sql | 1 - .../default/insert_overwrite_into_select_1.sql | 1 - .../insert_overwrite_into_select_2.hiveql | 1 - .../default/insert_overwrite_into_select_2.sql | 1 - .../default/insert_overwrite_into_select_3.sql | 1 - .../test/resources/queries/default/join_1.sql | 1 - .../test/resources/queries/default/join_10.sql | 1 - .../test/resources/queries/default/join_11.sql | 1 - .../test/resources/queries/default/join_12.sql | 1 - .../test/resources/queries/default/join_13.sql | 13 - .../test/resources/queries/default/join_14.sql | 1 - .../resources/queries/default/join_15.hiveql | 1 - .../test/resources/queries/default/join_15.sql | 1 - .../test/resources/queries/default/join_2.sql | 1 - .../test/resources/queries/default/join_3.sql | 1 - .../test/resources/queries/default/join_4.sql | 1 - .../test/resources/queries/default/join_5.sql | 1 - .../test/resources/queries/default/join_6.sql | 1 - .../test/resources/queries/default/join_7.sql | 1 - .../test/resources/queries/default/join_8.sql | 13 - .../test/resources/queries/default/join_9.sql | 5 - .../test/resources/queries/default/select_1.sql | 1 - .../resources/queries/default/select_10.hiveql | 5 - .../resources/queries/default/select_10.sql | 5 - .../resources/queries/default/select_11.hiveql | 4 - .../resources/queries/default/select_11.sql | 6 - .../resources/queries/default/select_12.hiveql | 3 - .../resources/queries/default/select_13.hiveql | 2 - .../resources/queries/default/select_13.sql | 2 - .../resources/queries/default/select_14.sql | 2 - .../resources/queries/default/select_15.hiveql | 1 - .../resources/queries/default/select_15.sql | 1 - .../test/resources/queries/default/select_2.sql | 1 - .../test/resources/queries/default/select_3.sql | 1 - .../test/resources/queries/default/select_4.sql | 1 - .../test/resources/queries/default/select_5.sql | 1 - .../test/resources/queries/default/select_6.sql | 1 - .../test/resources/queries/default/select_7.sql | 1 - .../test/resources/queries/default/select_8.sql | 1 - .../resources/queries/default/select_9.hiveql | 4 - .../test/resources/queries/default/select_9.sql | 4 - .../test/resources/queries/default/set_1.sql | 1 - .../test/resources/queries/default/set_2.sql | 1 - .../test/resources/queries/default/set_3.sql | 1 - .../test/resources/queries/default/set_4.sql | 36 - .../queries/default/table_subquery1.sql | 19 - .../queries/default/table_subquery2.sql | 21 - .../resources/queries/default/union_1.hiveql | 14 - .../after_set_property_delimiter.result | 3 - .../before_set_property_delimiter.result | 3 - .../TestBuiltinFunctions/testAvgDouble.result | 5 - .../TestBuiltinFunctions/testAvgInt.result | 3 - .../TestBuiltinFunctions/testAvgLong.result | 3 - .../testAvgLongOverflow.result | 3 - .../TestBuiltinFunctions/testCount.result | 3 - .../TestBuiltinFunctions/testMaxLong.result | 3 - .../TestBuiltinFunctions/testMaxString.result | 3 - .../TestBuiltinFunctions/testMinLong.result | 3 - .../TestBuiltinFunctions/testMinString.result | 3 - .../TestBuiltinFunctions/testSplitPart.result | 7 - .../testSplitPartByString.result | 7 - .../testSplitPartNested.result | 7 - .../TestCTASQuery/testCtasWithGroupby.result | 7 - .../TestCTASQuery/testCtasWithLimit.result | 5 - .../TestCTASQuery/testCtasWithOptions.result | 5 - .../TestCTASQuery/testCtasWithOrderby.result | 7 - .../TestCTASQuery/testCtasWithStoreType.result | 5 - .../TestCTASQuery/testCtasWithTextFile.result | 5 - .../TestCTASQuery/testCtasWithUnion.result | 8 - .../TestCaseByCases/testTAJO1224Case1.result | 3 - .../TestCaseByCases/testTAJO415Case.result | 7 - .../TestCaseByCases/testTAJO418Case.result | 4 - .../TestCaseByCases/testTAJO619Case.result | 3 - .../TestCaseByCases/testTAJO718Case.result | 5 - .../TestCaseByCases/testTAJO739Case.result | 7 - .../TestCaseByCases/testTAJO914Case1.result | 5 - .../TestCaseByCases/testTAJO914Case2.result | 5 - .../TestCaseByCases/testTAJO914Case3.result | 5 - .../TestCaseByCases/testTAJO914Case4.result | 5 - .../TestCaseByCases/testTAJO917Case1.result | 7 - .../quoted_identifier_mixed_chars_1.result | 5 - .../quoted_identifier_mixed_chars_2.result | 5 - .../quoted_identifier_mixed_chars_3.result | 8 - .../quoted_identifier_non_ascii_1.result | 5 - .../quoted_identifier_non_ascii_2.result | 5 - .../quoted_identifier_non_ascii_3.result | 5 - .../testFindScalarFunctions.result | 2 - .../testComplexParameter.result | 3 - .../testComplexParameter2.result | 3 - .../testComplexParameterWithSubQuery.result | 3 - .../testComplexTargetWithPythonUdaf.result | 3 - .../testDistinctAggregation1.result | 5 - .../testDistinctAggregation2.result | 5 - .../testDistinctAggregation3.result | 3 - .../testDistinctAggregation4.result | 4 - .../testDistinctAggregation5.result | 4 - .../testDistinctAggregation6.result | 5 - .../testDistinctAggregation7.result | 3 - .../testDistinctAggregation8.result | 7 - .../testDistinctAggregationCaseByCase3.result | 3 - .../testDistinctAggregationCaseByCase4.result | 3 - .../testDistinctAggregationWithHaving1.result | 3 - .../testDistinctAggregationWithUnion1.result | 4 - .../testDistinctAggregation_case1.result | 4 - .../testDistinctAggregation_case10.result | 3 - .../testDistinctAggregation_case2.result | 4 - .../testDistinctAggregation_case3.result | 4 - .../testDistinctAggregation_case4.result | 5 - .../testDistinctAggregation_case5.result | 5 - .../testDistinctAggregation_case6.result | 5 - .../testDistinctAggregation_case7.result | 5 - .../testDistinctAggregation_case8.result | 6 - .../testDistinctAggregation_case9.result | 6 - .../testDistinctPythonUdafWithUnion1.result | 4 - .../results/TestGroupByQuery/testGroupBy.result | 3 - .../TestGroupByQuery/testGroupBy2.result | 4 - .../TestGroupByQuery/testGroupBy3.result | 5 - .../TestGroupByQuery/testGroupBy4.result | 5 - .../TestGroupByQuery/testGroupBy5.result | 5 - .../TestGroupByQuery/testGroupByNested1.result | 6 - .../TestGroupByQuery/testGroupByNested2.result | 6 - .../testGroupByWithConstantKeys1.result | 3 - .../testGroupByWithConstantKeys2.result | 5 - .../testGroupByWithConstantKeys3.result | 3 - .../testGroupByWithConstantKeys4.result | 5 - .../testGroupByWithConstantKeys5.result | 5 - .../testGroupByWithExpressionKeys1.result | 5 - .../testGroupByWithExpressionKeys2.result | 5 - .../testGroupByWithNullData1.result | 3 - .../testGroupByWithNullData10.result | 3 - .../testGroupByWithNullData11.result | 2 - .../testGroupByWithNullData12.result | 2 - .../testGroupByWithNullData2.result | 3 - .../testGroupByWithNullData3.result | 3 - .../testGroupByWithNullData4.result | 3 - .../testGroupByWithNullData5.result | 3 - .../testGroupByWithNullData6.result | 3 - .../testGroupByWithNullData7.result | 3 - .../testGroupByWithNullData8.result | 3 - .../testGroupByWithNullData9.result | 2 - .../testGroupByWithSameConstantKeys1.result | 5 - .../testGroupByWithSameExprs1.result | 6 - .../testGroupByWithSameExprs2.result | 6 - .../TestGroupByQuery/testGroupbyWithJson.result | 5 - .../testGroupbyWithLimit1.result | 3 - .../testGroupbyWithLimit2.result | 3 - .../testGroupbyWithLimit3.result | 3 - .../testGroupbyWithPythonFunc.result | 7 - .../testGroupbyWithPythonFunc2.result | 7 - .../testHavingWithAggFunction.result | 4 - .../testHavingWithNamedTarget.result | 5 - .../TestGroupByQuery/testPythonUdaf.result | 3 - .../TestGroupByQuery/testPythonUdaf2.result | 4 - .../TestGroupByQuery/testPythonUdaf3.result | 5 - .../testPythonUdafWithHaving.result | 4 - .../testPythonUdafWithNullData.result | 2 - .../TestHBaseTable/testBinaryMappedQuery.result | 81 - .../results/TestHBaseTable/testCTAS.result | 100 -- .../testColumnKeyValueSelectQuery.result | 12 - .../TestHBaseTable/testIndexPredication.result | 38 - .../TestHBaseTable/testInsertInto.result | 3 - .../testInsertIntoBinaryMultiRegion.result | 100 -- .../testInsertIntoColumnKeyValue.result | 21 - .../testInsertIntoMultiRegion.result | 100 -- .../testInsertIntoMultiRegion2.result | 100 -- ...stInsertIntoMultiRegionMultiRowFields.result | 100 -- ...estInsertIntoMultiRegionWithSplitFile.result | 100 -- .../testInsertIntoRowField.result | 4 - .../testInsertIntoUsingPut.result | 3 - .../TestHBaseTable/testInsertValues1.result | 4 - .../results/TestHBaseTable/testJoin.result | 7 - .../TestHBaseTable/testNonForwardQuery.result | 102 -- .../testRowFieldSelectQuery.result | 88 -- .../TestHBaseTable/testSimpleSelectQuery.result | 88 -- .../testInAndNotInSubQuery.result | 24 - .../TestInSubquery/testInSubQuery.result | 27 - .../TestInSubquery/testInSubQuery2.result | 3 - .../testInSubQueryWithJoin.result | 5 - .../testInSubQueryWithOtherConditions.result | 25 - .../testInSubQueryWithTableSubQuery.result | 4 - .../testMultipleInSubQuery.result | 5 - .../testMultipleNotInSubQuery.result | 20 - .../testNestedInAndNotInSubQuery.result | 3 - .../TestInSubquery/testNestedInSubQuery.result | 3 - .../TestInSubquery/testNestedInSubQuery2.result | 3 - .../testNestedNotInSubQuery.result | 7 - .../TestInSubquery/testNotInSubQuery.result | 22 - ...testSameKeyNameOfOuterAndInnerQueries.result | 3 - .../testWithAsteriskAndJoin.result | 6 - .../TestIndexScan/testOnMultipleExprs.result | 3 - .../TestIndexScan/testOnMultipleKeys.result | 3 - .../TestIndexScan/testOnMultipleKeys2.result | 3 - .../testOnSortedNonUniqueKeys.result | 4 - .../TestIndexScan/testOnUnsortedTextKeys.result | 3 - .../TestIndexScan/testWithGroupBy.result | 3 - .../results/TestIndexScan/testWithJoin.result | 4 - .../results/TestIndexScan/testWithSort.result | 4 - .../testBroadcastTwoPartJoin.Hash.plan | 135 -- ...stBroadcastTwoPartJoin.Hash_NoBroadcast.plan | 249 ---- .../testBroadcastTwoPartJoin.Sort.plan | 135 -- ...stBroadcastTwoPartJoin.Sort_NoBroadcast.plan | 249 ---- .../testBroadcastTwoPartJoin.result | 7 - .../testComplexJoinCondition1.Hash.plan | 78 - ...tComplexJoinCondition1.Hash_NoBroadcast.plan | 105 -- .../testComplexJoinCondition1.Sort.plan | 78 - ...tComplexJoinCondition1.Sort_NoBroadcast.plan | 105 -- .../testComplexJoinCondition1.result | 27 - .../testComplexJoinCondition2.Hash.plan | 78 - ...tComplexJoinCondition2.Hash_NoBroadcast.plan | 105 -- .../testComplexJoinCondition2.Sort.plan | 78 - ...tComplexJoinCondition2.Sort_NoBroadcast.plan | 105 -- .../testComplexJoinCondition2.result | 27 - .../testComplexJoinCondition3.Hash.plan | 78 - ...tComplexJoinCondition3.Hash_NoBroadcast.plan | 105 -- .../testComplexJoinCondition3.Sort.plan | 78 - ...tComplexJoinCondition3.Sort_NoBroadcast.plan | 105 -- .../testComplexJoinCondition3.result | 27 - .../testComplexJoinCondition4.Hash.plan | 78 - ...tComplexJoinCondition4.Hash_NoBroadcast.plan | 105 -- .../testComplexJoinCondition4.Sort.plan | 78 - ...tComplexJoinCondition4.Sort_NoBroadcast.plan | 105 -- .../testComplexJoinCondition4.result | 29 - .../testCrossJoin.1.Hash.plan | 76 - .../testCrossJoin.1.Hash_NoBroadcast.plan | 103 -- .../testCrossJoin.1.Sort.plan | 76 - .../testCrossJoin.1.Sort_NoBroadcast.plan | 103 -- .../TestInnerJoinQuery/testCrossJoin.1.result | 127 -- .../testCrossJoin.2.Hash.plan | 51 - .../testCrossJoin.2.Hash_NoBroadcast.plan | 78 - .../testCrossJoin.2.Sort.plan | 51 - .../testCrossJoin.2.Sort_NoBroadcast.plan | 78 - .../TestInnerJoinQuery/testCrossJoin.2.result | 27 - .../testCrossJoin.3.Hash.plan | 51 - .../testCrossJoin.3.Hash_NoBroadcast.plan | 78 - .../testCrossJoin.3.Sort.plan | 51 - .../testCrossJoin.3.Sort_NoBroadcast.plan | 78 - .../TestInnerJoinQuery/testCrossJoin.3.result | 27 - .../testCrossJoin.4.Hash.plan | 51 - .../testCrossJoin.4.Hash_NoBroadcast.plan | 78 - .../testCrossJoin.4.Sort.plan | 51 - .../testCrossJoin.4.Sort_NoBroadcast.plan | 78 - .../TestInnerJoinQuery/testCrossJoin.4.result | 27 - .../testCrossJoin.5.Hash.plan | 76 - .../testCrossJoin.5.Hash_NoBroadcast.plan | 103 -- .../testCrossJoin.5.Sort.plan | 76 - .../testCrossJoin.5.Sort_NoBroadcast.plan | 103 -- .../TestInnerJoinQuery/testCrossJoin.5.result | 27 - .../testCrossJoinAndCaseWhen.Hash.plan | 78 - ...stCrossJoinAndCaseWhen.Hash_NoBroadcast.plan | 105 -- .../testCrossJoinAndCaseWhen.Sort.plan | 78 - ...stCrossJoinAndCaseWhen.Sort_NoBroadcast.plan | 105 -- .../testCrossJoinAndCaseWhen.result | 27 - .../testCrossJoinWithAsterisk1.Hash.plan | 76 - ...CrossJoinWithAsterisk1.Hash_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk1.Sort.plan | 76 - ...CrossJoinWithAsterisk1.Sort_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk1.result | 27 - .../testCrossJoinWithAsterisk2.Hash.plan | 76 - ...CrossJoinWithAsterisk2.Hash_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk2.Sort.plan | 76 - ...CrossJoinWithAsterisk2.Sort_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk2.result | 27 - .../testCrossJoinWithAsterisk3.Hash.plan | 76 - ...CrossJoinWithAsterisk3.Hash_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk3.Sort.plan | 76 - ...CrossJoinWithAsterisk3.Sort_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk3.result | 27 - .../testCrossJoinWithAsterisk4.Hash.plan | 76 - ...CrossJoinWithAsterisk4.Hash_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk4.Sort.plan | 76 - ...CrossJoinWithAsterisk4.Sort_NoBroadcast.plan | 103 -- .../testCrossJoinWithAsterisk4.result | 27 - .../testCrossJoinWithEmptyTable1.Hash.plan | 78 - ...ossJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 -- .../testCrossJoinWithEmptyTable1.Sort.plan | 78 - ...ossJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 -- .../testCrossJoinWithEmptyTable1.result | 2 - ...sJoinWithThetaJoinConditionInWhere.Hash.plan | 63 - ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 90 -- ...sJoinWithThetaJoinConditionInWhere.Sort.plan | 63 - ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 90 -- ...rossJoinWithThetaJoinConditionInWhere.result | 12 - .../testDifferentTypesJoinCondition.Hash.plan | 53 - ...rentTypesJoinCondition.Hash_NoBroadcast.plan | 80 - .../testDifferentTypesJoinCondition.Sort.plan | 53 - ...rentTypesJoinCondition.Sort_NoBroadcast.plan | 80 - .../testDifferentTypesJoinCondition.result | 7 - .../testInnerJoinAndCaseWhen.Hash.plan | 78 - ...stInnerJoinAndCaseWhen.Hash_NoBroadcast.plan | 105 -- .../testInnerJoinAndCaseWhen.Sort.plan | 78 - ...stInnerJoinAndCaseWhen.Sort_NoBroadcast.plan | 105 -- .../testInnerJoinAndCaseWhen.result | 27 - .../testInnerJoinWithEmptyTable.Hash.plan | 78 - ...nnerJoinWithEmptyTable.Hash_NoBroadcast.plan | 105 -- .../testInnerJoinWithEmptyTable.Sort.plan | 78 - ...nnerJoinWithEmptyTable.Sort_NoBroadcast.plan | 105 -- .../testInnerJoinWithEmptyTable.result | 2 - ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 - ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 -- ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 - ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 -- ...nnerJoinWithThetaJoinConditionInWhere.result | 7 - .../testJoinAsterisk.Hash.plan | 53 - .../testJoinAsterisk.Hash_NoBroadcast.plan | 80 - .../testJoinAsterisk.Sort.plan | 53 - .../testJoinAsterisk.Sort_NoBroadcast.plan | 80 - .../TestInnerJoinQuery/testJoinAsterisk.result | 7 - .../testJoinCoReferredEvals1.Hash.plan | 78 - ...stJoinCoReferredEvals1.Hash_NoBroadcast.plan | 105 -- .../testJoinCoReferredEvals1.Sort.plan | 78 - ...stJoinCoReferredEvals1.Sort_NoBroadcast.plan | 105 -- .../testJoinCoReferredEvals1.result | 27 - ...tJoinCoReferredEvalsWithSameExprs1.Hash.plan | 88 -- ...redEvalsWithSameExprs1.Hash_NoBroadcast.plan | 115 -- ...tJoinCoReferredEvalsWithSameExprs1.Sort.plan | 88 -- ...redEvalsWithSameExprs1.Sort_NoBroadcast.plan | 115 -- ...testJoinCoReferredEvalsWithSameExprs1.result | 22 - ...tJoinCoReferredEvalsWithSameExprs2.Hash.plan | 119 -- ...redEvalsWithSameExprs2.Hash_NoBroadcast.plan | 146 -- ...tJoinCoReferredEvalsWithSameExprs2.Sort.plan | 119 -- ...redEvalsWithSameExprs2.Sort_NoBroadcast.plan | 146 -- ...testJoinCoReferredEvalsWithSameExprs2.result | 22 - .../testJoinOnMultipleDatabases.Hash.plan | 135 -- ...oinOnMultipleDatabases.Hash_NoBroadcast.plan | 249 ---- .../testJoinOnMultipleDatabases.Sort.plan | 135 -- ...oinOnMultipleDatabases.Sort_NoBroadcast.plan | 249 ---- .../testJoinOnMultipleDatabases.result | 5 - .../testJoinOnMultipleDatabasesWithJson.result | 5 - .../TestInnerJoinQuery/testJoinWithJson.result | 27 - .../testJoinWithMultipleJoinQual1.Hash.plan | 135 -- ...nWithMultipleJoinQual1.Hash_NoBroadcast.plan | 249 ---- .../testJoinWithMultipleJoinQual1.Sort.plan | 135 -- ...nWithMultipleJoinQual1.Sort_NoBroadcast.plan | 249 ---- .../testJoinWithMultipleJoinQual1.result | 2 - .../testJoinWithOrPredicates.Hash.plan | 90 -- ...stJoinWithOrPredicates.Hash_NoBroadcast.plan | 117 -- .../testJoinWithOrPredicates.Sort.plan | 90 -- ...stJoinWithOrPredicates.Sort_NoBroadcast.plan | 117 -- .../testJoinWithOrPredicates.result | 4 - .../testNaturalJoin.Hash.plan | 78 - .../testNaturalJoin.Hash_NoBroadcast.plan | 105 -- .../testNaturalJoin.Sort.plan | 78 - .../testNaturalJoin.Sort_NoBroadcast.plan | 105 -- .../TestInnerJoinQuery/testNaturalJoin.result | 27 - .../TestInnerJoinQuery/testTPCHQ2Join.Hash.plan | 135 -- .../testTPCHQ2Join.Hash_NoBroadcast.plan | 249 ---- .../TestInnerJoinQuery/testTPCHQ2Join.Sort.plan | 135 -- .../testTPCHQ2Join.Sort_NoBroadcast.plan | 249 ---- .../TestInnerJoinQuery/testTPCHQ2Join.result | 5 - .../testWhereClauseJoin1.Hash.plan | 78 - .../testWhereClauseJoin1.Hash_NoBroadcast.plan | 105 -- .../testWhereClauseJoin1.Sort.plan | 78 - .../testWhereClauseJoin1.Sort_NoBroadcast.plan | 105 -- .../testWhereClauseJoin1.result | 27 - .../testWhereClauseJoin2.Hash.plan | 78 - .../testWhereClauseJoin2.Hash_NoBroadcast.plan | 105 -- .../testWhereClauseJoin2.Sort.plan | 78 - .../testWhereClauseJoin2.Sort_NoBroadcast.plan | 105 -- .../testWhereClauseJoin2.result | 27 - .../testWhereClauseJoin3.Hash.plan | 78 - .../testWhereClauseJoin3.Hash_NoBroadcast.plan | 105 -- .../testWhereClauseJoin3.Sort.plan | 78 - .../testWhereClauseJoin3.Sort_NoBroadcast.plan | 105 -- .../testWhereClauseJoin3.result | 27 - .../testWhereClauseJoin4.Hash.plan | 78 - .../testWhereClauseJoin4.Hash_NoBroadcast.plan | 105 -- .../testWhereClauseJoin4.Sort.plan | 78 - .../testWhereClauseJoin4.Sort_NoBroadcast.plan | 105 -- .../testWhereClauseJoin4.result | 27 - .../testWhereClauseJoin5.Hash.plan | 97 -- .../testWhereClauseJoin5.Hash_NoBroadcast.plan | 153 -- .../testWhereClauseJoin5.Sort.plan | 97 -- .../testWhereClauseJoin5.Sort_NoBroadcast.plan | 153 -- .../testWhereClauseJoin5.result | 5 - .../testWhereClauseJoin6.Hash.plan | 116 -- .../testWhereClauseJoin6.Hash_NoBroadcast.plan | 201 --- .../testWhereClauseJoin6.Sort.plan | 116 -- .../testWhereClauseJoin6.Sort_NoBroadcast.plan | 201 --- .../testWhereClauseJoin6.result | 5 - .../testBroadcastSubquery.Hash.plan | 109 -- .../testBroadcastSubquery.Hash_NoBroadcast.plan | 165 -- .../testBroadcastSubquery.Sort.plan | 109 -- .../testBroadcastSubquery.Sort_NoBroadcast.plan | 165 -- .../testBroadcastSubquery.result | 7 - .../testBroadcastSubquery2.Hash.plan | 216 --- ...testBroadcastSubquery2.Hash_NoBroadcast.plan | 328 ---- .../testBroadcastSubquery2.Sort.plan | 216 --- ...testBroadcastSubquery2.Sort_NoBroadcast.plan | 328 ---- .../testBroadcastSubquery2.result | 3 - .../testComplexJoinCondition5.Hash.plan | 90 -- ...tComplexJoinCondition5.Hash_NoBroadcast.plan | 117 -- .../testComplexJoinCondition5.Sort.plan | 90 -- ...tComplexJoinCondition5.Sort_NoBroadcast.plan | 117 -- .../testComplexJoinCondition5.result | 29 - .../testComplexJoinCondition6.Hash.plan | 109 -- ...tComplexJoinCondition6.Hash_NoBroadcast.plan | 145 -- .../testComplexJoinCondition6.Sort.plan | 109 -- ...tComplexJoinCondition6.Sort_NoBroadcast.plan | 145 -- .../testComplexJoinCondition6.result | 56 - .../testComplexJoinCondition7.Hash.plan | 109 -- ...tComplexJoinCondition7.Hash_NoBroadcast.plan | 145 -- .../testComplexJoinCondition7.Sort.plan | 109 -- ...tComplexJoinCondition7.Sort_NoBroadcast.plan | 145 -- .../testComplexJoinCondition7.result | 56 - .../testJoinWithJson2.result | 5 - .../testJoinWithMultipleJoinQual2.Hash.plan | 86 -- ...nWithMultipleJoinQual2.Hash_NoBroadcast.plan | 142 -- .../testJoinWithMultipleJoinQual2.Sort.plan | 86 -- ...nWithMultipleJoinQual2.Sort_NoBroadcast.plan | 142 -- .../testJoinWithMultipleJoinQual2.result | 3 - .../testJoinWithMultipleJoinQual3.Hash.plan | 105 -- ...nWithMultipleJoinQual3.Hash_NoBroadcast.plan | 190 --- .../testJoinWithMultipleJoinQual3.Sort.plan | 105 -- ...nWithMultipleJoinQual3.Sort_NoBroadcast.plan | 190 --- .../testJoinWithMultipleJoinQual3.result | 5 - .../testJoinWithMultipleJoinQual4.Hash.plan | 109 -- ...nWithMultipleJoinQual4.Hash_NoBroadcast.plan | 194 --- .../testJoinWithMultipleJoinQual4.Sort.plan | 109 -- ...nWithMultipleJoinQual4.Sort_NoBroadcast.plan | 194 --- .../testJoinWithMultipleJoinQual4.result | 4 - .../testThetaJoinKeyPairs.Hash.plan | 146 -- .../testThetaJoinKeyPairs.Hash_NoBroadcast.plan | 200 --- .../testThetaJoinKeyPairs.Sort.plan | 146 -- .../testThetaJoinKeyPairs.Sort_NoBroadcast.plan | 200 --- .../testThetaJoinKeyPairs.result | 21 - ...estInsertOverwriteWithAsteriskAndMore.result | 7 - ...sertOverwriteWithAsteriskUsingParquet.result | 4 - ...ertOverwriteWithAsteriskUsingParquet2.result | 4 - .../testInsertWithDifferentColumnOrder.result | 27 - .../selfJoinOfPartitionedTable.result | 7 - .../testBroadcastPartitionTable.result | 5 - ...FilterPushDownPartitionColumnCaseWhen.result | 4 - ...tionedBroadcastDataFileWithZeroLength.result | 7 - ...ionedBroadcastDataFileWithZeroLength2.result | 7 - .../testNoProjectionJoinQual.result | 3 - .../testPartialFilterPushDown.result | 3 - .../testPartialFilterPushDownOuterJoin.result | 27 - .../testPartialFilterPushDownOuterJoin2.result | 27 - ...estPartitionMultiplePartitionFilter.1.result | 2 - .../testPartitionTableJoinSmallTable.result | 7 - .../TestJoinQuery/testWhereClauseJoin6.result | 5 - .../testComplexJoinsWithCaseWhen.Hash.plan | 97 -- ...mplexJoinsWithCaseWhen.Hash_NoBroadcast.plan | 153 -- .../testComplexJoinsWithCaseWhen.Sort.plan | 97 -- ...mplexJoinsWithCaseWhen.Sort_NoBroadcast.plan | 153 -- .../testComplexJoinsWithCaseWhen.result | 27 - .../testComplexJoinsWithCaseWhen2.Hash.plan | 109 -- ...plexJoinsWithCaseWhen2.Hash_NoBroadcast.plan | 165 -- .../testComplexJoinsWithCaseWhen2.Sort.plan | 109 -- ...plexJoinsWithCaseWhen2.Sort_NoBroadcast.plan | 165 -- .../testComplexJoinsWithCaseWhen2.result | 27 - .../testInnerAndOuterWithEmpty.1.Hash.plan | 74 - ...nerAndOuterWithEmpty.1.Hash_NoBroadcast.plan | 130 -- .../testInnerAndOuterWithEmpty.1.Sort.plan | 74 - ...nerAndOuterWithEmpty.1.Sort_NoBroadcast.plan | 130 -- .../testInnerAndOuterWithEmpty.1.result | 7 - .../testJoinWithMultipleJoinTypes.Hash.plan | 84 -- ...nWithMultipleJoinTypes.Hash_NoBroadcast.plan | 140 -- .../testJoinWithMultipleJoinTypes.Sort.plan | 84 -- ...nWithMultipleJoinTypes.Sort_NoBroadcast.plan | 140 -- .../testJoinWithMultipleJoinTypes.result | 6 - .../results/TestNetTypes/testGroupby.result | 7 - .../results/TestNetTypes/testGroupby2.result | 5 - .../results/TestNetTypes/testJoin.result | 6 - .../results/TestNetTypes/testSelect.result | 7 - .../results/TestNetTypes/testSort.result | 7 - .../results/TestNetTypes/testSort2.result | 7 - .../testGetClusterDetails.result | 4 - .../testGetNextRowsForAggregateFunction.result | 3 - .../testGetNextRowsForTable.result | 5 - .../testFullOuterJoin1.Hash.plan | 105 -- .../testFullOuterJoin1.Hash_NoBroadcast.plan | 105 -- .../testFullOuterJoin1.Sort.plan | 105 -- .../testFullOuterJoin1.Sort_NoBroadcast.plan | 105 -- .../testFullOuterJoin1.result | 7 - ...lOuterJoinPredicationCaseByCase1.1.Hash.plan | 153 -- ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 153 -- ...lOuterJoinPredicationCaseByCase1.1.Sort.plan | 153 -- ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 153 -- ...FullOuterJoinPredicationCaseByCase1.1.result | 9 - .../testFullOuterJoinWithEmptyTable1.Hash.plan | 105 -- ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 -- .../testFullOuterJoinWithEmptyTable1.Sort.plan | 105 -- ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 -- .../testFullOuterJoinWithEmptyTable1.result | 7 - ...testJoinFilterOfRowPreservedTable1.Hash.plan | 78 - ...erOfRowPreservedTable1.Hash_NoBroadcast.plan | 105 -- ...testJoinFilterOfRowPreservedTable1.Sort.plan | 78 - ...erOfRowPreservedTable1.Sort_NoBroadcast.plan | 105 -- .../testJoinFilterOfRowPreservedTable1.result | 15 - .../testLeftOuterJoin1.Hash.plan | 78 - .../testLeftOuterJoin1.Hash_NoBroadcast.plan | 105 -- .../testLeftOuterJoin1.Sort.plan | 78 - .../testLeftOuterJoin1.Sort_NoBroadcast.plan | 105 -- .../testLeftOuterJoin1.result | 7 - .../testLeftOuterJoin2.Hash.plan | 91 -- .../testLeftOuterJoin2.Hash_NoBroadcast.plan | 176 --- .../testLeftOuterJoin2.Sort.plan | 91 -- .../testLeftOuterJoin2.Sort_NoBroadcast.plan | 176 --- .../testLeftOuterJoin2.result | 7 - .../testLeftOuterJoin3.Hash.plan | 160 -- .../testLeftOuterJoin3.Hash_NoBroadcast.plan | 272 ---- .../testLeftOuterJoin3.Sort.plan | 160 -- .../testLeftOuterJoin3.Sort_NoBroadcast.plan | 272 ---- .../testLeftOuterJoin3.result | 9 - ...tLeftOuterJoinLeftSideSmallTable.1.Hash.plan | 105 -- ...inLeftSideSmallTable.1.Hash_NoBroadcast.plan | 105 -- ...tLeftOuterJoinLeftSideSmallTable.1.Sort.plan | 105 -- ...inLeftSideSmallTable.1.Sort_NoBroadcast.plan | 105 -- ...testLeftOuterJoinLeftSideSmallTable.1.result | 7 - ...tOuterJoinPredicationCaseByCase1.1.Hash.plan | 72 - ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 128 -- ...tOuterJoinPredicationCaseByCase1.1.Sort.plan | 72 - ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 128 -- ...LeftOuterJoinPredicationCaseByCase1.1.result | 7 - ...tOuterJoinPredicationCaseByCase2.1.Hash.plan | 122 -- ...edicationCaseByCase2.1.Hash_NoBroadcast.plan | 176 --- ...tOuterJoinPredicationCaseByCase2.1.Sort.plan | 122 -- ...edicationCaseByCase2.1.Sort_NoBroadcast.plan | 176 --- ...LeftOuterJoinPredicationCaseByCase2.1.result | 4 - ...uterJoinPredicationCaseByCase2_1.1.Hash.plan | 97 -- ...icationCaseByCase2_1.1.Hash_NoBroadcast.plan | 182 --- ...uterJoinPredicationCaseByCase2_1.1.Sort.plan | 97 -- ...icationCaseByCase2_1.1.Sort_NoBroadcast.plan | 182 --- ...ftOuterJoinPredicationCaseByCase2_1.1.result | 5 - ...tOuterJoinPredicationCaseByCase3.1.Hash.plan | 72 - ...edicationCaseByCase3.1.Hash_NoBroadcast.plan | 128 -- ...tOuterJoinPredicationCaseByCase3.1.Sort.plan | 72 - ...edicationCaseByCase3.1.Sort_NoBroadcast.plan | 128 -- ...LeftOuterJoinPredicationCaseByCase3.1.result | 7 - ...tOuterJoinPredicationCaseByCase4.1.Hash.plan | 74 - ...edicationCaseByCase4.1.Hash_NoBroadcast.plan | 130 -- ...tOuterJoinPredicationCaseByCase4.1.Sort.plan | 74 - ...edicationCaseByCase4.1.Sort_NoBroadcast.plan | 130 -- ...LeftOuterJoinPredicationCaseByCase4.1.result | 7 - ...tOuterJoinPredicationCaseByCase5.1.Hash.plan | 74 - ...edicationCaseByCase5.1.Hash_NoBroadcast.plan | 130 -- ...tOuterJoinPredicationCaseByCase5.1.Sort.plan | 74 - ...edicationCaseByCase5.1.Sort_NoBroadcast.plan | 130 -- ...LeftOuterJoinPredicationCaseByCase5.1.result | 6 - ...tOuterJoinPredicationCaseByCase6.1.Hash.plan | 76 - ...edicationCaseByCase6.1.Hash_NoBroadcast.plan | 132 -- ...tOuterJoinPredicationCaseByCase6.1.Sort.plan | 76 - ...edicationCaseByCase6.1.Sort_NoBroadcast.plan | 132 -- ...LeftOuterJoinPredicationCaseByCase6.1.result | 3 - ...testLeftOuterJoinWithConstantExpr1.Hash.plan | 86 -- ...rJoinWithConstantExpr1.Hash_NoBroadcast.plan | 113 -- ...testLeftOuterJoinWithConstantExpr1.Sort.plan | 86 -- ...rJoinWithConstantExpr1.Sort_NoBroadcast.plan | 113 -- .../testLeftOuterJoinWithConstantExpr1.result | 7 - ...testLeftOuterJoinWithConstantExpr4.Hash.plan | 63 - ...rJoinWithConstantExpr4.Hash_NoBroadcast.plan | 90 -- ...testLeftOuterJoinWithConstantExpr4.Sort.plan | 63 - ...rJoinWithConstantExpr4.Sort_NoBroadcast.plan | 90 -- .../testLeftOuterJoinWithConstantExpr4.result | 7 - ...testLeftOuterJoinWithConstantExpr5.Hash.plan | 65 - ...rJoinWithConstantExpr5.Hash_NoBroadcast.plan | 92 -- ...testLeftOuterJoinWithConstantExpr5.Sort.plan | 65 - ...rJoinWithConstantExpr5.Sort_NoBroadcast.plan | 92 -- .../testLeftOuterJoinWithConstantExpr5.result | 6 - .../testLeftOuterJoinWithEmptyTable1.Hash.plan | 78 - ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 -- .../testLeftOuterJoinWithEmptyTable1.Sort.plan | 78 - ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 -- .../testLeftOuterJoinWithEmptyTable1.result | 7 - .../testLeftOuterJoinWithEmptyTable2.Hash.plan | 109 -- ...terJoinWithEmptyTable2.Hash_NoBroadcast.plan | 136 -- .../testLeftOuterJoinWithEmptyTable2.Sort.plan | 109 -- ...terJoinWithEmptyTable2.Sort_NoBroadcast.plan | 136 -- .../testLeftOuterJoinWithEmptyTable2.result | 7 - .../testLeftOuterJoinWithEmptyTable3.Hash.plan | 160 -- ...terJoinWithEmptyTable3.Hash_NoBroadcast.plan | 187 --- .../testLeftOuterJoinWithEmptyTable3.Sort.plan | 160 -- ...terJoinWithEmptyTable3.Sort_NoBroadcast.plan | 187 --- .../testLeftOuterJoinWithEmptyTable3.result | 7 - .../testLeftOuterJoinWithEmptyTable4.Hash.plan | 160 -- ...terJoinWithEmptyTable4.Hash_NoBroadcast.plan | 214 --- .../testLeftOuterJoinWithEmptyTable4.Sort.plan | 160 -- ...terJoinWithEmptyTable4.Sort_NoBroadcast.plan | 214 --- .../testLeftOuterJoinWithEmptyTable4.result | 4 - .../testLeftOuterJoinWithEmptyTable5.Hash.plan | 109 -- ...terJoinWithEmptyTable5.Hash_NoBroadcast.plan | 136 -- .../testLeftOuterJoinWithEmptyTable5.Sort.plan | 109 -- ...terJoinWithEmptyTable5.Sort_NoBroadcast.plan | 136 -- .../testLeftOuterJoinWithEmptyTable5.result | 4 - .../testLeftOuterJoinWithNull1.Hash.plan | 82 - ...LeftOuterJoinWithNull1.Hash_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull1.Sort.plan | 82 - ...LeftOuterJoinWithNull1.Sort_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull1.result | 4 - .../testLeftOuterJoinWithNull2.Hash.plan | 82 - ...LeftOuterJoinWithNull2.Hash_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull2.Sort.plan | 82 - ...LeftOuterJoinWithNull2.Sort_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull2.result | 4 - .../testLeftOuterJoinWithNull3.Hash.plan | 82 - ...LeftOuterJoinWithNull3.Hash_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull3.Sort.plan | 82 - ...LeftOuterJoinWithNull3.Sort_NoBroadcast.plan | 109 -- .../testLeftOuterJoinWithNull3.result | 2 - ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 - ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 -- ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 - ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 -- ...uterJoinWithThetaJoinConditionInWhere.result | 4 - .../testLeftOuterWithEmptyTable.1.Hash.plan | 53 - ...tOuterWithEmptyTable.1.Hash_NoBroadcast.plan | 80 - .../testLeftOuterWithEmptyTable.1.Sort.plan | 53 - ...tOuterWithEmptyTable.1.Sort_NoBroadcast.plan | 80 - .../testLeftOuterWithEmptyTable.1.result | 7 - ...pleBroadcastDataFileWithZeroLength.Hash.plan | 57 - ...DataFileWithZeroLength.Hash_NoBroadcast.plan | 84 -- ...pleBroadcastDataFileWithZeroLength.Sort.plan | 57 - ...DataFileWithZeroLength.Sort_NoBroadcast.plan | 84 -- ...ltipleBroadcastDataFileWithZeroLength.result | 2 - ...leBroadcastDataFileWithZeroLength2.Hash.plan | 76 - ...ataFileWithZeroLength2.Hash_NoBroadcast.plan | 132 -- ...leBroadcastDataFileWithZeroLength2.Sort.plan | 76 - ...ataFileWithZeroLength2.Sort_NoBroadcast.plan | 132 -- ...tipleBroadcastDataFileWithZeroLength2.result | 7 - .../testOuterJoinAndCaseWhen1.Hash.plan | 126 -- ...tOuterJoinAndCaseWhen1.Hash_NoBroadcast.plan | 153 -- .../testOuterJoinAndCaseWhen1.Sort.plan | 126 -- ...tOuterJoinAndCaseWhen1.Sort_NoBroadcast.plan | 153 -- .../testOuterJoinAndCaseWhen1.result | 7 - .../testRightOuterJoin1.Hash.plan | 78 - .../testRightOuterJoin1.Hash_NoBroadcast.plan | 105 -- .../testRightOuterJoin1.Sort.plan | 78 - .../testRightOuterJoin1.Sort_NoBroadcast.plan | 105 -- .../testRightOuterJoin1.result | 7 - ...tOuterJoinPredicationCaseByCase1.1.Hash.plan | 101 -- ...edicationCaseByCase1.1.Hash_NoBroadcast.plan | 128 -- ...tOuterJoinPredicationCaseByCase1.1.Sort.plan | 101 -- ...edicationCaseByCase1.1.Sort_NoBroadcast.plan | 128 -- ...ightOuterJoinPredicationCaseByCase1.1.result | 4 - ...tOuterJoinPredicationCaseByCase2.1.Hash.plan | 76 - ...edicationCaseByCase2.1.Hash_NoBroadcast.plan | 132 -- ...tOuterJoinPredicationCaseByCase2.1.Sort.plan | 76 - ...edicationCaseByCase2.1.Sort_NoBroadcast.plan | 132 -- ...ightOuterJoinPredicationCaseByCase2.1.result | 4 - ...tOuterJoinPredicationCaseByCase3.1.Hash.plan | 101 -- ...edicationCaseByCase3.1.Hash_NoBroadcast.plan | 128 -- ...tOuterJoinPredicationCaseByCase3.1.Sort.plan | 101 -- ...edicationCaseByCase3.1.Sort_NoBroadcast.plan | 128 -- ...ightOuterJoinPredicationCaseByCase3.1.result | 4 - .../testRightOuterJoinWithEmptyTable1.Hash.plan | 78 - ...terJoinWithEmptyTable1.Hash_NoBroadcast.plan | 105 -- .../testRightOuterJoinWithEmptyTable1.Sort.plan | 78 - ...terJoinWithEmptyTable1.Sort_NoBroadcast.plan | 105 -- .../testRightOuterJoinWithEmptyTable1.result | 7 - ...rJoinWithThetaJoinConditionInWhere.Hash.plan | 57 - ...taJoinConditionInWhere.Hash_NoBroadcast.plan | 84 -- ...rJoinWithThetaJoinConditionInWhere.Sort.plan | 57 - ...taJoinConditionInWhere.Sort_NoBroadcast.plan | 84 -- ...uterJoinWithThetaJoinConditionInWhere.result | 4 - ...terJoinWithEmptyIntermediateData.1.Hash.plan | 108 -- ...mptyIntermediateData.1.Hash_NoBroadcast.plan | 108 -- ...terJoinWithEmptyIntermediateData.1.Sort.plan | 108 -- ...mptyIntermediateData.1.Sort_NoBroadcast.plan | 108 -- ...lOuterJoinWithEmptyIntermediateData.1.result | 2 - .../testJoinWithDifferentShuffleKey.1.Hash.plan | 199 --- ...hDifferentShuffleKey.1.Hash_NoBroadcast.plan | 199 --- .../testJoinWithDifferentShuffleKey.1.Sort.plan | 199 --- ...hDifferentShuffleKey.1.Sort_NoBroadcast.plan | 199 --- .../testJoinWithDifferentShuffleKey.1.result | 3 - ...testLeftOuterJoinWithConstantExpr2.Hash.plan | 98 -- ...rJoinWithConstantExpr2.Hash_NoBroadcast.plan | 125 -- ...testLeftOuterJoinWithConstantExpr2.Sort.plan | 98 -- ...rJoinWithConstantExpr2.Sort_NoBroadcast.plan | 125 -- .../testLeftOuterJoinWithConstantExpr2.result | 7 - ...testLeftOuterJoinWithConstantExpr3.Hash.plan | 156 -- ...rJoinWithConstantExpr3.Hash_NoBroadcast.plan | 156 -- ...testLeftOuterJoinWithConstantExpr3.Sort.plan | 156 -- ...rJoinWithConstantExpr3.Sort_NoBroadcast.plan | 156 -- .../testLeftOuterJoinWithConstantExpr3.result | 7 - ...tLeftOuterJoinWithEmptySubquery1.1.Hash.plan | 111 -- ...inWithEmptySubquery1.1.Hash_NoBroadcast.plan | 167 --- ...tLeftOuterJoinWithEmptySubquery1.1.Sort.plan | 111 -- ...inWithEmptySubquery1.1.Sort_NoBroadcast.plan | 167 --- ...testLeftOuterJoinWithEmptySubquery1.1.result | 7 - ...tLeftOuterJoinWithEmptySubquery2.1.Hash.plan | 86 -- ...inWithEmptySubquery2.1.Hash_NoBroadcast.plan | 142 -- ...tLeftOuterJoinWithEmptySubquery2.1.Sort.plan | 86 -- ...inWithEmptySubquery2.1.Sort_NoBroadcast.plan | 142 -- ...testLeftOuterJoinWithEmptySubquery2.1.result | 2 - .../TestQueryUnitStatusUpdate/case3.result | 4 - .../create_table_nested_1.result | 40 - .../create_table_nested_2.result | 57 - .../results/TestSQLAnalyzer/setcatalog1.result | 5 - .../results/TestSQLAnalyzer/setcatalog2.result | 5 - .../results/TestSQLAnalyzer/setsession1.result | 5 - .../results/TestSQLAnalyzer/setsession2.result | 5 - .../results/TestSQLAnalyzer/setsession3.result | 5 - .../results/TestSQLAnalyzer/setsession4.result | 5 - .../results/TestSQLAnalyzer/setsession5.result | 5 - .../results/TestSQLAnalyzer/setsession6.result | 5 - .../results/TestSQLAnalyzer/setsession7.result | 5 - .../results/TestSQLAnalyzer/settimezone1.result | 5 - .../results/TestSQLAnalyzer/settimezone2.result | 5 - .../results/TestSQLAnalyzer/settimezone3.result | 4 - .../results/TestSQLAnalyzer/window1.result | 37 - .../results/TestSQLAnalyzer/window2.result | 44 - .../results/TestSQLAnalyzer/window3.result | 50 - .../results/TestSQLAnalyzer/window4.result | 48 - .../results/TestSQLAnalyzer/window5.result | 77 - .../results/TestSQLAnalyzer/window6.result | 83 -- .../results/TestSQLAnalyzer/window7.result | 81 - .../results/TestSQLAnalyzer/window8.result | 86 -- .../results/TestSQLAnalyzer/window9.result | 56 - .../testInsertType1.result | 5 - .../testInsertType2.result | 5 - .../testNestedFieldAsGroupbyKey1.result | 6 - .../testNestedFieldAsJoinKey1.result | 6 - .../TestSelectNestedRecord/testSelect0.result | 5 - .../TestSelectNestedRecord/testSelect1.result | 5 - .../TestSelectNestedRecord/testSelect2.result | 6 - .../TestSelectNestedRecord/testSelect3.result | 3 - .../results/TestSelectQuery/testCaseWhen.result | 7 - .../TestSelectQuery/testCaseWhenRound.result | 22 - .../testCaseWhenWithoutElse.result | 7 - ...estColumnEqualityButNotJoinCondition1.result | 3 - ...estColumnEqualityButNotJoinCondition2.result | 6 - .../TestSelectQuery/testDatabaseRef.result | 7 - .../TestSelectQuery/testExplainSelect.result | 6 - .../testExplainSelectPhysical.1.result | 26 - .../testExplainSelectPhysical.2.result | 88 -- .../testExplainSelectPhysical.3.result | 89 -- .../results/TestSelectQuery/testInClause.result | 5 - .../TestSelectQuery/testInStrClause.result | 4 - .../TestSelectQuery/testLikeClause.result | 9 - .../results/TestSelectQuery/testLimit.result | 5 - .../testMultiBytesDelimiter1.result | 7 - .../testMultiBytesDelimiter2.result | 7 - .../testMultiBytesDelimiter3.result | 7 - .../testMultiBytesDelimiter4.result | 7 - .../testNestedPythonFunction.result | 7 - .../TestSelectQuery/testNonFromSelect1.result | 3 - .../testNonQualifiedNames.result | 7 - .../results/TestSelectQuery/testNotEqual.result | 5 - .../TestSelectQuery/testNotInClause.result | 4 - .../TestSelectQuery/testNotInStrClause.result | 4 - .../TestSelectQuery/testRealValueCompare.result | 3 - .../results/TestSelectQuery/testSelect.result | 7 - .../results/TestSelectQuery/testSelect2.result | 7 - .../results/TestSelectQuery/testSelect3.result | 7 - .../TestSelectQuery/testSelectAsterisk1.result | 7 - .../TestSelectQuery/testSelectAsterisk2.result | 3 - .../TestSelectQuery/testSelectAsterisk3.result | 3 - .../TestSelectQuery/testSelectAsterisk4.result | 7 - .../TestSelectQuery/testSelectAsterisk5.result | 3 - .../testSelectColumnAlias1.result | 7 - ...tSelectColumnAliasExistingInRelation1.result | 4 - ...tSelectColumnAliasExistingInRelation2.result | 7 - ...tSelectColumnAliasExistingInRelation3.result | 11 - .../TestSelectQuery/testSelectDistinct.result | 7 - .../testSelectOnSessionTable.result | 3 - .../testSelectPythonFuncs.result | 7 - ...lectSameConstantsWithDifferentAliases.result | 7 - ...ectSameConstantsWithDifferentAliases2.result | 7 - ...ectSameConstantsWithDifferentAliases3.result | 7 - ...stSelectSameExprsWithDifferentAliases.result | 7 - .../testSelectWithCommonQuals1.1.plan | 7 - .../testSelectWithCommonQuals1.1.result | 27 - .../testSelectWithCommonQuals2.1.plan | 7 - .../testSelectWithCommonQuals2.1.result | 27 - .../testSelectWithCommonQuals3.1.plan | 7 - .../testSelectWithCommonQuals3.1.result | 7 - .../TestSelectQuery/testSelectWithJson.result | 7 - .../testSelectWithParentheses1.result | 3 - .../testSelectWithParentheses2.result | 3 - .../testSelectWithPredicateOnPythonFunc.result | 17 - .../TestSelectQuery/testSimpleQuery.result | 7 - .../testSimpleQueryWithLimit.result | 5 - ...tSimpleQueryWithLimitPartitionedTable.result | 12 - .../TestSelectQuery/testStringCompare.result | 5 - .../TestSelectQuery/testSumFloatOverflow.result | 3 - .../TestSelectQuery/testSumIntOverflow.result | 3 - .../TestSelectQuery/testTimezonedTable1.result | 5 - .../TestSelectQuery/testTimezonedTable2.result | 5 - .../TestSelectQuery/testTimezonedTable3.result | 5 - .../results/TestSelectQuery/testUnion1.result | 10 - .../results/TestSelectQuery/testUnion2.result | 12 - .../TestSelectQuery/testWhereCond1.result | 3 - .../TestSelectQuery/testWhereCond2.result | 3 - .../testWhereCondWithAlias1.result | 4 - .../testWhereCondWithAlias2.result | 4 - .../results/TestSortQuery/testAsterisk.result | 7 - .../results/TestSortQuery/testSort.result | 7 - .../TestSortQuery/testSortAfterGroupby.result | 5 - .../testSortAfterGroupbyWithAlias.result | 5 - .../results/TestSortQuery/testSortDesc.result | 7 - .../TestSortQuery/testSortFirstDesc.result | 10 - .../TestSortQuery/testSortOnNullColumn.result | 6 - .../testSortOnUnicodeTextAsc.result | 6 - .../testSortOnUnicodeTextDesc.result | 6 - .../TestSortQuery/testSortWithAlias1.result | 7 - .../TestSortQuery/testSortWithAlias2.result | 5 - .../TestSortQuery/testSortWithAlias3.result | 7 - .../testSortWithAliasButOriginalName.result | 7 - .../testSortWithAscDescKeys.result | 26 - .../TestSortQuery/testSortWithConstKeys.result | 7 - .../TestSortQuery/testSortWithDate.result | 7 - .../TestSortQuery/testSortWithExpr1.result | 7 - .../TestSortQuery/testSortWithExpr2.result | 7 - .../TestSortQuery/testSortWithJson.result | 5 - .../testSubQuerySortAfterGroupMultiBlocks.plan | 112 -- ...testSubQuerySortAfterGroupMultiBlocks.result | 5 - .../results/TestSortQuery/testTopK.result | 5 - .../TestSortQuery/testTopkWithJson.result | 5 - .../results/TestTPCH/testFirstJoinInQ7.plan | 156 -- .../results/TestTPCH/testFirstJoinInQ7.result | 4 - .../results/TestTPCH/testQ1OrderBy.plan | 88 -- .../results/TestTPCH/testQ1OrderBy.result | 4 - .../results/TestTPCH/testQ2FourJoins.plan | 228 --- .../results/TestTPCH/testQ2FourJoins.result | 3 - .../results/TestTPCH/testTPCH14Expr.plan | 119 -- .../results/TestTPCH/testTPCH14Expr.result | 3 - .../resources/results/TestTPCH/testTPCHQ5.plan | 332 ----- .../results/TestTPCH/testTPCHQ5.result | 2 - .../TestSpecialCharPartitionKeys1.result | 4 - .../TestSpecialCharPartitionKeys2.result | 3 - .../results/TestTablePartitions/case1.result | 4 - .../results/TestTablePartitions/case10.result | 7 - .../results/TestTablePartitions/case11.result | 7 - .../results/TestTablePartitions/case12.result | 7 - .../results/TestTablePartitions/case13.result | 7 - .../results/TestTablePartitions/case14.result | 3 - .../results/TestTablePartitions/case15.result | 3 - .../results/TestTablePartitions/case2.result | 6 - .../results/TestTablePartitions/case3.result | 5 - .../results/TestTablePartitions/case4.result | 7 - .../results/TestTablePartitions/case5.result | 7 - .../results/TestTablePartitions/case6.result | 7 - .../results/TestTablePartitions/case7.result | 5 - .../results/TestTablePartitions/case8.result | 7 - .../results/TestTablePartitions/case9.result | 7 - ...rtitionedTableWithSmallerExpressions5.result | 7 - ...rtitionedTableWithSmallerExpressions6.result | 4 - .../testGroupBySubQuery.result | 3 - .../testGroupbySubqueryWithJson.result | 3 - .../TestTableSubQuery/testJoinSubQuery.result | 4 - .../TestTableSubQuery/testJoinSubQuery2.result | 4 - .../testJoinSubqueryWithJson.result | 4 - .../TestTableSubQuery/testTableSubquery1.result | 7 - .../testAlterTableAddDropPartition.result | 9 - .../results/TestTajoCli/testDescTable.result | 27 - .../testDescTableForNestedSchema.result | 29 - .../TestTajoCli/testHelpSessionVars.result | 44 - .../testLocalQueryWithoutFrom.result | 8 - .../TestTajoCli/testNonForwardQueryPause.result | 6 - .../testSelectResultWithNullFalse.result | 8 - .../testSelectResultWithNullTrue.result | 8 - ...estSelectResultWithNullTrueDeprecated.result | 9 - .../results/TestTajoCli/testSetTimezone1.result | 4 - .../TestTajoCli/testStopWhenError.result | 5 - .../testStopWhenErrorDeprecated.result | 6 - .../testQueryFailure.result | 0 .../TestTajoCliNegatives/testQuerySyntax.result | 3 - .../testExecuteQueryAsync.result | 7 - .../testExecuteQueryAsyncWithListener.result | 2 - .../testExecuteQueryType1.result | 7 - .../testExecuteQueryType2.result | 4 - .../testExecuteQueryType3.result | 4 - .../TestTajoDatabaseMetaData/getSchemas1.result | 3 - .../TestTajoDatabaseMetaData/getSchemas2.result | 3 - .../getTableTypes.result | 3 - .../TestTajoDatabaseMetaData/getTables1.result | 4 - .../TestTajoDatabaseMetaData/getTables2.result | 4 - .../results/TestTajoDump/testDump1.result | 16 - .../results/TestTajoDump/testDump2.result | 16 - .../results/TestTajoDump/testDump3.result | 20 - .../TestTajoJdbc/testSortWithDateTime.result | 7 - .../TestUnionQuery/testComplexUnion1.plan | 80 - .../TestUnionQuery/testComplexUnion1.result | 6 - .../TestUnionQuery/testComplexUnion2.plan | 116 -- .../TestUnionQuery/testComplexUnion2.result | 7 - .../results/TestUnionQuery/testUnion1.result | 7 - .../results/TestUnionQuery/testUnion10.result | 7 - .../results/TestUnionQuery/testUnion11.result | 3 - .../results/TestUnionQuery/testUnion12.result | 7 - .../results/TestUnionQuery/testUnion13.result | 7 - .../results/TestUnionQuery/testUnion14.result | 9 - .../results/TestUnionQuery/testUnion15.result | 5 - .../results/TestUnionQuery/testUnion16.result | 5 - .../results/TestUnionQuery/testUnion2.result | 5 - .../results/TestUnionQuery/testUnion3.result | 4 - .../results/TestUnionQuery/testUnion4.result | 3 - .../results/TestUnionQuery/testUnion5.result | 3 - .../results/TestUnionQuery/testUnion6.result | 3 - .../results/TestUnionQuery/testUnion7.result | 5 - .../results/TestUnionQuery/testUnion8.result | 3 - .../results/TestUnionQuery/testUnion9.result | 7 - .../results/TestUnionQuery/testUnionAll1.result | 10 - .../TestUnionQuery/testUnionAll10.result | 22 - .../TestUnionQuery/testUnionAll11.result | 3 - .../TestUnionQuery/testUnionAll12.result | 7 - .../TestUnionQuery/testUnionAll13.result | 7 - .../TestUnionQuery/testUnionAll14.result | 9 - .../TestUnionQuery/testUnionAll15.result | 5 - .../TestUnionQuery/testUnionAll16.result | 5 - .../results/TestUnionQuery/testUnionAll2.result | 12 - .../results/TestUnionQuery/testUnionAll3.result | 4 - .../results/TestUnionQuery/testUnionAll4.result | 3 - .../results/TestUnionQuery/testUnionAll5.result | 3 - .../results/TestUnionQuery/testUnionAll6.result | 3 - .../results/TestUnionQuery/testUnionAll7.result | 12 - .../results/TestUnionQuery/testUnionAll8.result | 3 - .../results/TestUnionQuery/testUnionAll9.result | 7 - .../testUnionAllWithDifferentAlias.result | 4 - ...UnionAllWithDifferentAliasAndFunction.result | 7 - .../testUnionAllWithSameAliasNames.result | 12 - .../testUnionWithDifferentAlias.result | 4 - ...estUnionWithDifferentAliasAndFunction.result | 7 - .../testUnionWithSameAliasNames.result | 5 - .../TestWindowQuery/testComplexOrderBy1.result | 7 - .../TestWindowQuery/testFirstValue1.result | 7 - .../results/TestWindowQuery/testLag1.result | 7 - .../TestWindowQuery/testLagWithDefault.result | 7 - .../TestWindowQuery/testLagWithNoArgs.result | 7 - .../TestWindowQuery/testLastValue1.result | 7 - .../results/TestWindowQuery/testLead1.result | 7 - .../TestWindowQuery/testLeadWithDefault.result | 7 - .../TestWindowQuery/testLeadWithNoArgs.result | 7 - .../TestWindowQuery/testRowNumber1.result | 7 - .../TestWindowQuery/testRowNumber2.result | 7 - .../TestWindowQuery/testRowNumber3.result | 7 - .../TestWindowQuery/testStdDevPop1.result | 7 - .../TestWindowQuery/testStdDevSamp1.result | 7 - .../results/TestWindowQuery/testWindow1.result | 7 - .../results/TestWindowQuery/testWindow2.result | 7 - .../results/TestWindowQuery/testWindow3.result | 7 - .../results/TestWindowQuery/testWindow4.result | 7 - .../results/TestWindowQuery/testWindow5.result | 7 - .../results/TestWindowQuery/testWindow6.result | 7 - .../results/TestWindowQuery/testWindow7.result | 7 - .../results/TestWindowQuery/testWindow8.result | 7 - .../testWindowBeforeLimit.result | 5 - .../testWindowWithAggregation1.result | 3 - .../testWindowWithAggregation2.result | 5 - .../testWindowWithAggregation3.result | 3 - .../testWindowWithAggregation4.result | 5 - .../testWindowWithAggregation5.result | 5 - .../testWindowWithAggregation6.result | 5 - .../testWindowWithOrderBy1.result | 7 - .../testWindowWithOrderBy2.result | 7 - .../testWindowWithOrderBy3.result | 7 - .../testWindowWithOrderBy4.result | 7 - .../testWindowWithOrderBy5.result | 7 - .../testWindowWithSubQuery.result | 7 - .../testWindowWithSubQuery2.result | 5 - .../testWindowWithSubQuery3.result | 7 - .../testWindowWithSubQuery4.result | 7 - .../testWindowWithSubQuery5.result | 5 - .../testWindowWithSubQuery6.result | 3 - .../testBuildDDLForBaseTable.result | 4 - .../testBuildDDLForExternalTable.result | 5 - .../testBuildDDLQuotedTableName1.result | 5 - .../testBuildDDLQuotedTableName2.result | 4 - tajo-core/src/test/resources/yarn-site.xml | 25 - tajo-core/src/test/tpch/customer.tbl | 5 - tajo-core/src/test/tpch/empty_orders.tbl | 0 tajo-core/src/test/tpch/lineitem.tbl | 5 - tajo-core/src/test/tpch/nation.tbl | 25 - tajo-core/src/test/tpch/orders.tbl | 3 - tajo-core/src/test/tpch/part.tbl | 4 - tajo-core/src/test/tpch/partsupp.tbl | 3 - tajo-core/src/test/tpch/region.tbl | 5 - tajo-core/src/test/tpch/supplier.tbl | 3 - tajo-project/pom.xml | 19 +- 3480 files changed, 95869 insertions(+), 95392 deletions(-) ----------------------------------------------------------------------