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:16 UTC

[09/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/QueriesCompactionTestCase.scala
----------------------------------------------------------------------
diff --git a/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesCompactionTestCase.scala b/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesCompactionTestCase.scala
new file mode 100644
index 0000000..7e568b0
--- /dev/null
+++ b/integration/spark-common-cluster-test/src/test/scala/org/apache/carbondata/cluster/sdv/generated/QueriesCompactionTestCase.scala
@@ -0,0 +1,6809 @@
+
+/*
+ * 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 QueriesCompactionTestCase to verify all scenerios
+ */
+
+class QueriesCompactionTestCase extends QueryTest with BeforeAndAfterAll {
+         
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_CreateCube
+  test("Comp_VMALL_DICTIONARY_INCLUDE_CreateCube", Include) {
+    sql(s"""drop table if exists Comp_VMALL_DICTIONARY_INCLUDE""").collect
+    sql(s"""drop table if exists Comp_VMALL_DICTIONARY_INCLUDE_hive""").collect
+
+    sql(s"""create table  Comp_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_ph
 onePADPartitionedVersions 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  Comp_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_ph
 onePADPartitionedVersions 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
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad1
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad1", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad2
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad2", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad3
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad3", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad4
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad4", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad5
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad5", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad6
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad6", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad7
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad7", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad8
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad8", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad9
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad9", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad10
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad10", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad11
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad11", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad12
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad12", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad13
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad13", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad14
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad14", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad15
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad15", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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_
 releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad16
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad16", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad17
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad17", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad18
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad18", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad19
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad19", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_DataLoad20
+  test("Comp_VMALL_DICTIONARY_INCLUDE_DataLoad20", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_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
 _releaseId,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 Comp_VMALL_DICTIONARY_INCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_MajorCompaction
+  test("Comp_VMALL_DICTIONARY_INCLUDE_MajorCompaction", Include) {
+
+    sql(s"""alter table Comp_VMALL_DICTIONARY_INCLUDE compact 'Major'""").collect
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_CreateCube
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_CreateCube", Include) {
+    sql(s"""drop table if exists Comp_VMALL_DICTIONARY_EXCLUDE""").collect
+    sql(s"""drop table if exists Comp_VMALL_DICTIONARY_EXCLUDE_hive""").collect
+
+    sql(s"""create table  Comp_VMALL_DICTIONARY_EXCLUDE (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_ph
 onePADPartitionedVersions 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_EXCLUDE'='imei')""").collect
+
+    sql(s"""create table  Comp_VMALL_DICTIONARY_EXCLUDE_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_ph
 onePADPartitionedVersions 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
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad1
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad1", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad2
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad2", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad3
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad3", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad4
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad4", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad5
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad5", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad6
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad6", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad7
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad7", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad8
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad8", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad9
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad9", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad10
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad10", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad11
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad11", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad12
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad12", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad13
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad13", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad14
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad14", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad15
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad15", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad16
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad16", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad17
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad17", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad18
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad18", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad19
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad19", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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,Lates
 t_releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad20
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_DataLoad20", Include) {
+
+    sql(s"""LOAD DATA INPATH  '$resourcesPath/Data/100_olap_C20.csv' INTO table Comp_VMALL_DICTIONARY_EXCLUDE 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
 _releaseId,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 Comp_VMALL_DICTIONARY_EXCLUDE_hive """).collect
+
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_EXCLUDE_MinorCompaction
+  test("Comp_VMALL_DICTIONARY_EXCLUDE_MinorCompaction", Include) {
+
+    sql(s"""alter table Comp_VMALL_DICTIONARY_EXCLUDE compact 'Minor'""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_001
+  test("Comp_VMALL_DICTIONARY_INCLUDE_001", Include) {
+
+    checkAnswer(s"""Select count(imei) from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(imei) from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_001")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_002
+  test("Comp_VMALL_DICTIONARY_INCLUDE_002", Include) {
+
+    checkAnswer(s"""select count(DISTINCT imei) as a from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT imei) as a from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_002")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_003
+  test("Comp_VMALL_DICTIONARY_INCLUDE_003", Include) {
+
+    checkAnswer(s"""select sum(Latest_month)+10 as a ,imei  from Comp_VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select sum(Latest_month)+10 as a ,imei  from Comp_VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_003")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_004
+  test("Comp_VMALL_DICTIONARY_INCLUDE_004", Include) {
+
+    checkAnswer(s"""select max(imei),min(imei) from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(imei),min(imei) from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_004")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_005
+  test("Comp_VMALL_DICTIONARY_INCLUDE_005", Include) {
+
+    checkAnswer(s"""select min(imei), max(imei) Total from Comp_VMALL_DICTIONARY_INCLUDE group by  channelsId order by Total""",
+      s"""select min(imei), max(imei) Total from Comp_VMALL_DICTIONARY_INCLUDE_hive group by  channelsId order by Total""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_005")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_006
+  test("Comp_VMALL_DICTIONARY_INCLUDE_006", Include) {
+
+    checkAnswer(s"""select last(imei) a from Comp_VMALL_DICTIONARY_INCLUDE  group by imei order by imei limit 1""",
+      s"""select last(imei) a from Comp_VMALL_DICTIONARY_INCLUDE_hive  group by imei order by imei limit 1""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_006")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_007
+  test("Comp_VMALL_DICTIONARY_INCLUDE_007", Include) {
+
+    sql(s"""select FIRST(imei) a from Comp_VMALL_DICTIONARY_INCLUDE group by imei order by imei limit 1""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_008
+  test("Comp_VMALL_DICTIONARY_INCLUDE_008", Include) {
+
+    checkAnswer(s"""select imei,count(imei) a from Comp_VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select imei,count(imei) a from Comp_VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_008")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_009
+  test("Comp_VMALL_DICTIONARY_INCLUDE_009", Include) {
+
+    checkAnswer(s"""select Lower(imei) a  from Comp_VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select Lower(imei) a  from Comp_VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_009")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_010
+  test("Comp_VMALL_DICTIONARY_INCLUDE_010", Include) {
+
+    checkAnswer(s"""select distinct imei from Comp_VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select distinct imei from Comp_VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_010")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_011
+  test("Comp_VMALL_DICTIONARY_INCLUDE_011", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE order by imei limit 101 """,
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive order by imei limit 101 """, "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_011")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_012
+  test("Comp_VMALL_DICTIONARY_INCLUDE_012", Include) {
+
+    checkAnswer(s"""select imei as a from Comp_VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select imei as a from Comp_VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_012")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_013
+  test("Comp_VMALL_DICTIONARY_INCLUDE_013", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where  (contractNumber == 9223372047700) and (imei=='1AA100004')""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where  (contractNumber == 9223372047700) and (imei=='1AA100004')""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_013")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_014
+  test("Comp_VMALL_DICTIONARY_INCLUDE_014", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei !='1AA100064' order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei !='1AA100064' order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_014")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_015
+  test("Comp_VMALL_DICTIONARY_INCLUDE_015", Include) {
+
+    checkAnswer(s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_015")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_016
+  test("Comp_VMALL_DICTIONARY_INCLUDE_016", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei !='1AA100012' order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei !='1AA100012' order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_016")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_017
+  test("Comp_VMALL_DICTIONARY_INCLUDE_017", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei >'1AA100012' order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei >'1AA100012' order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_017")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_018
+  test("Comp_VMALL_DICTIONARY_INCLUDE_018", Include) {
+
+    checkAnswer(s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE where imei<>imei""",
+      s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei<>imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_018")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_019
+  test("Comp_VMALL_DICTIONARY_INCLUDE_019", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei != Latest_areaId order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei != Latest_areaId order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_019")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_020
+  test("Comp_VMALL_DICTIONARY_INCLUDE_020", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where Latest_areaId<imei order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where Latest_areaId<imei order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_020")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_021
+  test("Comp_VMALL_DICTIONARY_INCLUDE_021", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where Latest_DAY<=imei order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where Latest_DAY<=imei order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_021")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_022
+  test("Comp_VMALL_DICTIONARY_INCLUDE_022", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei <'1AA10002' order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei <'1AA10002' order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_022")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_023
+  test("Comp_VMALL_DICTIONARY_INCLUDE_023", Include) {
+
+    checkAnswer(s"""select Latest_day  from Comp_VMALL_DICTIONARY_INCLUDE where imei IS NULL""",
+      s"""select Latest_day  from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei IS NULL""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_023")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_024
+  test("Comp_VMALL_DICTIONARY_INCLUDE_024", Include) {
+
+    checkAnswer(s"""select Latest_day  from Comp_VMALL_DICTIONARY_INCLUDE where imei IS NOT NULL order by Latest_day""",
+      s"""select Latest_day  from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei IS NOT NULL order by Latest_day""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_024")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_025
+  test("Comp_VMALL_DICTIONARY_INCLUDE_025", Include) {
+
+    checkAnswer(s"""Select count(imei),min(imei) from Comp_VMALL_DICTIONARY_INCLUDE """,
+      s"""Select count(imei),min(imei) from Comp_VMALL_DICTIONARY_INCLUDE_hive """, "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_025")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_026
+  test("Comp_VMALL_DICTIONARY_INCLUDE_026", Include) {
+
+    checkAnswer(s"""select count(DISTINCT imei,latest_day) as a from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT imei,latest_day) as a from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_026")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_027
+  test("Comp_VMALL_DICTIONARY_INCLUDE_027", Include) {
+
+    checkAnswer(s"""select max(imei),min(imei),count(imei) from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(imei),min(imei),count(imei) from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_027")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_028
+  test("Comp_VMALL_DICTIONARY_INCLUDE_028", Include) {
+
+    checkAnswer(s"""select sum(imei),avg(imei),count(imei) a  from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(imei),avg(imei),count(imei) a  from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_028")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_029
+  test("Comp_VMALL_DICTIONARY_INCLUDE_029", Include) {
+
+    sql(s"""select last(imei),Min(imei),max(imei)  a from (select imei from Comp_VMALL_DICTIONARY_INCLUDE order by imei) t""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_030
+  test("Comp_VMALL_DICTIONARY_INCLUDE_030", Include) {
+
+    sql(s"""select FIRST(imei),Last(imei) a from Comp_VMALL_DICTIONARY_INCLUDE group by imei order by imei limit 1""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_031
+  test("Comp_VMALL_DICTIONARY_INCLUDE_031", Include) {
+
+    checkAnswer(s"""select imei,count(imei) a from Comp_VMALL_DICTIONARY_INCLUDE group by imei order by imei""",
+      s"""select imei,count(imei) a from Comp_VMALL_DICTIONARY_INCLUDE_hive group by imei order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_031")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_032
+  test("Comp_VMALL_DICTIONARY_INCLUDE_032", Include) {
+
+    checkAnswer(s"""select Lower(imei),upper(imei)  a  from Comp_VMALL_DICTIONARY_INCLUDE order by imei""",
+      s"""select Lower(imei),upper(imei)  a  from Comp_VMALL_DICTIONARY_INCLUDE_hive order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_032")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_033
+  test("Comp_VMALL_DICTIONARY_INCLUDE_033", Include) {
+
+    checkAnswer(s"""select imei as a from Comp_VMALL_DICTIONARY_INCLUDE  order by a asc limit 10""",
+      s"""select imei as a from Comp_VMALL_DICTIONARY_INCLUDE_hive  order by a asc limit 10""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_033")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_034
+  test("Comp_VMALL_DICTIONARY_INCLUDE_034", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where  (contractNumber == 9223372047700) and (imei=='1AA100012')""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where  (contractNumber == 9223372047700) and (imei=='1AA100012')""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_034")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_035
+  test("Comp_VMALL_DICTIONARY_INCLUDE_035", Include) {
+
+    checkAnswer(s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE where imei !='8imei' order by imei""",
+      s"""select imei from Comp_VMALL_DICTIONARY_INCLUDE_hive where imei !='8imei' order by imei""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_035")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_036
+  test("Comp_VMALL_DICTIONARY_INCLUDE_036", Include) {
+
+    checkAnswer(s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""",
+      s"""select imei  from Comp_VMALL_DICTIONARY_INCLUDE_hive where (deviceInformationId=100 and deviceColor='1Device Color') OR (deviceInformationId=10 and deviceColor='0Device Color')""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_036")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_037
+  test("Comp_VMALL_DICTIONARY_INCLUDE_037", Include) {
+
+    checkAnswer(s"""Select count(contractNumber) from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""Select count(contractNumber) from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_037")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_038
+  test("Comp_VMALL_DICTIONARY_INCLUDE_038", Include) {
+
+    checkAnswer(s"""select count(DISTINCT contractNumber) as a from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select count(DISTINCT contractNumber) as a from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_038")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_039
+  test("Comp_VMALL_DICTIONARY_INCLUDE_039", Include) {
+
+    checkAnswer(s"""select sum(contractNumber)+10 as a ,contractNumber  from Comp_VMALL_DICTIONARY_INCLUDE group by contractNumber""",
+      s"""select sum(contractNumber)+10 as a ,contractNumber  from Comp_VMALL_DICTIONARY_INCLUDE_hive group by contractNumber""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_039")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_040
+  test("Comp_VMALL_DICTIONARY_INCLUDE_040", Include) {
+
+    checkAnswer(s"""select max(contractNumber),min(contractNumber) from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select max(contractNumber),min(contractNumber) from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_040")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_041
+  test("Comp_VMALL_DICTIONARY_INCLUDE_041", Include) {
+
+    checkAnswer(s"""select sum(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select sum(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_041")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_042
+  test("Comp_VMALL_DICTIONARY_INCLUDE_042", Include) {
+
+    checkAnswer(s"""select avg(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select avg(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_042")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_043
+  test("Comp_VMALL_DICTIONARY_INCLUDE_043", Include) {
+
+    checkAnswer(s"""select min(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE""",
+      s"""select min(contractNumber) a  from Comp_VMALL_DICTIONARY_INCLUDE_hive""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_043")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_044
+  test("Comp_VMALL_DICTIONARY_INCLUDE_044", Include) {
+
+    sql(s"""select variance(contractNumber) as a   from (select contractNumber from Comp_VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_045
+  test("Comp_VMALL_DICTIONARY_INCLUDE_045", Include) {
+
+    checkAnswer(s"""select var_pop(contractNumber) as a from (select * from Comp_VMALL_DICTIONARY_INCLUDE order by contractNumber) t""",
+      s"""select var_pop(contractNumber) as a from (select * from Comp_VMALL_DICTIONARY_INCLUDE_hive order by contractNumber) t""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_045")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_046
+  test("Comp_VMALL_DICTIONARY_INCLUDE_046", Include) {
+
+    checkAnswer(s"""select var_samp(contractNumber) as a from  (select * from Comp_VMALL_DICTIONARY_INCLUDE order by contractNumber) t""",
+      s"""select var_samp(contractNumber) as a from  (select * from Comp_VMALL_DICTIONARY_INCLUDE_hive order by contractNumber) t""", "QueriesCompactionTestCase_Comp_VMALL_DICTIONARY_INCLUDE_046")
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_047
+  test("Comp_VMALL_DICTIONARY_INCLUDE_047", Include) {
+
+    sql(s"""select stddev_pop(contractNumber) as a  from (select contractNumber from Comp_VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_048
+  test("Comp_VMALL_DICTIONARY_INCLUDE_048", Include) {
+
+    sql(s"""select stddev_samp(contractNumber)  as a from (select contractNumber from Comp_VMALL_DICTIONARY_INCLUDE order by contractNumber) t""").collect
+
+  }
+
+
+  //Comp_VMALL_DICTIONARY_INCLUDE_049
+  test("Comp_VMALL_DICTIONARY_INCLUDE_049", Include) {
+
+    sql(s"""select covar_pop(contractNumber,contractNumber) as a  from (select contractNumber from Comp_VMALL_DICTIONA

<TRUNCATED>