You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@carbondata.apache.org by ch...@apache.org on 2017/08/01 06:00:14 UTC

[07/20] carbondata git commit: [CARBONDATA-1346] SDV cluster tests

http://git-wip-us.apache.org/repos/asf/carbondata/blob/14624953/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesIncludeDictionaryTestCase.scala
----------------------------------------------------------------------
diff --git a/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesIncludeDictionaryTestCase.scala b/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesIncludeDictionaryTestCase.scala
new file mode 100644
index 0000000..fbcc74d
--- /dev/null
+++ b/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesIncludeDictionaryTestCase.scala
@@ -0,0 +1,4686 @@
+
+/*
+ * Licensed to the Apache Software Foundation (ASF) under one or more
+ * contributor license agreements.  See the NOTICE file distributed with
+ * this work for additional information regarding copyright ownership.
+ * The ASF licenses this file to You under the Apache License, Version 2.0
+ * (the "License"); you may not use this file except in compliance with
+ * the License.  You may obtain a copy of the License at
+ *
+ *    http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+
+package org.apache.carbondata.cluster.sdv.generated
+
+import org.apache.spark.sql.common.util._
+import org.scalatest.BeforeAndAfterAll
+
+/**
+ * Test Class for QueriesIncludeDictionaryTestCase to verify all scenerios
+ */
+
+class QueriesIncludeDictionaryTestCase extends QueryTest with BeforeAndAfterAll {
+         
+
+  //VMALL_DICTIONARY_INCLUDE_CreateCube
+  test("VMALL_DICTIONARY_INCLUDE_CreateCube", Include) {
+    sql(s"""drop table if exists VMALL_DICTIONARY_INCLUDE""").collect
+    sql(s"""drop table if exists VMALL_DICTIONARY_INCLUDE_hive""").collect
+
+    sql(s"""create table  VMALL_DICTIONARY_INCLUDE (imei string,deviceInformationId int,MAC string,deviceColor string,device_backColor string,modelId string,marketName string,AMSize string,ROMSize string,CUPAudit string,CPIClocked string,series string,productionDate timestamp,bomCode string,internalModels string, deliveryTime string, channelsId string, channelsName string , deliveryAreaId string, deliveryCountry string, deliveryProvince string, deliveryCity string,deliveryDistrict string, deliveryStreet string, oxSingleNumber string, ActiveCheckTime string, ActiveAreaId string, ActiveCountry string, ActiveProvince string, Activecity string, ActiveDistrict string, ActiveStreet string, ActiveOperatorId string, Active_releaseId string, Active_EMUIVersion string, Active_operaSysVersion string, Active_BacVerNumber string, Active_BacFlashVer string, Active_webUIVersion string, Active_webUITypeCarrVer string,Active_webTypeDataVerNumber string, Active_operatorsVersion string, Active_phonePA
 DPartitionedVersions string, Latest_YEAR int, Latest_MONTH int, Latest_DAY Decimal(30,10), Latest_HOUR string, Latest_areaId string, Latest_country string, Latest_province string, Latest_city string, Latest_district string, Latest_street string, Latest_releaseId string, Latest_EMUIVersion string, Latest_operaSysVersion string, Latest_BacVerNumber string, Latest_BacFlashVer string, Latest_webUIVersion string, Latest_webUITypeCarrVer string, Latest_webTypeDataVerNumber string, Latest_operatorsVersion string, Latest_phonePADPartitionedVersions string, Latest_operatorId string, gamePointDescription string,gamePointId double,contractNumber BigInt)  STORED BY 'org.apache.carbondata.format' TBLPROPERTIES('DICTIONARY_INCLUDE'='imei,deviceInformationId,productionDate,gamePointId,Latest_DAY,contractNumber')
+  """).collect
+
+    sql(s"""create table  VMALL_DICTIONARY_INCLUDE_hive (imei string,deviceInformationId int,MAC string,deviceColor string,device_backColor string,modelId string,marketName string,AMSize string,ROMSize string,CUPAudit string,CPIClocked string,series string,productionDate timestamp,bomCode string,internalModels string,deliveryTime string,channelsId string,channelsName string,deliveryAreaId string,deliveryCountry string,deliveryProvince string,deliveryCity string,deliveryDistrict string,deliveryStreet string,oxSingleNumber string,contractNumber BigInt,ActiveCheckTime string,ActiveAreaId string,ActiveCountry string,ActiveProvince string,Activecity string,ActiveDistrict string,ActiveStreet string,ActiveOperatorId string,Active_releaseId string,Active_EMUIVersion string,Active_operaSysVersion string,Active_BacVerNumber string,Active_BacFlashVer string,Active_webUIVersion string,Active_webUITypeCarrVer string,Active_webTypeDataVerNumber string,Active_operatorsVersion string,Active_phonePA
 DPartitionedVersions string,Latest_YEAR int,Latest_MONTH int,Latest_DAY Decimal(30,10),Latest_HOUR string,Latest_areaId string,Latest_country string,Latest_province string,Latest_city string,Latest_district string,Latest_street string,Latest_releaseId string,Latest_EMUIVersion string,Latest_operaSysVersion string,Latest_BacVerNumber string,Latest_BacFlashVer string,Latest_webUIVersion string,Latest_webUITypeCarrVer string,Latest_webTypeDataVerNumber string,Latest_operatorsVersion string,Latest_phonePADPartitionedVersions string,Latest_operatorId string,gamePointId double,gamePointDescription string) ROW FORMAT DELIMITED FIELDS TERMINATED BY ','""").collect
+
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_CreateCube_count
+  test("VMALL_DICTIONARY_INCLUDE_CreateCube_count", Include) {
+
+    sql(s"""select count(*) from VMALL_DICTIONARY_INCLUDE""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_DataLoad
+  test("VMALL_DICTIONARY_INCLUDE_DataLoad", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table VMALL_DICTIONARY_INCLUDE options ('DELIMITER'=',', 'QUOTECHAR'='"','BAD_RECORDS_ACTION'='FORCE','FILEHEADER'='imei,deviceInformationId,MAC,deviceColor,device_backColor,modelId,marketName,AMSize,ROMSize,CUPAudit,CPIClocked,series,productionDate,bomCode,internalModels,deliveryTime,channelsId,channelsName,deliveryAreaId,deliveryCountry,deliveryProvince,deliveryCity,deliveryDistrict,deliveryStreet,oxSingleNumber,contractNumber,ActiveCheckTime,ActiveAreaId,ActiveCountry,ActiveProvince,Activecity,ActiveDistrict,ActiveStreet,ActiveOperatorId,Active_releaseId,Active_EMUIVersion,Active_operaSysVersion,Active_BacVerNumber,Active_BacFlashVer,Active_webUIVersion,Active_webUITypeCarrVer,Active_webTypeDataVerNumber,Active_operatorsVersion,Active_phonePADPartitionedVersions,Latest_YEAR,Latest_MONTH,Latest_DAY,Latest_HOUR,Latest_areaId,Latest_country,Latest_province,Latest_city,Latest_district,Latest_street,Latest_relea
 seId,Latest_EMUIVersion,Latest_operaSysVersion,Latest_BacVerNumber,Latest_BacFlashVer,Latest_webUIVersion,Latest_webUITypeCarrVer,Latest_webTypeDataVerNumber,Latest_operatorsVersion,Latest_phonePADPartitionedVersions,Latest_operatorId,gamePointId,gamePointDescription')""").collect
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_001
+  test("VMALL_DICTIONARY_INCLUDE_001", Include) {
+
+    checkAnswer(s"""Select count(imei) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(imei) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_001")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_002
+  test("VMALL_DICTIONARY_INCLUDE_002", Include) {
+
+    checkAnswer(s"""select count(DISTINCT imei) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT imei) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_002")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_003
+  test("VMALL_DICTIONARY_INCLUDE_003", Include) {
+
+    checkAnswer(s"""select sum(Latest_month)+10 as a ,imei  from VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select sum(Latest_month)+10 as a ,imei  from VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_003")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_004
+  test("VMALL_DICTIONARY_INCLUDE_004", Include) {
+
+    checkAnswer(s"""select max(imei),min(imei) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(imei),min(imei) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_004")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_005
+  test("VMALL_DICTIONARY_INCLUDE_005", Include) {
+
+    checkAnswer(s"""select min(imei), max(imei) Total from VMALL_DICTIONARY_INCLUDE group by  channelsId order by Total""",
+      s"""select min(imei), max(imei) Total from VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by Total""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_005")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_006
+  test("VMALL_DICTIONARY_INCLUDE_006", Include) {
+
+    checkAnswer(s"""select last(imei) a from VMALL_DICTIONARY_INCLUDE  group by imei order by imei limit 1""",
+      s"""select last(imei) a from VMALL_DICTIONARY_INCLUDE_hive  group by imei order by imei limit 1""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_006")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_007
+  test("VMALL_DICTIONARY_INCLUDE_007", Include) {
+
+    sql(s"""select FIRST(imei) a from VMALL_DICTIONARY_INCLUDE group by imei order by imei limit 1""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_008
+  test("VMALL_DICTIONARY_INCLUDE_008", Include) {
+
+    checkAnswer(s"""select imei,count(imei) a from VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select imei,count(imei) a from VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_008")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_009
+  test("VMALL_DICTIONARY_INCLUDE_009", Include) {
+
+    checkAnswer(s"""select Lower(imei) a  from VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select Lower(imei) a  from VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_009")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_010
+  test("VMALL_DICTIONARY_INCLUDE_010", Include) {
+
+    checkAnswer(s"""select distinct imei from VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select distinct imei from VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_010")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_011
+  test("VMALL_DICTIONARY_INCLUDE_011", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE order by imei limit 101 """,
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive order by imei limit 101 """, "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_011")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_012
+  test("VMALL_DICTIONARY_INCLUDE_012", Include) {
+
+    checkAnswer(s"""select imei as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select imei as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_012")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_013
+  test("VMALL_DICTIONARY_INCLUDE_013", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where  (contractNumber == 9223372047700) and (imei=='1AA100004')""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where  (contractNumber == 9223372047700) and (imei=='1AA100004')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_013")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_014
+  test("VMALL_DICTIONARY_INCLUDE_014", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei !='1AA100064' order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei !='1AA100064' order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_014")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_015
+  test("VMALL_DICTIONARY_INCLUDE_015", Include) {
+
+    checkAnswer(s"""select imei  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select imei  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_015")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_016
+  test("VMALL_DICTIONARY_INCLUDE_016", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei !='1AA100012' order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei !='1AA100012' order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_016")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_017
+  test("VMALL_DICTIONARY_INCLUDE_017", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei >'1AA100012' order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei >'1AA100012' order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_017")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_018
+  test("VMALL_DICTIONARY_INCLUDE_018", Include) {
+
+    checkAnswer(s"""select imei  from VMALL_DICTIONARY_INCLUDE where imei<>imei""",
+      s"""select imei  from VMALL_DICTIONARY_INCLUDE_hive where imei<>imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_018")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_019
+  test("VMALL_DICTIONARY_INCLUDE_019", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei != Latest_areaId order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei != Latest_areaId order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_019")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_020
+  test("VMALL_DICTIONARY_INCLUDE_020", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where Latest_areaId<imei order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<imei order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_020")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_021
+  test("VMALL_DICTIONARY_INCLUDE_021", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where Latest_DAY<=imei order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY<=imei order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_021")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_022
+  test("VMALL_DICTIONARY_INCLUDE_022", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei <'1AA10002' order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei <'1AA10002' order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_022")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_023
+  test("VMALL_DICTIONARY_INCLUDE_023", Include) {
+
+    checkAnswer(s"""select Latest_day  from VMALL_DICTIONARY_INCLUDE where imei IS NULL""",
+      s"""select Latest_day  from VMALL_DICTIONARY_INCLUDE_hive where imei IS NULL""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_023")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_024
+  test("VMALL_DICTIONARY_INCLUDE_024", Include) {
+
+    checkAnswer(s"""select Latest_day  from VMALL_DICTIONARY_INCLUDE where imei IS NOT NULL order by Latest_day""",
+      s"""select Latest_day  from VMALL_DICTIONARY_INCLUDE_hive where imei IS NOT NULL order by Latest_day""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_024")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_025
+  test("VMALL_DICTIONARY_INCLUDE_025", Include) {
+
+    checkAnswer(s"""Select count(imei),min(imei) from VMALL_DICTIONARY_INCLUDE """,
+      s"""Select count(imei),min(imei) from VMALL_DICTIONARY_INCLUDE_hive """, "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_025")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_026
+  test("VMALL_DICTIONARY_INCLUDE_026", Include) {
+
+    checkAnswer(s"""select count(DISTINCT imei,latest_day) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT imei,latest_day) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_026")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_027
+  test("VMALL_DICTIONARY_INCLUDE_027", Include) {
+
+    checkAnswer(s"""select max(imei),min(imei),count(imei) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(imei),min(imei),count(imei) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_027")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_028
+  test("VMALL_DICTIONARY_INCLUDE_028", Include) {
+
+    checkAnswer(s"""select sum(imei),avg(imei),count(imei) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(imei),avg(imei),count(imei) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_028")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_029
+  test("VMALL_DICTIONARY_INCLUDE_029", Include) {
+
+    sql(s"""select last(imei),Min(imei),max(imei)  a from (select imei from VMALL_DICTIONARY_INCLUDE order by imei) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_030
+  test("VMALL_DICTIONARY_INCLUDE_030", Include) {
+
+    sql(s"""select FIRST(imei),Last(imei) a from VMALL_DICTIONARY_INCLUDE group by imei order by imei limit 1""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_031
+  test("VMALL_DICTIONARY_INCLUDE_031", Include) {
+
+    checkAnswer(s"""select imei,count(imei) a from VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select imei,count(imei) a from VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_031")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_032
+  test("VMALL_DICTIONARY_INCLUDE_032", Include) {
+
+    checkAnswer(s"""select Lower(imei),upper(imei)  a  from VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select Lower(imei),upper(imei)  a  from VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_032")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_033
+  test("VMALL_DICTIONARY_INCLUDE_033", Include) {
+
+    checkAnswer(s"""select imei as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select imei as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_033")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_034
+  test("VMALL_DICTIONARY_INCLUDE_034", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where  (contractNumber == 9223372047700) and (imei=='1AA100012')""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where  (contractNumber == 9223372047700) and (imei=='1AA100012')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_034")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_035
+  test("VMALL_DICTIONARY_INCLUDE_035", Include) {
+
+    checkAnswer(s"""select imei from VMALL_DICTIONARY_INCLUDE where imei !='8imei' order by imei""",
+      s"""select imei from VMALL_DICTIONARY_INCLUDE_hive where imei !='8imei' order by imei""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_035")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_036
+  test("VMALL_DICTIONARY_INCLUDE_036", Include) {
+
+    checkAnswer(s"""select imei  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select imei  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_036")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_037
+  test("VMALL_DICTIONARY_INCLUDE_037", Include) {
+
+    checkAnswer(s"""Select count(contractNumber) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(contractNumber) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_037")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_038
+  test("VMALL_DICTIONARY_INCLUDE_038", Include) {
+
+    checkAnswer(s"""select count(DISTINCT contractNumber) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT contractNumber) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_038")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_039
+  test("VMALL_DICTIONARY_INCLUDE_039", Include) {
+
+    checkAnswer(s"""select sum(contractNumber)+10 as a ,contractNumber  from VMALL_DICTIONARY_INCLUDE group by contractNumber""",
+      s"""select sum(contractNumber)+10 as a ,contractNumber  from VMALL_DICTIONARY_INCLUDE_hive group by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_039")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_040
+  test("VMALL_DICTIONARY_INCLUDE_040", Include) {
+
+    checkAnswer(s"""select max(contractNumber),min(contractNumber) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(contractNumber),min(contractNumber) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_040")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_041
+  test("VMALL_DICTIONARY_INCLUDE_041", Include) {
+
+    checkAnswer(s"""select sum(contractNumber) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(contractNumber) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_041")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_042
+  test("VMALL_DICTIONARY_INCLUDE_042", Include) {
+
+    checkAnswer(s"""select avg(contractNumber) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(contractNumber) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_042")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_043
+  test("VMALL_DICTIONARY_INCLUDE_043", Include) {
+
+    checkAnswer(s"""select min(contractNumber) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(contractNumber) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_043")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_044
+  test("VMALL_DICTIONARY_INCLUDE_044", Include) {
+
+    sql(s"""select variance(contractNumber) as a   from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_045
+  ignore("VMALL_DICTIONARY_INCLUDE_045", Include) {
+
+    checkAnswer(s"""select var_pop(contractNumber) as a from (select * from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""",
+      s"""select var_pop(contractNumber) as a from (select * from VMALL_DICTIONARY_INCLUDE_hive order by contractNumber) t""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_045")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_046
+  test("VMALL_DICTIONARY_INCLUDE_046", Include) {
+
+    checkAnswer(s"""select var_samp(contractNumber) as a from  (select * from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""",
+      s"""select var_samp(contractNumber) as a from  (select * from VMALL_DICTIONARY_INCLUDE_hive order by contractNumber) t""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_046")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_047
+  test("VMALL_DICTIONARY_INCLUDE_047", Include) {
+
+    sql(s"""select stddev_pop(contractNumber) as a  from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_048
+  test("VMALL_DICTIONARY_INCLUDE_048", Include) {
+
+    sql(s"""select stddev_samp(contractNumber)  as a from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_049
+  test("VMALL_DICTIONARY_INCLUDE_049", Include) {
+
+    sql(s"""select covar_pop(contractNumber,contractNumber) as a  from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_050
+  test("VMALL_DICTIONARY_INCLUDE_050", Include) {
+
+    sql(s"""select covar_samp(contractNumber,contractNumber) as a  from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_051
+  test("VMALL_DICTIONARY_INCLUDE_051", Include) {
+
+    checkAnswer(s"""select corr(contractNumber,contractNumber)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select corr(contractNumber,contractNumber)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_051")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_052
+  test("VMALL_DICTIONARY_INCLUDE_052", Include) {
+
+    sql(s"""select percentile_approx(contractNumber,0.2) as a  from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_053
+  test("VMALL_DICTIONARY_INCLUDE_053", Include) {
+
+    sql(s"""select percentile_approx(contractNumber,0.2,5) as a  from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_054
+  test("VMALL_DICTIONARY_INCLUDE_054", Include) {
+
+    sql(s"""select percentile_approx(contractNumber,array(0.2,0.3,0.99))  as a from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_055
+  test("VMALL_DICTIONARY_INCLUDE_055", Include) {
+
+    sql(s"""select percentile_approx(contractNumber,array(0.2,0.3,0.99),5) as a from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_056
+  test("VMALL_DICTIONARY_INCLUDE_056", Include) {
+
+    sql(s"""select histogram_numeric(contractNumber,2)  as a from (select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_057
+  test("VMALL_DICTIONARY_INCLUDE_057", Include) {
+
+    checkAnswer(s"""select contractNumber+ 10 as a  from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select contractNumber+ 10 as a  from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_057")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_058
+  test("VMALL_DICTIONARY_INCLUDE_058", Include) {
+
+    checkAnswer(s"""select min(contractNumber), max(contractNumber+ 10) Total from VMALL_DICTIONARY_INCLUDE group by  channelsId order by Total""",
+      s"""select min(contractNumber), max(contractNumber+ 10) Total from VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by Total""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_058")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_059
+  test("VMALL_DICTIONARY_INCLUDE_059", Include) {
+
+    sql(s"""select last(contractNumber) a from VMALL_DICTIONARY_INCLUDE  order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_060
+  test("VMALL_DICTIONARY_INCLUDE_060", Include) {
+
+    checkAnswer(s"""select FIRST(contractNumber) a from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select FIRST(contractNumber) a from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_060")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_061
+  test("VMALL_DICTIONARY_INCLUDE_061", Include) {
+
+    checkAnswer(s"""select contractNumber,count(contractNumber) a from VMALL_DICTIONARY_INCLUDE group by contractNumber order by contractNumber""",
+      s"""select contractNumber,count(contractNumber) a from VMALL_DICTIONARY_INCLUDE_hive group by contractNumber order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_061")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_062
+  test("VMALL_DICTIONARY_INCLUDE_062", Include) {
+
+    checkAnswer(s"""select Lower(contractNumber) a  from VMALL_DICTIONARY_INCLUDE order by contractNumber""",
+      s"""select Lower(contractNumber) a  from VMALL_DICTIONARY_INCLUDE_hive order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_062")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_063
+  test("VMALL_DICTIONARY_INCLUDE_063", Include) {
+
+    checkAnswer(s"""select distinct contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber""",
+      s"""select distinct contractNumber from VMALL_DICTIONARY_INCLUDE_hive order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_063")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_064
+  test("VMALL_DICTIONARY_INCLUDE_064", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE order by contractNumber limit 101""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive order by contractNumber limit 101""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_064")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_065
+  test("VMALL_DICTIONARY_INCLUDE_065", Include) {
+
+    checkAnswer(s"""select contractNumber as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select contractNumber as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_065")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_066
+  test("VMALL_DICTIONARY_INCLUDE_066", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where  (contractNumber == 9223372047700) and (imei=='1AA100012')""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where  (contractNumber == 9223372047700) and (imei=='1AA100012')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_066")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_067
+  test("VMALL_DICTIONARY_INCLUDE_067", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber !=9223372047700 order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber !=9223372047700 order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_067")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_068
+  test("VMALL_DICTIONARY_INCLUDE_068", Include) {
+
+    checkAnswer(s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color') order by contractNumber""",
+      s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color') order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_068")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_069
+  test("VMALL_DICTIONARY_INCLUDE_069", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber !=9223372047700 order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber !=9223372047700 order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_069")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_070
+  test("VMALL_DICTIONARY_INCLUDE_070", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber >9223372047700 order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber >9223372047700 order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_070")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_071
+  test("VMALL_DICTIONARY_INCLUDE_071", Include) {
+
+    checkAnswer(s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE where contractNumber<>contractNumber""",
+      s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE_hive where contractNumber<>contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_071")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_072
+  test("VMALL_DICTIONARY_INCLUDE_072", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber != Latest_areaId order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber != Latest_areaId order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_072")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_073
+  test("VMALL_DICTIONARY_INCLUDE_073", Include) {
+
+    checkAnswer(s"""select contractNumber, contractNumber from VMALL_DICTIONARY_INCLUDE where Latest_areaId<contractNumber order by contractNumber""",
+      s"""select contractNumber, contractNumber from VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<contractNumber order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_073")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_074
+  test("VMALL_DICTIONARY_INCLUDE_074", Include) {
+
+    checkAnswer(s"""select contractNumber, contractNumber from VMALL_DICTIONARY_INCLUDE where Latest_DAY<=contractNumber order by contractNumber""",
+      s"""select contractNumber, contractNumber from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY<=contractNumber order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_074")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_075
+  test("VMALL_DICTIONARY_INCLUDE_075", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber <1000 order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber <1000 order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_075")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_076
+  test("VMALL_DICTIONARY_INCLUDE_076", Include) {
+
+    checkAnswer(s"""select contractNumber from VMALL_DICTIONARY_INCLUDE where contractNumber >1000 order by contractNumber""",
+      s"""select contractNumber from VMALL_DICTIONARY_INCLUDE_hive where contractNumber >1000 order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_076")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_077
+  test("VMALL_DICTIONARY_INCLUDE_077", Include) {
+
+    checkAnswer(s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE where contractNumber IS NULL order by contractNumber""",
+      s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE_hive where contractNumber IS NULL order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_077")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_078
+  test("VMALL_DICTIONARY_INCLUDE_078", Include) {
+
+    checkAnswer(s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE where Latest_DAY IS NOT NULL order by contractNumber""",
+      s"""select contractNumber  from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY IS NOT NULL order by contractNumber""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_078")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_079
+  test("VMALL_DICTIONARY_INCLUDE_079", Include) {
+
+    checkAnswer(s"""Select count(Latest_DAY) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(Latest_DAY) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_079")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_080
+  test("VMALL_DICTIONARY_INCLUDE_080", Include) {
+
+    checkAnswer(s"""select count(DISTINCT Latest_DAY) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT Latest_DAY) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_080")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_081
+  test("VMALL_DICTIONARY_INCLUDE_081", Include) {
+
+    checkAnswer(s"""select sum(Latest_DAY)+10 as a ,Latest_DAY  from VMALL_DICTIONARY_INCLUDE group by Latest_DAY order by a""",
+      s"""select sum(Latest_DAY)+10 as a ,Latest_DAY  from VMALL_DICTIONARY_INCLUDE_hive group by Latest_DAY order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_081")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_082
+  test("VMALL_DICTIONARY_INCLUDE_082", Include) {
+
+    checkAnswer(s"""select max(Latest_DAY),min(Latest_DAY) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(Latest_DAY),min(Latest_DAY) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_082")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_083
+  test("VMALL_DICTIONARY_INCLUDE_083", Include) {
+
+    checkAnswer(s"""select sum(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_083")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_084
+  test("VMALL_DICTIONARY_INCLUDE_084", Include) {
+
+    checkAnswer(s"""select avg(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_084")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_085
+  test("VMALL_DICTIONARY_INCLUDE_085", Include) {
+
+    checkAnswer(s"""select min(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_085")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_086
+  test("VMALL_DICTIONARY_INCLUDE_086", Include) {
+
+    sql(s"""select variance(Latest_DAY) as a   from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_087
+  test("VMALL_DICTIONARY_INCLUDE_087", Include) {
+
+    sql(s"""select var_pop(Latest_DAY)  as a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_088
+  test("VMALL_DICTIONARY_INCLUDE_088", Include) {
+
+    sql(s"""select var_samp(Latest_DAY) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_089
+  test("VMALL_DICTIONARY_INCLUDE_089", Include) {
+
+    sql(s"""select stddev_pop(Latest_DAY) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_090
+  test("VMALL_DICTIONARY_INCLUDE_090", Include) {
+
+    sql(s"""select stddev_samp(Latest_DAY)  as a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_091
+  test("VMALL_DICTIONARY_INCLUDE_091", Include) {
+
+    sql(s"""select covar_pop(Latest_DAY,Latest_DAY) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_092
+  test("VMALL_DICTIONARY_INCLUDE_092", Include) {
+
+    sql(s"""select covar_samp(Latest_DAY,Latest_DAY) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_093
+  test("VMALL_DICTIONARY_INCLUDE_093", Include) {
+
+    checkAnswer(s"""select corr(Latest_DAY,Latest_DAY)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select corr(Latest_DAY,Latest_DAY)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_093")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_094
+  test("VMALL_DICTIONARY_INCLUDE_094", Include) {
+
+    sql(s"""select percentile_approx(Latest_DAY,0.2) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_095
+  test("VMALL_DICTIONARY_INCLUDE_095", Include) {
+
+    sql(s"""select percentile_approx(Latest_DAY,0.2,5) as a  from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_096
+  test("VMALL_DICTIONARY_INCLUDE_096", Include) {
+
+    sql(s"""select percentile_approx(Latest_DAY,array(0.2,0.3,0.99))  as a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_097
+  test("VMALL_DICTIONARY_INCLUDE_097", Include) {
+
+    sql(s"""select percentile_approx(Latest_DAY,array(0.2,0.3,0.99),5) as a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_098
+  test("VMALL_DICTIONARY_INCLUDE_098", Include) {
+
+    sql(s"""select histogram_numeric(Latest_DAY,2)  as a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_099
+  test("VMALL_DICTIONARY_INCLUDE_099", Include) {
+
+    checkAnswer(s"""select Latest_DAY, Latest_DAY+ 10 as a  from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select Latest_DAY, Latest_DAY+ 10 as a  from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_099")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_100
+  test("VMALL_DICTIONARY_INCLUDE_100", Include) {
+
+    checkAnswer(s"""select min(Latest_DAY) a, max(Latest_DAY+ 10) Total from VMALL_DICTIONARY_INCLUDE group by  channelsId order by a,Total""",
+      s"""select min(Latest_DAY) a, max(Latest_DAY+ 10) Total from VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by a,Total""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_100")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_101
+  test("VMALL_DICTIONARY_INCLUDE_101", Include) {
+
+    sql(s"""select last(Latest_DAY) a from VMALL_DICTIONARY_INCLUDE order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_102
+  test("VMALL_DICTIONARY_INCLUDE_102", Include) {
+
+    sql(s"""select FIRST(Latest_DAY) a from (select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_103
+  test("VMALL_DICTIONARY_INCLUDE_103", Include) {
+
+    checkAnswer(s"""select Latest_DAY,count(Latest_DAY) a from VMALL_DICTIONARY_INCLUDE group by Latest_DAY order by Latest_DAY""",
+      s"""select Latest_DAY,count(Latest_DAY) a from VMALL_DICTIONARY_INCLUDE_hive group by Latest_DAY order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_103")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_104
+  test("VMALL_DICTIONARY_INCLUDE_104", Include) {
+
+    checkAnswer(s"""select Lower(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select Lower(Latest_DAY) a  from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_104")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_105
+  test("VMALL_DICTIONARY_INCLUDE_105", Include) {
+
+    checkAnswer(s"""select distinct Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY""",
+      s"""select distinct Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_105")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_106
+  test("VMALL_DICTIONARY_INCLUDE_106", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE order by Latest_DAY limit 101""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive order by Latest_DAY limit 101""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_106")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_107
+  test("VMALL_DICTIONARY_INCLUDE_107", Include) {
+
+    checkAnswer(s"""select Latest_DAY as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select Latest_DAY as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_107")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_108
+  test("VMALL_DICTIONARY_INCLUDE_108", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where  (Latest_DAY == 1234567890123450.0000000000)  and (imei=='1AA1')""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where  (Latest_DAY == 1234567890123450.0000000000)  and (imei=='1AA1')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_108")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_109
+  test("VMALL_DICTIONARY_INCLUDE_109", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY !=1234567890123450.0000000000  order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY !=1234567890123450.0000000000  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_109")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_110
+  test("VMALL_DICTIONARY_INCLUDE_110", Include) {
+
+    checkAnswer(s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_110")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_111
+  test("VMALL_DICTIONARY_INCLUDE_111", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY !=1234567890123450.0000000000  order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY !=1234567890123450.0000000000  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_111")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_112
+  test("VMALL_DICTIONARY_INCLUDE_112", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY >1234567890123450.0000000000  order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY >1234567890123450.0000000000  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_112")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_113
+  test("VMALL_DICTIONARY_INCLUDE_113", Include) {
+
+    checkAnswer(s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE where Latest_DAY<>Latest_DAY""",
+      s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY<>Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_113")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_114
+  test("VMALL_DICTIONARY_INCLUDE_114", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY != Latest_areaId order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY != Latest_areaId order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_114")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_115
+  test("VMALL_DICTIONARY_INCLUDE_115", Include) {
+
+    checkAnswer(s"""select Latest_DAY, Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_areaId<Latest_DAY order by Latest_DAY""",
+      s"""select Latest_DAY, Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<Latest_DAY order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_115")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_116
+  test("VMALL_DICTIONARY_INCLUDE_116", Include) {
+
+    checkAnswer(s"""select Latest_DAY, Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY<=Latest_DAY  order by Latest_DAY""",
+      s"""select Latest_DAY, Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY<=Latest_DAY  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_116")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_117
+  test("VMALL_DICTIONARY_INCLUDE_117", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY <1000  order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY <1000  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_117")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_118
+  test("VMALL_DICTIONARY_INCLUDE_118", Include) {
+
+    checkAnswer(s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE where Latest_DAY >1000  order by Latest_DAY""",
+      s"""select Latest_DAY from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY >1000  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_118")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_119
+  test("VMALL_DICTIONARY_INCLUDE_119", Include) {
+
+    checkAnswer(s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE where Latest_DAY IS NULL  order by Latest_DAY""",
+      s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY IS NULL  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_119")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_120
+  test("VMALL_DICTIONARY_INCLUDE_120", Include) {
+
+    checkAnswer(s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE where Latest_DAY IS NOT NULL  order by Latest_DAY""",
+      s"""select Latest_DAY  from VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY IS NOT NULL  order by Latest_DAY""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_120")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_121
+  test("VMALL_DICTIONARY_INCLUDE_121", Include) {
+
+    checkAnswer(s"""Select count(gamePointId) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(gamePointId) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_121")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_122
+  test("VMALL_DICTIONARY_INCLUDE_122", Include) {
+
+    checkAnswer(s"""select count(DISTINCT gamePointId) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT gamePointId) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_122")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_123
+  test("VMALL_DICTIONARY_INCLUDE_123", Include) {
+
+    checkAnswer(s"""select sum(gamePointId)+10 as a ,gamePointId  from VMALL_DICTIONARY_INCLUDE group by gamePointId order by a""",
+      s"""select sum(gamePointId)+10 as a ,gamePointId  from VMALL_DICTIONARY_INCLUDE_hive group by gamePointId order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_123")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_124
+  test("VMALL_DICTIONARY_INCLUDE_124", Include) {
+
+    checkAnswer(s"""select max(gamePointId),min(gamePointId) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(gamePointId),min(gamePointId) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_124")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_125
+  test("VMALL_DICTIONARY_INCLUDE_125", Include) {
+
+    checkAnswer(s"""select sum(gamePointId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(gamePointId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_125")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_126
+  test("VMALL_DICTIONARY_INCLUDE_126", Include) {
+
+    checkAnswer(s"""select avg(gamePointId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(gamePointId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_126")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_127
+  test("VMALL_DICTIONARY_INCLUDE_127", Include) {
+
+    checkAnswer(s"""select min(gamePointId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(gamePointId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_127")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_128
+  test("VMALL_DICTIONARY_INCLUDE_128", Include) {
+
+    sql(s"""select variance(gamePointId) as a   from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_129
+  test("VMALL_DICTIONARY_INCLUDE_129", Include) {
+
+    sql(s"""select var_pop(gamePointId)  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_130
+  test("VMALL_DICTIONARY_INCLUDE_130", Include) {
+
+    sql(s"""select var_samp(gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_131
+  test("VMALL_DICTIONARY_INCLUDE_131", Include) {
+
+    sql(s"""select stddev_pop(gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_132
+  test("VMALL_DICTIONARY_INCLUDE_132", Include) {
+
+    sql(s"""select stddev_samp(gamePointId)  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_133
+  test("VMALL_DICTIONARY_INCLUDE_133", Include) {
+
+    sql(s"""select covar_pop(gamePointId,gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_134
+  test("VMALL_DICTIONARY_INCLUDE_134", Include) {
+
+    sql(s"""select covar_samp(gamePointId,gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_135
+  test("VMALL_DICTIONARY_INCLUDE_135", Include) {
+
+    checkAnswer(s"""select corr(gamePointId,gamePointId)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select corr(gamePointId,gamePointId)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_135")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_136
+  test("VMALL_DICTIONARY_INCLUDE_136", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,0.2) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_137
+  test("VMALL_DICTIONARY_INCLUDE_137", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,0.2,5) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_138
+  test("VMALL_DICTIONARY_INCLUDE_138", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,array(0.2,0.3,0.99))  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_139
+  test("VMALL_DICTIONARY_INCLUDE_139", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,array(0.2,0.3,0.99),5) as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_140
+  test("VMALL_DICTIONARY_INCLUDE_140", Include) {
+
+    sql(s"""select histogram_numeric(gamePointId,2)  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_141
+  test("VMALL_DICTIONARY_INCLUDE_141", Include) {
+
+    checkAnswer(s"""select gamePointId, gamePointId+ 10 as a  from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select gamePointId, gamePointId+ 10 as a  from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_141")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_142
+  test("VMALL_DICTIONARY_INCLUDE_142", Include) {
+
+    checkAnswer(s"""select min(gamePointId), max(gamePointId+ 10) Total from VMALL_DICTIONARY_INCLUDE group by  channelsId order by Total""",
+      s"""select min(gamePointId), max(gamePointId+ 10) Total from VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by Total""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_142")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_143
+  test("VMALL_DICTIONARY_INCLUDE_143", Include) {
+
+    sql(s"""select last(gamePointId) a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_144
+  test("VMALL_DICTIONARY_INCLUDE_144", Include) {
+
+    sql(s"""select FIRST(gamePointId) a from VMALL_DICTIONARY_INCLUDE order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_145
+  test("VMALL_DICTIONARY_INCLUDE_145", Include) {
+
+    checkAnswer(s"""select gamePointId,count(gamePointId) a from VMALL_DICTIONARY_INCLUDE group by gamePointId order by gamePointId""",
+      s"""select gamePointId,count(gamePointId) a from VMALL_DICTIONARY_INCLUDE_hive group by gamePointId order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_145")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_146
+  test("VMALL_DICTIONARY_INCLUDE_146", Include) {
+
+    checkAnswer(s"""select Lower(gamePointId) a  from VMALL_DICTIONARY_INCLUDE order by gamePointId""",
+      s"""select Lower(gamePointId) a  from VMALL_DICTIONARY_INCLUDE_hive order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_146")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_147
+  test("VMALL_DICTIONARY_INCLUDE_147", Include) {
+
+    checkAnswer(s"""select distinct gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId""",
+      s"""select distinct gamePointId from VMALL_DICTIONARY_INCLUDE_hive order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_147")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_148
+  test("VMALL_DICTIONARY_INCLUDE_148", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE  order by gamePointId limit 101""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive  order by gamePointId limit 101""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_148")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_149
+  test("VMALL_DICTIONARY_INCLUDE_149", Include) {
+
+    checkAnswer(s"""select gamePointId as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select gamePointId as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_149")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_150
+  test("VMALL_DICTIONARY_INCLUDE_150", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where  (gamePointId == 4.70133553923674E43) and (imei=='1AA100084')""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where  (gamePointId == 4.70133553923674E43) and (imei=='1AA100084')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_150")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_151
+  test("VMALL_DICTIONARY_INCLUDE_151", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId !=4.70133553923674E43  order by gamePointId""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId !=4.70133553923674E43  order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_151")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_152
+  test("VMALL_DICTIONARY_INCLUDE_152", Include) {
+
+    checkAnswer(s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_152")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_153
+  test("VMALL_DICTIONARY_INCLUDE_153", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId !=4.70133553923674E43""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId !=4.70133553923674E43""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_153")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_154
+  test("VMALL_DICTIONARY_INCLUDE_154", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId >4.70133553923674E43""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId >4.70133553923674E43""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_154")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_155
+  test("VMALL_DICTIONARY_INCLUDE_155", Include) {
+
+    checkAnswer(s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE where gamePointId<>gamePointId""",
+      s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE_hive where gamePointId<>gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_155")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_156
+  test("VMALL_DICTIONARY_INCLUDE_156", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId != Latest_areaId  order by gamePointId""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId != Latest_areaId  order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_156")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_157
+  test("VMALL_DICTIONARY_INCLUDE_157", Include) {
+
+    checkAnswer(s"""select gamePointId, gamePointId from VMALL_DICTIONARY_INCLUDE where Latest_areaId<gamePointId  order by gamePointId""",
+      s"""select gamePointId, gamePointId from VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<gamePointId  order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_157")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_158
+  test("VMALL_DICTIONARY_INCLUDE_158", Include) {
+
+    checkAnswer(s"""select gamePointId, gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId<=gamePointId  order by gamePointId""",
+      s"""select gamePointId, gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId<=gamePointId  order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_158")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_159
+  test("VMALL_DICTIONARY_INCLUDE_159", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId <1000 order by gamePointId""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId <1000 order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_159")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_160
+  test("VMALL_DICTIONARY_INCLUDE_160", Include) {
+
+    checkAnswer(s"""select gamePointId from VMALL_DICTIONARY_INCLUDE where gamePointId >1000 order by gamePointId""",
+      s"""select gamePointId from VMALL_DICTIONARY_INCLUDE_hive where gamePointId >1000 order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_160")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_161
+  test("VMALL_DICTIONARY_INCLUDE_161", Include) {
+
+    checkAnswer(s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE where gamePointId IS NULL order by gamePointId""",
+      s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE_hive where gamePointId IS NULL order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_161")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_162
+  test("VMALL_DICTIONARY_INCLUDE_162", Include) {
+
+    checkAnswer(s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE where gamePointId IS NOT NULL order by gamePointId""",
+      s"""select gamePointId  from VMALL_DICTIONARY_INCLUDE_hive where gamePointId IS NOT NULL order by gamePointId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_162")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_163
+  test("VMALL_DICTIONARY_INCLUDE_163", Include) {
+
+    checkAnswer(s"""Select count(productionDate) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(productionDate) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_163")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_164
+  test("VMALL_DICTIONARY_INCLUDE_164", Include) {
+
+    checkAnswer(s"""select count(DISTINCT productionDate) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT productionDate) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_164")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_165
+  test("VMALL_DICTIONARY_INCLUDE_165", Include) {
+
+    checkAnswer(s"""select sum(productionDate)+10 as a ,productionDate  from VMALL_DICTIONARY_INCLUDE group by productionDate order by productionDate""",
+      s"""select sum(productionDate)+10 as a ,productionDate  from VMALL_DICTIONARY_INCLUDE_hive group by productionDate order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_165")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_166
+  test("VMALL_DICTIONARY_INCLUDE_166", Include) {
+
+    checkAnswer(s"""select max(productionDate),min(productionDate) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(productionDate),min(productionDate) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_166")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_167
+  test("VMALL_DICTIONARY_INCLUDE_167", Include) {
+
+    checkAnswer(s"""select sum(productionDate) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(productionDate) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_167")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_168
+  test("VMALL_DICTIONARY_INCLUDE_168", Include) {
+
+    checkAnswer(s"""select avg(productionDate) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(productionDate) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_168")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_169
+  test("VMALL_DICTIONARY_INCLUDE_169", Include) {
+
+    checkAnswer(s"""select min(productionDate) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(productionDate) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_169")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_170
+  test("VMALL_DICTIONARY_INCLUDE_170", Include) {
+
+    sql(s"""select variance(gamePointId) as a   from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_171
+  ignore("VMALL_DICTIONARY_INCLUDE_171", Include) {
+
+    checkAnswer(s"""select var_pop(gamePointId) as a from (select * from VMALL_DICTIONARY_INCLUDE order by gamePointId)""",
+      s"""select var_pop(gamePointId) as a from (select * from VMALL_DICTIONARY_INCLUDE_hive order by gamePointId)""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_171")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_172
+  ignore("VMALL_DICTIONARY_INCLUDE_172", Include) {
+
+    checkAnswer(s"""select var_samp(gamePointId) as a from (select * from VMALL_DICTIONARY_INCLUDE order by gamePointId)""",
+      s"""select var_samp(gamePointId) as a from (select * from VMALL_DICTIONARY_INCLUDE_hive order by gamePointId)""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_172")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_173
+  test("VMALL_DICTIONARY_INCLUDE_173", Include) {
+
+    sql(s"""select stddev_pop(gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_174
+  test("VMALL_DICTIONARY_INCLUDE_174", Include) {
+
+    sql(s"""select stddev_samp(gamePointId)  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_175
+  test("VMALL_DICTIONARY_INCLUDE_175", Include) {
+
+    sql(s"""select covar_pop(gamePointId,gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_176
+  test("VMALL_DICTIONARY_INCLUDE_176", Include) {
+
+    sql(s"""select covar_samp(gamePointId,gamePointId) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_177
+  test("VMALL_DICTIONARY_INCLUDE_177", Include) {
+
+    checkAnswer(s"""select corr(gamePointId,gamePointId)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select corr(gamePointId,gamePointId)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_177")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_178
+  test("VMALL_DICTIONARY_INCLUDE_178", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,0.2) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_179
+  test("VMALL_DICTIONARY_INCLUDE_179", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,0.2,5) as a  from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_180
+  test("VMALL_DICTIONARY_INCLUDE_180", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,array(0.2,0.3,0.99))  as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_181
+  test("VMALL_DICTIONARY_INCLUDE_181", Include) {
+
+    sql(s"""select percentile_approx(gamePointId,array(0.2,0.3,0.99),5) as a from (select gamePointId from VMALL_DICTIONARY_INCLUDE order by gamePointId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_182
+  test("VMALL_DICTIONARY_INCLUDE_182", Include) {
+
+    sql(s"""select histogram_numeric(productionDate,2)  as a from (select productionDate from VMALL_DICTIONARY_INCLUDE order by productionDate) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_183
+  ignore("VMALL_DICTIONARY_INCLUDE_183", Include) {
+
+    checkAnswer(s"""select last(productionDate) a from VMALL_DICTIONARY_INCLUDE order by a""",
+      s"""select last(productionDate) a from VMALL_DICTIONARY_INCLUDE_hive order by a""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_183")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_184
+  test("VMALL_DICTIONARY_INCLUDE_184", Include) {
+
+    sql(s"""select FIRST(productionDate) a from VMALL_DICTIONARY_INCLUDE  order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_185
+  test("VMALL_DICTIONARY_INCLUDE_185", Include) {
+
+    checkAnswer(s"""select productionDate,count(productionDate) a from VMALL_DICTIONARY_INCLUDE group by productionDate order by productionDate""",
+      s"""select productionDate,count(productionDate) a from VMALL_DICTIONARY_INCLUDE_hive group by productionDate order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_185")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_186
+  test("VMALL_DICTIONARY_INCLUDE_186", Include) {
+
+    checkAnswer(s"""select Lower(productionDate) a  from VMALL_DICTIONARY_INCLUDE order by productionDate""",
+      s"""select Lower(productionDate) a  from VMALL_DICTIONARY_INCLUDE_hive order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_186")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_187
+  test("VMALL_DICTIONARY_INCLUDE_187", Include) {
+
+    checkAnswer(s"""select distinct productionDate from VMALL_DICTIONARY_INCLUDE order by productionDate""",
+      s"""select distinct productionDate from VMALL_DICTIONARY_INCLUDE_hive order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_187")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_188
+  test("VMALL_DICTIONARY_INCLUDE_188", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE order by productionDate limit 101""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive order by productionDate limit 101""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_188")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_189
+  test("VMALL_DICTIONARY_INCLUDE_189", Include) {
+
+    checkAnswer(s"""select productionDate as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select productionDate as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_189")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_190
+  test("VMALL_DICTIONARY_INCLUDE_190", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where  (productionDate == '2015-07-01 12:07:28.0') and (productionDate=='2015-07-01 12:07:28.0')""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where  (productionDate == '2015-07-01 12:07:28.0') and (productionDate=='2015-07-01 12:07:28.0')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_190")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_191
+  test("VMALL_DICTIONARY_INCLUDE_191", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate !='2015-07-01 12:07:28.0' order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate !='2015-07-01 12:07:28.0' order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_191")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_192
+  test("VMALL_DICTIONARY_INCLUDE_192", Include) {
+
+    checkAnswer(s"""select productionDate  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select productionDate  from VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_192")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_193
+  test("VMALL_DICTIONARY_INCLUDE_193", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate !='2015-07-01 12:07:28.0' order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate !='2015-07-01 12:07:28.0' order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_193")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_194
+  test("VMALL_DICTIONARY_INCLUDE_194", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate >'2015-07-01 12:07:28.0' order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate >'2015-07-01 12:07:28.0' order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_194")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_195
+  test("VMALL_DICTIONARY_INCLUDE_195", Include) {
+
+    checkAnswer(s"""select productionDate  from VMALL_DICTIONARY_INCLUDE where productionDate<>productionDate order by productionDate""",
+      s"""select productionDate  from VMALL_DICTIONARY_INCLUDE_hive where productionDate<>productionDate order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_195")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_196
+  test("VMALL_DICTIONARY_INCLUDE_196", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate != Latest_areaId order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate != Latest_areaId order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_196")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_197
+  test("VMALL_DICTIONARY_INCLUDE_197", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where Latest_areaId<productionDate order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<productionDate order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_197")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_198
+  test("VMALL_DICTIONARY_INCLUDE_198", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate<=productionDate order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate<=productionDate order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_198")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_199
+  test("VMALL_DICTIONARY_INCLUDE_199", Include) {
+
+    checkAnswer(s"""select productionDate from VMALL_DICTIONARY_INCLUDE where productionDate <cast('2015-07-01 12:07:28.0' as timestamp) order by productionDate""",
+      s"""select productionDate from VMALL_DICTIONARY_INCLUDE_hive where productionDate <cast('2015-07-01 12:07:28.0' as timestamp) order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_199")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_200
+  test("VMALL_DICTIONARY_INCLUDE_200", Include) {
+
+    checkAnswer(s"""select productionDate  from VMALL_DICTIONARY_INCLUDE where productionDate IS NULL""",
+      s"""select productionDate  from VMALL_DICTIONARY_INCLUDE_hive where productionDate IS NULL""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_200")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_201
+  test("VMALL_DICTIONARY_INCLUDE_201", Include) {
+
+    checkAnswer(s"""select productionDate  from VMALL_DICTIONARY_INCLUDE where productionDate IS NOT NULL order by productionDate""",
+      s"""select productionDate  from VMALL_DICTIONARY_INCLUDE_hive where productionDate IS NOT NULL order by productionDate""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_201")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_202
+  test("VMALL_DICTIONARY_INCLUDE_202", Include) {
+
+    checkAnswer(s"""Select count(deviceInformationId) from VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(deviceInformationId) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_202")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_203
+  test("VMALL_DICTIONARY_INCLUDE_203", Include) {
+
+    checkAnswer(s"""select count(DISTINCT deviceInformationId) as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT deviceInformationId) as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_203")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_204
+  test("VMALL_DICTIONARY_INCLUDE_204", Include) {
+
+    checkAnswer(s"""select sum(deviceInformationId)+10 as a ,deviceInformationId  from VMALL_DICTIONARY_INCLUDE group by deviceInformationId order by deviceInformationId""",
+      s"""select sum(deviceInformationId)+10 as a ,deviceInformationId  from VMALL_DICTIONARY_INCLUDE_hive group by deviceInformationId order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_204")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_205
+  test("VMALL_DICTIONARY_INCLUDE_205", Include) {
+
+    checkAnswer(s"""select max(deviceInformationId),min(deviceInformationId) from VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(deviceInformationId),min(deviceInformationId) from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_205")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_206
+  test("VMALL_DICTIONARY_INCLUDE_206", Include) {
+
+    checkAnswer(s"""select sum(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_206")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_207
+  test("VMALL_DICTIONARY_INCLUDE_207", Include) {
+
+    checkAnswer(s"""select avg(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_207")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_208
+  test("VMALL_DICTIONARY_INCLUDE_208", Include) {
+
+    checkAnswer(s"""select min(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_208")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_209
+  test("VMALL_DICTIONARY_INCLUDE_209", Include) {
+
+    sql(s"""select variance(deviceInformationId) as a   from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_210
+  ignore("VMALL_DICTIONARY_INCLUDE_210", Include) {
+
+    checkAnswer(s"""select var_pop(deviceInformationId)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select var_pop(deviceInformationId)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_210")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_211
+  ignore("VMALL_DICTIONARY_INCLUDE_211", Include) {
+
+    checkAnswer(s"""select var_samp(deviceInformationId) as a  from VMALL_DICTIONARY_INCLUDE""",
+      s"""select var_samp(deviceInformationId) as a  from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_211")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_212
+  test("VMALL_DICTIONARY_INCLUDE_212", Include) {
+
+    sql(s"""select stddev_pop(deviceInformationId) as a  from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_213
+  test("VMALL_DICTIONARY_INCLUDE_213", Include) {
+
+    sql(s"""select stddev_samp(deviceInformationId)  as a from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_214
+  test("VMALL_DICTIONARY_INCLUDE_214", Include) {
+
+    sql(s"""select covar_pop(deviceInformationId,deviceInformationId) as a  from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_215
+  test("VMALL_DICTIONARY_INCLUDE_215", Include) {
+
+    sql(s"""select covar_samp(deviceInformationId,deviceInformationId) as a  from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_216
+  test("VMALL_DICTIONARY_INCLUDE_216", Include) {
+
+    checkAnswer(s"""select corr(deviceInformationId,deviceInformationId)  as a from VMALL_DICTIONARY_INCLUDE""",
+      s"""select corr(deviceInformationId,deviceInformationId)  as a from VMALL_DICTIONARY_INCLUDE_hive""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_216")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_217
+  test("VMALL_DICTIONARY_INCLUDE_217", Include) {
+
+    sql(s"""select percentile_approx(deviceInformationId,0.2) as a  from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_218
+  test("VMALL_DICTIONARY_INCLUDE_218", Include) {
+
+    sql(s"""select percentile_approx(deviceInformationId,0.2,5) as a  from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_219
+  test("VMALL_DICTIONARY_INCLUDE_219", Include) {
+
+    sql(s"""select percentile_approx(deviceInformationId,array(0.2,0.3,0.99))  as a from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_220
+  test("VMALL_DICTIONARY_INCLUDE_220", Include) {
+
+    sql(s"""select percentile_approx(deviceInformationId,array(0.2,0.3,0.99),5) as a from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_221
+  test("VMALL_DICTIONARY_INCLUDE_221", Include) {
+
+    sql(s"""select histogram_numeric(deviceInformationId,2)  as a from (select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId) t""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_222
+  test("VMALL_DICTIONARY_INCLUDE_222", Include) {
+
+    checkAnswer(s"""select deviceInformationId, deviceInformationId+ 10 as a  from VMALL_DICTIONARY_INCLUDE order by deviceInformationId""",
+      s"""select deviceInformationId, deviceInformationId+ 10 as a  from VMALL_DICTIONARY_INCLUDE_hive order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_222")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_223
+  test("VMALL_DICTIONARY_INCLUDE_223", Include) {
+
+    checkAnswer(s"""select min(deviceInformationId), max(deviceInformationId+ 10) Total from VMALL_DICTIONARY_INCLUDE group by  channelsId order by Total""",
+      s"""select min(deviceInformationId), max(deviceInformationId+ 10) Total from VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by Total""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_223")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_224
+  test("VMALL_DICTIONARY_INCLUDE_224", Include) {
+
+    sql(s"""select last(deviceInformationId) a from VMALL_DICTIONARY_INCLUDE order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_225
+  test("VMALL_DICTIONARY_INCLUDE_225", Include) {
+
+    sql(s"""select FIRST(deviceInformationId) a from VMALL_DICTIONARY_INCLUDE order by a""").collect
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_226
+  test("VMALL_DICTIONARY_INCLUDE_226", Include) {
+
+    checkAnswer(s"""select deviceInformationId,count(deviceInformationId) a from VMALL_DICTIONARY_INCLUDE group by deviceInformationId order by deviceInformationId""",
+      s"""select deviceInformationId,count(deviceInformationId) a from VMALL_DICTIONARY_INCLUDE_hive group by deviceInformationId order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_226")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_227
+  test("VMALL_DICTIONARY_INCLUDE_227", Include) {
+
+    checkAnswer(s"""select Lower(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE order by deviceInformationId""",
+      s"""select Lower(deviceInformationId) a  from VMALL_DICTIONARY_INCLUDE_hive order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_227")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_228
+  test("VMALL_DICTIONARY_INCLUDE_228", Include) {
+
+    checkAnswer(s"""select distinct deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId""",
+      s"""select distinct deviceInformationId from VMALL_DICTIONARY_INCLUDE_hive order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_228")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_229
+  test("VMALL_DICTIONARY_INCLUDE_229", Include) {
+
+    checkAnswer(s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE order by deviceInformationId limit 101""",
+      s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE_hive order by deviceInformationId limit 101""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_229")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_230
+  test("VMALL_DICTIONARY_INCLUDE_230", Include) {
+
+    checkAnswer(s"""select deviceInformationId as a from VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select deviceInformationId as a from VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_230")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_231
+  test("VMALL_DICTIONARY_INCLUDE_231", Include) {
+
+    checkAnswer(s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE where  (deviceInformationId == 100084) and (deviceInformationId==100084)""",
+      s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE_hive where  (deviceInformationId == 100084) and (deviceInformationId==100084)""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_231")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_232
+  test("VMALL_DICTIONARY_INCLUDE_232", Include) {
+
+    checkAnswer(s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE where deviceInformationId !='100084' order by deviceInformationId""",
+      s"""select deviceInformationId from VMALL_DICTIONARY_INCLUDE_hive where deviceInformationId !='100084' order by deviceInformationId""", "QueriesIncludeDictionaryTestCase_VMALL_DICTIONARY_INCLUDE_232")
+
+  }
+
+
+  //VMALL_DICTIONARY_INCLUDE_233
+  test("VMALL_DICTIONARY_INCLUDE_233", Include) {
+
+    checkAnswer(s"""select deviceInformationId  from VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and

<TRUNCATED>