You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@carbondata.apache.org by ra...@apache.org on 2016/12/11 04:10:13 UTC

[1/3] incubator-carbondata git commit: AllDataTypeTestCase6 improved

Repository: incubator-carbondata
Updated Branches:
  refs/heads/master a0714f511 -> 573e9e8c9


http://git-wip-us.apache.org/repos/asf/incubator-carbondata/blob/11eefc95/integration-testcases/src/test/scala/org/apache/spark/testsuite/allqueries/AllDataTypesTestCase6.scala
----------------------------------------------------------------------
diff --git a/integration-testcases/src/test/scala/org/apache/spark/testsuite/allqueries/AllDataTypesTestCase6.scala b/integration-testcases/src/test/scala/org/apache/spark/testsuite/allqueries/AllDataTypesTestCase6.scala
index 6ca2607..9068ecc 100644
--- a/integration-testcases/src/test/scala/org/apache/spark/testsuite/allqueries/AllDataTypesTestCase6.scala
+++ b/integration-testcases/src/test/scala/org/apache/spark/testsuite/allqueries/AllDataTypesTestCase6.scala
@@ -20,19 +20,24 @@
 package org.apache.carbondata.spark.testsuite.allqueries
 
 import java.io.File
+import java.sql.Timestamp
+import java.text.SimpleDateFormat
+import java.util.Date
 
-import org.apache.spark.sql.Row
+import junit.framework.TestCase._
+import org.apache.spark.sql.{DataFrame, Row}
 import org.apache.spark.sql.common.util.CarbonHiveContext._
 import org.apache.spark.sql.common.util.{NonRunningTests, QueryTest}
+import org.codehaus.groovy.util.AbstractConcurrentMapBase.Segment
 import org.scalatest.BeforeAndAfterAll
 
 import org.apache.carbondata.core.constants.CarbonCommonConstants
 import org.apache.carbondata.core.util.CarbonProperties
 
 /**
-  * Test Class for all queries on multiple datatypes
-  * Manohar
-  */
+ * Test Class for all queries on multiple datatypes
+ *
+ */
 class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
 
   override def beforeAll {
@@ -61,7 +66,7 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
         "Latest_BacFlashVer string, Latest_webUIVersion string, Latest_webUITypeCarrVer string, " +
         "Latest_webTypeDataVerNumber string, Latest_operatorsVersion string, " +
         "Latest_phonePADPartitionedVersions string, Latest_operatorId string, " +
-        "gamePointDescription string, gamePointId int,contractNumber int) stored by 'org.apache" +
+        " gamePointId int,contractNumber int,gamePointDescription string) stored by 'org.apache" +
         ".carbondata.format'")
       CarbonProperties.getInstance()
         .addProperty(CarbonCommonConstants.CARBON_TIMESTAMP_FORMAT,
@@ -73,7 +78,7 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           "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," +
+          "deliveryStreet,oxSingleNumber,ActiveCheckTime,ActiveAreaId," +
           "ActiveCountry,ActiveProvince,Activecity,ActiveDistrict,ActiveStreet,ActiveOperatorId," +
           "Active_releaseId,Active_EMUIVersion,Active_operaSysVersion,Active_BacVerNumber," +
           "Active_BacFlashVer,Active_webUIVersion,Active_webUITypeCarrVer," +
@@ -83,36 +88,66 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           "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')")
+          "Latest_phonePADPartitionedVersions,Latest_operatorId,gamePointId," +
+          "contractNumber,gamePointDescription')")
+
+
+      sql(
+        "create table Carbon_automation_test6_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 " +
+        "string,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_phonePADPartitionedVersions string, " +
+        "Latest_YEAR int, Latest_MONTH int, Latest_DAY int, 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 int,contractNumber int,gamePointDescription string) row format delimited " +
+        "fields terminated by ','")
+
+      sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
+          "/src/test/resources/100_olap.csv' INTO table Carbon_automation_test6_hive")
 
       sql(
         "create table hivetable(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 int, 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_phonePADPartitionedVersions string, " +
-          "Latest_YEAR int, Latest_MONTH int, Latest_DAY int, 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 int," +
-          "gamePointDescription string) row format " +
-          "delimited fields terminated by ','"
+        "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 int, 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_phonePADPartitionedVersions string, " +
+        "Latest_YEAR int, Latest_MONTH int, Latest_DAY int, 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 int," +
+        "gamePointDescription string) row format " +
+        "delimited fields terminated by ','"
       )
 
 
       sql(
         "LOAD DATA local inpath'" + currentDirectory + "/src/test/resources/100_olap.csv'" +
-          " overwrite INTO table hivetable"
+        " overwrite INTO table hivetable"
       )
 
       sql(
@@ -147,6 +182,29 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           "Latest_check_hour,Latest_areaId,Latest_country,Latest_province,Latest_city," +
           "Latest_district,Latest_firmware_version,Latest_emui_version,Latest_os_version," +
           "Latest_network,site,site_desc,product,product_desc')")
+
+      sql(
+        "create table myvmallTest_hive (imei String,uuid String,MAC String,device_color String," +
+        "device_shell_color String,device_name String,product_name String,ram String,rom  String," +
+        "cpu_clock String,series String,check_date String,check_month int , check_day int," +
+        "check_hour int,bom String,inside_name String,packing_date  String,packing_year String," +
+        "packing_month String,packing_day String,packing_hour String,customer_name String," +
+        "deliveryAreaId String,deliveryCountry String, deliveryProvince String,deliveryCity " +
+        "String,deliveryDistrict String,packing_list_no String,order_no String,Active_check_time " +
+        "String,Active_check_year int, Active_check_month int,Active_check_day int," +
+        "Active_check_hour int, ActiveAreaId String,ActiveCountry String,ActiveProvince String," +
+        "Activecity String, ActiveDistrict String,Active_network String,Active_firmware_version " +
+        "String, Active_emui_version String,Active_os_version String,Latest_check_time String, " +
+        "Latest_check_year int,Latest_check_month int,Latest_check_day int, Latest_check_hour " +
+        "int,Latest_areaId String,Latest_country String,Latest_province  String,Latest_city " +
+        "String,Latest_district String,Latest_firmware_version String, Latest_emui_version " +
+        "String,Latest_os_version String,Latest_network String,site String, site_desc String," +
+        "product String,product_desc String,check_year int) " +
+        "row format delimited fields terminated by ','")
+      sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
+          "/src/test/resources/100_VMALL_1_Day_DATA_2015-09-15.csv' INTO table myvmallTest_hive")
+
+
       sql(
         "create table if not exists traffic_2g_3g_4g (source_info string , app_category_id string" +
         " ,app_category_name string ,app_sub_category_id string , app_sub_category_name string ," +
@@ -171,7 +229,50 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
 
       sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
           "/src/test/resources/FACT_UNITED_DATA_INFO_sample_cube.csv' INTO table traffic_2g_3g_4g" +
-          "OPTIONS('DELIMITER'= ',' ,'QUOTECHAR'= '\"', 'FILEHEADER'= '')")
+          "OPTIONS('DELIMITER'= ',' ,'QUOTECHAR'= '\"', 'FILEHEADER'= 'source_info   , " +
+          "app_category_id    ,app_category_name   ,app_sub_category_id   , app_sub_category_name" +
+          "   , rat_name   ,imsi   ,offer_msisdn   , offer_id   ,offer_option_1    ," +
+          "offer_option_2   ,offer_option_3   , msisdn   ,package_type    ,package_price   ," +
+          "tag_imsi   ,tag_msisdn   ,province   ,city    ,area_code   ,tac   ,imei   , " +
+          "terminal_type   ,terminal_brand    ,terminal_model   ,price_level   ,network   ," +
+          "shipped_os   , wifi   ,wifi_hotspot   ,gsm   , wcdma   ,td_scdma   ,lte_fdd    ," +
+          "lte_tdd   ,cdma   , screen_size   ,screen_resolution   , host_name   ,website_name   ," +
+          " operator   ,srv_type_name   ,tag_host    ,cgi   ,cell_name   , coverity_type1   ," +
+          "coverity_type2   , coverity_type3   ,coverity_type4   ,coverity_type5   ,latitude   , " +
+          "longitude   ,azimuth   , tag_cgi   ,apn   ,user_agent   ,day    ,hour   ,`min`   , " +
+          "is_default_bear int ,eps_bearer_id   ,qci int , user_filter   , analysis_period  , " +
+          "up_throughput  ,down_throughput   , up_pkt_num  ,down_pkt_num  ,app_request_num  , " +
+          "pkt_num_len_1_64  ,pkt_num_len_64_128  ,pkt_num_len_128_256  , pkt_num_len_256_512  ," +
+          "pkt_num_len_512_768  ,pkt_num_len_768_1024  , pkt_num_len_1024_all  ,ip_flow_mark  ')")
+
+      sql(
+        "create table if not exists traffic_2g_3g_4g_hive (source_info string , app_category_id " +
+        "string" +
+        " ,app_category_name string ,app_sub_category_id string , app_sub_category_name string ," +
+        "rat_name string ,imsi string ,offer_msisdn string , offer_id string ,offer_option_1 " +
+        "string ,offer_option_2 string ,offer_option_3 string , msisdn string ,package_type " +
+        "string ,package_price string ,tag_imsi string ,tag_msisdn string ,province string ,city " +
+        "string ,area_code string ,tac string ,imei string , terminal_type string ,terminal_brand" +
+        " string ,terminal_model string ,price_level string  ,network string ,shipped_os string ," +
+        "wifi string ,wifi_hotspot string ,gsm string , wcdma string ,td_scdma string ,lte_fdd " +
+        "string ,lte_tdd string ,cdma string , screen_size string ,screen_resolution string ," +
+        "host_name string ,website_name string , operator string ,srv_type_name string ,tag_host " +
+        "string ,cgi string ,cell_name string , coverity_type1 string ,coverity_type2 string ," +
+        "coverity_type3 string ,coverity_type4  string ,coverity_type5 string ,latitude string ," +
+        "longitude string ,azimuth string , tag_cgi string ,apn string ,user_agent string ,day " +
+        "string ,hour string ,`min` string , is_default_bear int ,eps_bearer_id string ,qci int ," +
+        "user_filter string , analysis_period string, up_throughput decimal,down_throughput " +
+        "decimal, up_pkt_num decimal,down_pkt_num decimal,app_request_num decimal," +
+        "pkt_num_len_1_64  decimal,pkt_num_len_64_128 decimal,pkt_num_len_128_256 decimal," +
+        "pkt_num_len_256_512  decimal,pkt_num_len_512_768 decimal,pkt_num_len_768_1024 decimal," +
+        "pkt_num_len_1024_all  decimal,ip_flow_mark decimal)" +
+        "row format delimited fields terminated by ','")
+
+      sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
+          "/src/test/resources/FACT_UNITED_DATA_INFO_sample_cube.csv' INTO table " +
+          "traffic_2g_3g_4g_hive")
+
+
 
       sql(
         "Create table cube_restructure444 (a0 STRING,a STRING,b0 INT)  stored by 'org.apache" +
@@ -181,6 +282,13 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           " INTO TABLE cube_restructure444 OPTIONS('DELIMITER'=',', 'QUOTECHAR'= '\"')")
 
       sql(
+        "Create table cube_restructure444_hive (a0 STRING,a STRING,b0 INT)  row format delimited " +
+        "fields terminated by ','")
+      sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
+          "/src/test/resources/restructure_cube.csv'" +
+          " INTO TABLE cube_restructure444_hive")
+
+      sql(
         "create table  Carbon_automation_vmall_test1 (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," +
@@ -203,7 +311,7 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
         "Latest_operatorId string, gamePointDescription string,gamePointId decimal,contractNumber" +
         " decimal) stored by 'org.apache.carbondata.format'")
       sql("LOAD DATA LOCAL INPATH 'hdfs://hacluster/mano/Vmall_100_olap.csv' INTO table " +
-          "Carbon_automation_vmall_test1 OPTIONS('DELIMITER'= ',' ,'QUOTECHAR'= '\\\"', " +
+          "Carbon_automation_vmall_test1 OPTIONS('DELIMITER'= ',' ,'QUOTECHAR'= '\"', " +
           "'FILEHEADER'= 'imei,deviceInformationId,MAC,deviceColor,device_backColor,modelId," +
           "marketName,AMSize,ROMSize,CUPAudit,CPIClocked,series,productionDate,bomCode," +
           "internalModels,deliveryTime,channelsId,channelsName,deliveryAreaId,deliveryCountry," +
@@ -218,6 +326,35 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           "Latest_BacVerNumber,Latest_BacFlashVer,Latest_webUIVersion,Latest_webUITypeCarrVer," +
           "Latest_webTypeDataVerNumber,Latest_operatorsVersion," +
           "Latest_phonePADPartitionedVersions,Latest_operatorId,gamePointId,gamePointDescription')")
+
+
+      sql(
+        "create table  Carbon_automation_vmall_test1_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, 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_phonePADPartitionedVersions string, Latest_YEAR int, Latest_MONTH int, Latest_DAY" +
+        " int, 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 decimal,contractNumber" +
+        " decimal) row format delimited fields terminated by ','")
+      sql("LOAD DATA LOCAL INPATH 'hdfs://hacluster/mano/Vmall_100_olap.csv' INTO table " +
+          "Carbon_automation_vmall_test1_hive")
+
+
       sql(
         "create table Carbon_automation_test5 (imei string,deviceInformationId int,MAC string," +
         "deviceColor string,device_backColor string,modelId string,marketName string,AMSize " +
@@ -258,39 +395,117 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
           "Latest_webTypeDataVerNumber,Latest_operatorsVersion," +
           "Latest_phonePADPartitionedVersions,Latest_operatorId,gamePointId,gamePointDescription')")
 
+      sql(
+        "create table Carbon_automation_test5_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 " +
+        "string,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_phonePADPartitionedVersions string, " +
+        "Latest_YEAR int, Latest_MONTH int, Latest_DAY int, 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 int,contractNumber int) row format delimited " +
+        "fields terminated by ','")
+      sql("LOAD DATA LOCAL INPATH '" + currentDirectory +
+          "/src/test/resources/100_olap.csv' INTO table Carbon_automation_test5_hive")
+
       sql("create schema myschema")
       sql("create schema myschema1")
       sql("create schema drug")
-    }catch {
-      case e : Exception => print("ERROR : " + e.getMessage)
+    } catch {
+      case e: Exception => print("ERROR : " + e.getMessage)
     }
   }
 
   override def afterAll {
     try {
       sql("drop table Carbon_automation_test6")
+      sql("drop table Carbon_automation_test6_hive")
       sql("drop table hivetable")
       sql("drop table myvmallTest")
       sql("drop table traffic_2g_3g_4g")
+      sql("drop table traffic_2g_3g_4g_hive")
       sql("drop table cube_restructure444")
       sql("drop table Carbon_automation_vmall_test1")
       sql("drop table Carbon_automation_test5")
+      sql("drop table Carbon_automation_test5_hive")
       sql("drop schema myschema")
       sql("drop schema myschema1")
       sql("drop schema drug")
-    }catch {
-      case e : Exception => print("ERROR : " + e.getMessage)
+    } catch {
+      case e: Exception => print("ERROR : " + e.getMessage)
     }
   }
 
   //AllDataTypesTestCases2
+  //gamePointId int,contractNumber int,gamePointDescription string
+  //Test-46
+  test("select * Carbon_automation_test6 ")(
+  {
+    checkAnswer(
+      sql(
+        "select 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,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,contractNumber,gamePointDescription from " +
+        "Carbon_automation_test6"),
+      sql(
+        "select 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,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,contractNumber,gamePointDescription from " +
+        "Carbon_automation_test6_hive")
+    )
+  })
+
+
 
   //Test-46
-  test("select sum(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by series.")({
+  test(
+    "select sum(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by " +
+    "series.")(
+  {
 
     checkAnswer(
-      sql("select sum(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(900451, "6Series"), Row(1410606, "0Series"), Row(800391, "4Series"), Row(920401, "8Series"), Row(1620257, "7Series"), Row(300060, "1Series"), Row(1321584, "5Series"), Row(800323, "9Series"), Row(710330, "3Series"), Row(810414, "2Series")))
+      sql(
+        "select sum(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by " +
+        "series"),
+      sql(
+        "select sum(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by " +
+        "series")
+    )
   })
 
 
@@ -300,15 +515,25 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
 
     checkAnswer(
       sql("select sum(latest_year)+10 as a ,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(18145, "6Series"), Row(30235, "0Series"), Row(16130, "4Series"), Row(22175, "8Series"), Row(22175, "7Series"), Row(6055, "1Series"), Row(34265, "5Series"), Row(16130, "9Series"), Row(16130, "3Series"), Row(18145, "2Series")))
+      sql(
+        "select sum(latest_year)+10 as a ,series  from Carbon_automation_test6_hive group by " +
+        "series"))
+
   })
 
   //Test-49
-  test("select sum(deviceinformationid)+10.32 as a ,series  from Carbon_automation_test6 group by series")({
+  test(
+    "select sum(deviceinformationid)+10.32 as a ,series  from Carbon_automation_test6 group by " +
+    "series")({
 
     checkAnswer(
-      sql("select sum(deviceinformationid)+10.32 as a ,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(900451.32, "6Series"), Row(1410606.32, "0Series"), Row(800391.32, "4Series"), Row(920401.32, "8Series"), Row(1620257.32, "7Series"), Row(300060.32, "1Series"), Row(1321584.32, "5Series"), Row(800323.32, "9Series"), Row(710330.32, "3Series"), Row(810414.32, "2Series")))
+      sql(
+        "select sum(deviceinformationid)+10.32 as a ,series  from Carbon_automation_test6 group " +
+        "by series"),
+      sql(
+        "select sum(deviceinformationid)+10.32 as a ,series  from Carbon_automation_test6_hive " +
+        "group " +
+        "by series"))
   })
 
 
@@ -316,22 +541,38 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
   //TC_051
   test("select sum(latest_year)+10.364 as a,series  from Carbon_automation_test6 group by series")({
     checkAnswer(
-      sql("select sum(latest_year)+10.364 as a,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(18145.364, "6Series"), Row(30235.364, "0Series"), Row(16130.364, "4Series"), Row(22175.364, "8Series"), Row(22175.364, "7Series"), Row(6055.364, "1Series"), Row(34265.364, "5Series"), Row(16130.364, "9Series"), Row(16130.364, "3Series"), Row(18145.364, "2Series")))
+      sql("select sum(latest_year)+10.364 as a,series  from Carbon_automation_test6 group by " +
+          "series"),
+      sql(
+        "select sum(latest_year)+10.364 as a,series  from Carbon_automation_test6_hive group by " +
+        "series")
+    )
   })
 
   //TC_052
-  test("select avg(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by series")({
+  test(
+    "select avg(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by " +
+    "series")({
     checkAnswer(
-      sql("select avg(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(100059.0, "6Series"), Row(94049.73333333334, "0Series"), Row(100057.625, "4Series"), Row(83681.90909090909, "8Series"), Row(147305.18181818182, "7Series"), Row(100026.66666666667, "1Series"), Row(77749.64705882352, "5Series"), Row(100049.125, "9Series"), Row(88800.0, "3Series"), Row(90054.88888888889, "2Series")))
+      sql(
+        "select avg(deviceinformationid)+10 as a ,series  from Carbon_automation_test6 group by " +
+        "series"),
+      sql(
+        "select avg(deviceinformationid)+10 as a ,series  from Carbon_automation_test6_hive group" +
+        " by " +
+        "series")
+    )
   })
 
   //TC_054
-  test("select avg(latest_year)+10 as a ,series  from Carbon_automation_test6 group by series")({
+  test("select avg(latest_year)+10 as a ,series  from Carbon_automation_test6 group by " +
+       "series")({
     checkAnswer(
       sql("select avg(latest_year)+10 as a ,series  from Carbon_automation_test6 group by series"),
-      Seq(Row(2025.0, "6Series"), Row(2025.0, "0Series"), Row(2025.0, "4Series"), Row(2025.0, "8Series"), Row(2025.0, "7Series"), Row(2025.0, "1Series"), Row(2025.0, "5Series"), Row(2025.0, "9Series"), Row(2025.0, "3Series"), Row(2025.0, "2Series")))
+      sql(
+        "select avg(latest_year)+10 as a ,series  from Carbon_automation_test6_hive group by " +
+        "series")
+    )
   })
 
 
@@ -339,28 +580,31 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
   test("select sum(deviceInformationId) a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select sum(deviceInformationId) a  from Carbon_automation_test6"),
-      Seq(Row(9594717)))
+      sql("select sum(deviceInformationId) a  from Carbon_automation_test6_hive"))
   })
 
   //TC_073
   test("select sum(channelsId) a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select sum(channelsId) a  from Carbon_automation_test6"),
-      Seq(Row(428.0)))
+      sql("select sum(channelsId) a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_074
   test("select sum(bomCode)  a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select sum(bomCode)  a  from Carbon_automation_test6"),
-      Seq(Row(9594717.0)))
+      sql("select sum(bomCode)  a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_075
   test("select sum(Latest_MONTH)  a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select sum(Latest_MONTH)  a  from Carbon_automation_test6"),
-      Seq(Row(693)))
+      sql("select sum(Latest_MONTH)  a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_078
@@ -374,28 +618,32 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
   test("select avg(deviceInformationId) a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select avg(deviceInformationId) a  from Carbon_automation_test6"),
-      Seq(Row(96916.33333333333)))
+      sql("select avg(deviceInformationId) a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_084
   test("select avg(channelsId) a  from Carbon_automation_test6", NonRunningTests)({
     checkAnswer(
       sql("select avg(channelsId) a  from Carbon_automation_test6"),
-      Seq(Row(4.3232323232323235)))
+      sql("select avg(channelsId) a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_085
   test("select avg(bomCode)  a  from Carbon_automation_test6", NonRunningTests)({
     checkAnswer(
       sql("select avg(bomCode)  a  from Carbon_automation_test6"),
-      Seq(Row(96916.33333333333)))
+      sql("select avg(bomCode)  a  from Carbon_automation_test6_hive")
+    )
   })
 
   //TC_086
   test("select avg(Latest_MONTH)  a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select avg(Latest_MONTH)  a  from Carbon_automation_test6"),
-      Seq(Row(7.0)))
+      sql("select avg(Latest_MONTH)  a  from Carbon_automation_test6_hive")
+    )
   })
 
 
@@ -403,51 +651,58 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
   test("select var_pop(deviceInformationId)  as a from Carbon_automation_test6")({
     checkAnswer(
       sql("select var_pop(deviceInformationId)  as a from Carbon_automation_test6"),
-      Seq(Row(9.310415559636362E9)))
+      sql("select var_pop(deviceInformationId)  as a from Carbon_automation_test6_hive")
+
+    )
   })
 
 
   //TC_114
-  test("select percentile_approx(deviceInformationId,0.2,5) as a  from Carbon_automation_test6")({
+  test("select percentile_approx(deviceInformationId,0.2,5) as a  from " +
+       "Carbon_automation_test6")({
     checkAnswer(
       sql("select percentile_approx(deviceInformationId,0.2,5) as a  from Carbon_automation_test6"),
-      Seq(Row(17207.04)))
+      sql(
+        "select percentile_approx(deviceInformationId,0.2,5) as a  from " +
+        "Carbon_automation_test6_hive")
+    )
   })
 
 
   //TC_119
   test("select variance(gamePointId) as a   from Carbon_automation_test6")({
     checkAnswer(
-      sql("select variance(gamePointId) as a   from Carbon_automation_test6"),
-      sql("select variance(gamePointId) as a   from hivetable"))
+      sql("select variance(gamePointId) as a from Carbon_automation_test6"),
+      sql("select variance(gamePointId) as a from Carbon_automation_test6_hive"))
   })
 
   //TC_120
   test("select var_pop(gamePointId)  as a from Carbon_automation_test6")({
     checkAnswer(
       sql("select var_pop(gamePointId)  as a from Carbon_automation_test6"),
-      Seq(Row(654787.8439309275)))
+      sql("select var_pop(gamePointId)  as a from Carbon_automation_test6_hive"))
   })
 
   //TC_121
   test("select var_samp(gamePointId) as a  from Carbon_automation_test6")({
     checkAnswer(
       sql("select var_samp(gamePointId) as a  from Carbon_automation_test6"),
-      Seq(Row(661469.3525424675)))
+      sql("select var_samp(gamePointId) as a  from Carbon_automation_test6_hive"))
   })
 
   //TC_123
   test("select stddev_samp(gamePointId)  as a from Carbon_automation_test6")({
     checkAnswer(
       sql("select stddev_samp(gamePointId)  as a from Carbon_automation_test6"),
-      Seq(Row(813.3076616769742)))
+      sql("select stddev_samp(gamePointId)  as a from Carbon_automation_test6_hive"))
   })
 
   //TC_126
   test("select corr(gamePointId,gamePointId)  as a from Carbon_automation_test6")({
     checkAnswer(
-      sql("select corr(gamePointId,gamePointId)  as a from Carbon_automation_test6"),
-      Seq(Row(0.9999999999999999)))
+      sql("select corr(gamePointId,contractNumber)  as a from Carbon_automation_test6"),
+      sql("select corr(gamePointId,contractNumber)  as a from Carbon_automation_test6_hive")
+    )
   })
 
 
@@ -456,7 +711,7 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
     NonRunningTests)({
     checkAnswer(
       sql("select percentile_approx(gamePointId,0.2,5) as a  from Carbon_automation_test6"),
-      Seq(Row(492.5739612188367)))
+      sql("select percentile_approx(gamePointId,0.2,5) as a  from Carbon_automation_test6_hive"))
   })
 
 
@@ -465,1334 +720,1706 @@ class AllDataTypesTestCase6 extends QueryTest with BeforeAndAfterAll {
   test("select FIRST(imei) a from Carbon_automation_test6", NonRunningTests)({
     checkAnswer(
       sql("select FIRST(imei) a from Carbon_automation_test6"),
-      Seq(Row("1AA100040")))
+      sql("select FIRST(imei) a from Carbon_automation_test6_hive"))
   })
 
 
   //TC_137
-  test("select series,count(imei) a from Carbon_automation_test6 group by series order by a",
+  test("select series,count(imei) as  a from Carbon_automation_test6 group by series order " +
+       "by a",
     NonRunningTests)({
     checkAnswer(
-      sql("select series,count(imei) a from Carbon_automation_test6 group by series order by a"),
-      Seq(Row("1Series", 3), Row("4Series", 8), Row("9Series", 8), Row("3Series", 8), Row("6Series", 9), Row("2Series", 9), Row("7Series", 11), Row("8Series", 11), Row("0Series", 15), Row("5Series", 17)))
+      sql(
+        "select series,count(imei) as a from Carbon_automation_test6 group by series order by " +
+        "a"),
+      Seq(Row("1Series", 3),
+        Row("9Series", 8),
+        Row("3Series", 8),
+        Row("4Series", 8),
+        Row("2Series", 9),
+        Row("6Series", 9),
+        Row("7Series", 11),
+        Row("8Series", 11),
+        Row("0Series", 15),
+        Row("5Series", 17))
+    )
   })
 
   //TC_143
-  test("select deliveryProvince,series,sum(deviceInformationId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series")({
+  test(
+    "select deliveryProvince,series,sum(deviceInformationId) a from Carbon_automation_test6 group" +
+    " by deliveryProvince,series order by deliveryProvince,series")({
     checkAnswer(
-      sql("select deliveryProvince,series,sum(deviceInformationId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 600310), Row("Guangdong Province", "1Series", 100032), Row("Guangdong Province", "2Series", 200085), Row("Guangdong Province", "3Series", 410217), Row("Guangdong Province", "4Series", 100059), Row("Guangdong Province", "5Series", 520235), Row("Guangdong Province", "6Series", 100038), Row("Guangdong Province", "7Series", 110054), Row("Guangdong Province", "8Series", 300151), Row("Guangdong Province", "9Series", 200123), Row("Hubei Province", "0Series", 210087), Row("Hubei Province", "1Series", 100005), Row("Hubei Province", "2Series", 400244), Row("Hubei Province", "3Series", 100077), Row("Hubei Province", "4Series", 200071), Row("Hubei Province", "5Series", 1000), Row("Hubei Province", "6Series", 200130), Row("Hubei Province", "7Series", 1300123), Row("Hubei Province", "8Series", 300091), Row("Hubei Province", "9Series", 200062), Row("Hunan Province", "0Series", 600199), Row("Hunan Province", "1Series", 100013), Row("Hunan Province", "2
 Series", 210075), Row("Hunan Province", "3Series", 200026), Row("Hunan Province", "4Series", 500251), Row("Hunan Province", "5Series", 800339), Row("Hunan Province", "6Series", 600273), Row("Hunan Province", "7Series", 210070), Row("Hunan Province", "8Series", 320149), Row("Hunan Province", "9Series", 400128)))
+      sql(
+        "select deliveryProvince,series,sum(deviceInformationId) a from Carbon_automation_test6 " +
+        "group by deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,sum(deviceInformationId) a from " +
+        "Carbon_automation_test6_hive " +
+        "group by deliveryProvince,series order by deliveryProvince,series"))
   })
 
   //TC_144
-  test("select deliveryProvince,series,sum(channelsId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series")({
+  test(
+    "select deliveryProvince,series,sum(channelsId) a from Carbon_automation_test6 group by " +
+    "deliveryProvince,series order by deliveryProvince,series")({
     checkAnswer(
-      sql("select deliveryProvince,series,sum(channelsId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 20.0), Row("Guangdong Province", "1Series", 7.0), Row("Guangdong Province", "2Series", 13.0), Row("Guangdong Province", "3Series", 21.0), Row("Guangdong Province", "4Series", 7.0), Row("Guangdong Province", "5Series", 25.0), Row("Guangdong Province", "6Series", 3.0), Row("Guangdong Province", "7Series", 3.0), Row("Guangdong Province", "8Series", 10.0), Row("Guangdong Province", "9Series", 12.0), Row("Hubei Province", "0Series", 15.0), Row("Hubei Province", "1Series", 1.0), Row("Hubei Province", "2Series", 12.0), Row("Hubei Province", "3Series", 6.0), Row("Hubei Province", "4Series", 9.0), Row("Hubei Province", "5Series", 3.0), Row("Hubei Province", "6Series", 12.0), Row("Hubei Province", "7Series", 29.0), Row("Hubei Province", "8Series", 17.0), Row("Hubei Province", "9Series", 12.0), Row("Hunan Province", "0Series", 29.0), Row("Hunan Province", "1Series", 6.0), Row("Hunan Province", "2Series", 16.0), Row("Hunan Province", "3Series", 9.0
 ), Row("Hunan Province", "4Series", 18.0), Row("Hunan Province", "5Series", 44.0), Row("Hunan Province", "6Series", 28.0), Row("Hunan Province", "7Series", 13.0), Row("Hunan Province", "8Series", 15.0), Row("Hunan Province", "9Series", 13.0)))
+      sql(
+        "select deliveryProvince,series,sum(channelsId) a from Carbon_automation_test6 group by " +
+        "deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,sum(channelsId) a from Carbon_automation_test6_hive group" +
+        " by " +
+        "deliveryProvince,series order by deliveryProvince,series"))
   })
 
   //TC_145
-  test("select deliveryProvince,series,sum(bomCode) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series")({
+  test(
+    "select deliveryProvince,series,sum(bomCode) a from Carbon_automation_test6 group by " +
+    "deliveryProvince,series order by deliveryProvince,series")({
     checkAnswer(
-      sql("select deliveryProvince,series,sum(bomCode) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 600310.0), Row("Guangdong Province", "1Series", 100032.0), Row("Guangdong Province", "2Series", 200085.0), Row("Guangdong Province", "3Series", 410217.0), Row("Guangdong Province", "4Series", 100059.0), Row("Guangdong Province", "5Series", 520235.0), Row("Guangdong Province", "6Series", 100038.0), Row("Guangdong Province", "7Series", 110054.0), Row("Guangdong Province", "8Series", 300151.0), Row("Guangdong Province", "9Series", 200123.0), Row("Hubei Province", "0Series", 210087.0), Row("Hubei Province", "1Series", 100005.0), Row("Hubei Province", "2Series", 400244.0), Row("Hubei Province", "3Series", 100077.0), Row("Hubei Province", "4Series", 200071.0), Row("Hubei Province", "5Series", 1000.0), Row("Hubei Province", "6Series", 200130.0), Row("Hubei Province", "7Series", 1300123.0), Row("Hubei Province", "8Series", 300091.0), Row("Hubei Province", "9Series", 200062.0), Row("Hunan Province", "0Series", 600199.0), Row("Hunan Province", "1
 Series", 100013.0), Row("Hunan Province", "2Series", 210075.0), Row("Hunan Province", "3Series", 200026.0), Row("Hunan Province", "4Series", 500251.0), Row("Hunan Province", "5Series", 800339.0), Row("Hunan Province", "6Series", 600273.0), Row("Hunan Province", "7Series", 210070.0), Row("Hunan Province", "8Series", 320149.0), Row("Hunan Province", "9Series", 400128.0)))
+      sql(
+        "select deliveryProvince,series,sum(bomCode) a from Carbon_automation_test6 group by " +
+        "deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,sum(bomCode) a from Carbon_automation_test6_hive group by" +
+        " " +
+        "deliveryProvince,series order by deliveryProvince,series"))
   })
 
 
   //TC_148
-  test("select deliveryProvince,series,avg(deviceInformationId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series")({
+  test(
+    "select deliveryProvince,series,avg(deviceInformationId) a from Carbon_automation_test6 group" +
+    " by deliveryProvince,series order by deliveryProvince,series")({
     checkAnswer(
-      sql("select deliveryProvince,series,avg(deviceInformationId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 100051.66666666667), Row("Guangdong Province", "1Series", 100032.0), Row("Guangdong Province", "2Series", 100042.5), Row("Guangdong Province", "3Series", 82043.4), Row("Guangdong Province", "4Series", 100059.0), Row("Guangdong Province", "5Series", 74319.28571428571), Row("Guangdong Province", "6Series", 100038.0), Row("Guangdong Province", "7Series", 55027.0), Row("Guangdong Province", "8Series", 100050.33333333333), Row("Guangdong Province", "9Series", 100061.5), Row("Hubei Province", "0Series", 70029.0), Row("Hubei Province", "1Series", 100005.0), Row("Hubei Province", "2Series", 100061.0), Row("Hubei Province", "3Series", 100077.0), Row("Hubei Province", "4Series", 100035.5), Row("Hubei Province", "5Series", 1000.0), Row("Hubei Province", "6Series", 100065.0), Row("Hubei Province", "7Series", 216687.16666666666), Row("Hubei Province", "8Series", 100030.33333333333), Row("Hubei Province", "9Series", 100031.0), Row("Hunan Province", "
 0Series", 100033.16666666667), Row("Hunan Province", "1Series", 100013.0), Row("Hunan Province", "2Series", 70025.0), Row("Hunan Province", "3Series", 100013.0), Row("Hunan Province", "4Series", 100050.2), Row("Hunan Province", "5Series", 88926.55555555556), Row("Hunan Province", "6Series", 100045.5), Row("Hunan Province", "7Series", 70023.33333333333), Row("Hunan Province", "8Series", 64029.8), Row("Hunan Province", "9Series", 100032.0)))
+      sql(
+        "select deliveryProvince,series,avg(deviceInformationId) a from Carbon_automation_test6 " +
+        "group by deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,avg(deviceInformationId) a from " +
+        "Carbon_automation_test6_hive " +
+        "group by deliveryProvince,series order by deliveryProvince,series"))
   })
 
   //TC_149
-  test("select deliveryProvince,series,avg(channelsId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series", NonRunningTests)({
+  test(
+    "select deliveryProvince,series,avg(channelsId) a from Carbon_automation_test6 group by " +
+    "deliveryProvince,series order by deliveryProvince,series",
+    NonRunningTests)({
     checkAnswer(
-      sql("select deliveryProvince,series,avg(channelsId) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 3.3333333333333335), Row("Guangdong Province", "1Series", 7.0), Row("Guangdong Province", "2Series", 6.5), Row("Guangdong Province", "3Series", 4.2), Row("Guangdong Province", "4Series", 7.0), Row("Guangdong Province", "5Series", 3.5714285714285716), Row("Guangdong Province", "6Series", 3.0), Row("Guangdong Province", "7Series", 1.5), Row("Guangdong Province", "8Series", 3.3333333333333335), Row("Guangdong Province", "9Series", 6.0), Row("Hubei Province", "0Series", 5.0), Row("Hubei Province", "1Series", 1.0), Row("Hubei Province", "2Series", 3.0), Row("Hubei Province", "3Series", 6.0), Row("Hubei Province", "4Series", 4.5), Row("Hubei Province", "5Series", 3.0), Row("Hubei Province", "6Series", 6.0), Row("Hubei Province", "7Series", 4.833333333333333), Row("Hubei Province", "8Series", 5.666666666666667), Row("Hubei Province", "9Series", 6.0), Row("Hunan Province", "0Series", 4.833333333333333), Row("Hunan Province", "1Series", 6.0), Ro
 w("Hunan Province", "2Series", 5.333333333333333), Row("Hunan Province", "3Series", 4.5), Row("Hunan Province", "4Series", 3.6), Row("Hunan Province", "5Series", 4.888888888888889), Row("Hunan Province", "6Series", 4.666666666666667), Row("Hunan Province", "7Series", 4.333333333333333), Row("Hunan Province", "8Series", 3.0), Row("Hunan Province", "9Series", 3.25)))
+      sql(
+        "select deliveryProvince,series,avg(channelsId) a from Carbon_automation_test6 group by " +
+        "deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,avg(channelsId) a from Carbon_automation_test6_hive group" +
+        " by " +
+        "deliveryProvince,series order by deliveryProvince,series"))
   })
 
   //TC_150
-  test("select deliveryProvince,series,avg(bomCode) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series", NonRunningTests)({
+  test(
+    "select deliveryProvince,series,avg(bomCode) a from Carbon_automation_test6 group by " +
+    "deliveryProvince,series order by deliveryProvince,series",
+    NonRunningTests)({
     checkAnswer(
-      sql("select deliveryProvince,series,avg(bomCode) a from Carbon_automation_test6 group by deliveryProvince,series order by deliveryProvince,series"),
-      Seq(Row("Guangdong Province", "0Series", 100051.66666666667), Row("Guangdong Province", "1Series", 100032.0), Row("Guangdong Province", "2Series", 100042.5), Row("Guangdong Province", "3Series", 82043.4), Row("Guangdong Province", "4Series", 100059.0), Row("Guangdong Province", "5Series", 74319.28571428571), Row("Guangdong Province", "6Series", 100038.0), Row("Guangdong Province", "7Series", 55027.0), Row("Guangdong Province", "8Series", 100050.33333333333), Row("Guangdong Province", "9Series", 100061.5), Row("Hubei Province", "0Series", 70029.0), Row("Hubei Province", "1Series", 100005.0), Row("Hubei Province", "2Series", 100061.0), Row("Hubei Province", "3Series", 100077.0), Row("Hubei Province", "4Series", 100035.5), Row("Hubei Province", "5Series", 1000.0), Row("Hubei Province", "6Series", 100065.0), Row("Hubei Province", "7Series", 216687.16666666666), Row("Hubei Province", "8Series", 100030.33333333333), Row("Hubei Province", "9Series", 100031.0), Row("Hunan Province", "
 0Series", 100033.16666666667), Row("Hunan Province", "1Series", 100013.0), Row("Hunan Province", "2Series", 70025.0), Row("Hunan Province", "3Series", 100013.0), Row("Hunan Province", "4Series", 100050.2), Row("Hunan Province", "5Series", 88926.55555555556), Row("Hunan Province", "6Series", 100045.5), Row("Hunan Province", "7Series", 70023.33333333333), Row("Hunan Province", "8Series", 64029.8), Row("Hunan Province", "9Series", 100032.0)))
+      sql(
+        "select deliveryProvince,series,avg(bomCode) a from Carbon_automation_test6 group by " +
+        "deliveryProvince,series order by deliveryProvince,series"),
+      sql(
+        "select deliveryProvince,series,avg(bomCode) a from Carbon_automation_test6_hive group by" +
+        " " +
+        "deliveryProvince,series order by deliveryProvince,series"))
   })
 
   //TC_161
-  test("select Latest_DAY from Carbon_automation_test6 where Latest_DAY in (select  Latest_DAY from Carbon_automation_test6) order by Latest_DAY", NonRunningTests)({
+  test(
+    "select Latest_DAY from Carbon_automation_test6 where Latest_DAY in (select  Latest_DAY from " +
+    "Carbon_automation_test6) order by Latest_DAY",
+    NonRunningTests)({
+    pending
     checkAnswer(
-      sql("select Latest_DAY from Carbon_automation_test6 where Latest_DAY in (select  Latest_DAY from Carbon_automation_test6) order by Latest_DAY"),
-      Seq(Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1), Row(1)))
+      sql(
+        "select Latest_DAY from Carbon_automation_test6 where Latest_DAY in (select  Latest_DAY" +
+        "from Carbon_automation_test6) order by Latest_DAY"),
+      sql(
+        "select Latest_DAY from Carbon_automation_test6_hive where Latest_DAY in (select  " +
+        "Latest_DAY from Carbon_automation_test6_hive) order by Latest_DAY"))
   })
 
 
-
   //TC_164
-  test("select channelsId from Carbon_automation_test6 where channelsId in (select  channelsId from Carbon_automation_test6) order by channelsId", NonRunningTests)({
+  test(
+    "select channelsId from Carbon_automation_test6 where channelsId in (select  channelsId from " +
+    "Carbon_automation_test6) order by channelsId",
+    NonRunningTests)({
+    pending
     checkAnswer(
-      sql("select channelsId from Carbon_automation_test6 where channelsId in (select  channelsId from Carbon_automation_test6) order by channelsId"),
-      Seq(Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("1"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("2"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("3"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("4"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("5"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("6"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"), Row("7"
 )))
+      sql(
+        "select channelsId from Carbon_automation_test6 where channelsId in (select  channelsId " +
+        "from Carbon_automation_test6) order by channelsId"),
+      sql(
+        "select channelsId from Carbon_automation_test6_hive where channelsId in (select  " +
+        "channelsId from Carbon_automation_test6_hive) order by channelsId")
+    )
   })
 
   //TC_165
-  test("select  imei, sum(deviceInformationId) as a  from Carbon_automation_test6 where deviceInformationId in (select deviceInformationId  from Carbon_automation_test6) group by deviceInformationId,imei", NonRunningTests)({
+  test(
+    "select  imei, sum(deviceInformationId) as a  from Carbon_automation_test6 where " +
+    "deviceInformationId in (select deviceInformationId  from Carbon_automation_test6) group by " +
+    "deviceInformationId,imei",
+    NonRunningTests)({
+    pending
     checkAnswer(
-      sql("select  imei, sum(deviceInformationId) as a  from Carbon_automation_test6 where deviceInformationId in (select deviceInformationId  from Carbon_automation_test6) group by deviceInformationId,imei"),
-      Seq(Row("1AA100082", 100082), Row("1AA1000", 1000), Row("1AA1000000", 1000000), Row("1AA100008", 100008), Row("1AA100018", 100018), Row("1AA100028", 100028), Row("1AA100038", 100038), Row("1AA100048", 100048), Row("1AA100058", 100058), Row("1AA100068", 100068), Row("1AA100078", 100078), Row("1AA100003", 100003), Row("1AA10004", 10004), Row("1AA100013", 100013), Row("1AA100023", 100023), Row("1AA100033", 100033), Row("1AA100043", 100043), Row("1AA100053", 100053), Row("1AA100063", 100063), Row("1AA100073", 100073), Row("1AA100083", 100083), Row("1AA100", 100), Row("1AA100009", 100009), Row("1AA100019", 100019), Row("1AA100029", 100029), Row("1AA100039", 100039), Row("1AA100049", 100049), Row("1AA100059", 100059), Row("1AA100069", 100069), Row("1AA100079", 100079), Row("1AA100004", 100004), Row("1AA10005", 10005), Row("1AA100014", 100014), Row("1AA100024", 100024), Row("1AA100034", 100034), Row("1AA100044", 100044), Row("1AA100054", 100054), Row("1AA100064", 100064), Row("1AA100
 074", 100074), Row("1AA100084", 100084), Row("1AA10000", 10000), Row("1AA1", 1), Row("1AA10006", 10006), Row("1AA100005", 100005), Row("1AA100015", 100015), Row("1AA100025", 100025), Row("1AA100035", 100035), Row("1AA100045", 100045), Row("1AA100055", 100055), Row("1AA100065", 100065), Row("1AA100075", 100075), Row("1AA100000", 100000), Row("1AA10001", 10001), Row("1AA100010", 100010), Row("1AA100020", 100020), Row("1AA100030", 100030), Row("1AA100040", 100040), Row("1AA100050", 100050), Row("1AA100060", 100060), Row("1AA100070", 100070), Row("1AA100080", 100080), Row("1AA100006", 100006), Row("1AA10007", 10007), Row("1AA100016", 100016), Row("1AA100026", 100026), Row("1AA100036", 100036), Row("1AA100046", 100046), Row("1AA100056", 100056), Row("1AA100066", 100066), Row("1AA10", 10), Row("1AA100076", 100076), Row("1AA10002", 10002), Row("1AA100001", 100001), Row("1AA100011", 100011), Row("1AA100021", 100021), Row("1AA100031", 100031), Row("1AA100041", 100041), Row("1AA100051", 10005
 1), Row("1AA100061", 100061), Row("1AA100071", 100071), Row("1AA100081", 100081), Row("1AA10008", 10008), Row("1AA100007", 100007), Row("1AA100017", 100017), Row("1AA100027", 100027), Row("1AA100037", 100037), Row("1AA100047", 100047), Row("1AA100057", 100057), Row("1AA100067", 100067), Row("1AA100077", 100077), Row("1AA100002", 100002), Row("1AA10003", 10003), Row("1AA100012", 100012), Row("1AA100022", 100022), Row("1AA100032", 100032), Row("1AA100042", 100042), Row("1AA100052", 100052), Row("1AA100062", 100062), Row("1AA100072", 100072)))
+      sql(
+        "select  imei, sum(deviceInformationId) as a  from Carbon_automation_test6 where " +
+        "deviceInformationId in (select deviceInformationId  from Carbon_automation_test6)      " +
+        "group " +
+        "by deviceInformationId,imei"),
+      sql(
+        "select  imei, sum(deviceInformationId) as a  from Carbon_automation_test6_hive where " +
+        "deviceInformationId in (select deviceInformationId  from Carbon_automation_test6_hive)  " +
+        "    " +
+        "group by deviceInformationId,imei"))
   })
 
   //TC_170
-  test("select Upper(series) a ,channelsId from Carbon_automation_test6 group by series,channelsId order by channelsId", NonRunningTests)({
+  test(
+    "select Upper(series) a ,channelsId from Carbon_automation_test6 group by series,channelsId  " +
+    "    " +
+    "order by channelsId",
+    NonRunningTests)({
     checkAnswer(
-      sql("select Upper(series) a ,channelsId from Carbon_automation_test6 group by series,channelsId order by channelsId"),
-      Seq(Row("0SERIES", "1"), Row("2SERIES", "1"), Row("8SERIES", "1"), Row("3SERIES", "1"), Row("7SERIES", "1"), Row("4SERIES", "1"), Row("1SERIES", "1"), Row("5SERIES", "1"), Row("9SERIES", "1"), Row("8SERIES", "2"), Row("7SERIES", "2"), Row("0SERIES", "2"), Row("4SERIES", "2"), Row("5SERIES", "2"), Row("6SERIES", "2"), Row("3SERIES", "3"), Row("7SERIES", "3"), Row("0SERIES", "3"), Row("5SERIES", "3"), Row("2SERIES", "3"), Row("8SERIES", "3"), Row("9SERIES", "3"), Row("6SERIES", "3"), Row("3SERIES", "4"), Row("5SERIES", "4"), Row("8SERIES", "4"), Row("6SERIES", "4"), Row("7SERIES", "4"), Row("0SERIES", "4"), Row("0SERIES", "5"), Row("6SERIES", "5"), Row("3SERIES", "5"), Row("2SERIES", "5"), Row("8SERIES", "5"), Row("5SERIES", "5"), Row("3SERIES", "6"), Row("0SERIES", "6"), Row("4SERIES", "6"), Row("5SERIES", "6"), Row("2SERIES", "6"), Row("9SERIES", "6"), Row("6SERIES", "6"), Row("7SERIES", "6"), Row("1SERIES", "6"), Row("8SERIES", "6"), Row("7SERIES", "7"), Row("0SERIES", "7"), 
 Row("1SERIES", "7"), Row("2SERIES", "7"), Row("8SERIES", "7"), Row("6SERIES", "7"), Row("4SERIES", "7"), Row("5SERIES", "7")))
+      sql(
+        "select Upper(series) as a ,channelsId from Carbon_automation_test6 group by series," +
+        "channelsId order by channelsId"),
+      Seq(Row("8SERIES", "1"),
+        Row("0SERIES", "1"),
+        Row("5SERIES", "1"),
+        Row("3SERIES", "1"),
+        Row("1SERIES", "1"),
+        Row("9SERIES", "1"),
+        Row("4SERIES", "1"),
+        Row("7SERIES", "1"),
+        Row("2SERIES", "1"),
+        Row("8SERIES", "2"),
+        Row("0SERIES", "2"),
+        Row("5SERIES", "2"),
+        Row("6SERIES", "2"),
+        Row("4SERIES", "2"),
+        Row("7SERIES", "2"),
+        Row("2SERIES", "3"),
+        Row("0SERIES", "3"),
+        Row("8SERIES", "3"),
+        Row("5SERIES", "3"),
+        Row("3SERIES", "3"),
+        Row("6SERIES", "3"),
+        Row("9SERIES", "3"),
+        Row("7SERIES", "3"),
+        Row("8SERIES", "4"),
+        Row("0SERIES", "4"),
+        Row("5SERIES", "4"),
+        Row("3SERIES", "4"),
+        Row("6SERIES", "4"),
+        Row("7SERIES", "4"),
+        Row("2SERIES", "5"),
+        Row("0SERIES", "5"),
+        Row("8SERIES", "5"),
+        Row("5SERIES", "5"),
+        Row("3SERIES", "5"),
+        Row("6SERIES", "5"),
+        Row("7SERIES", "6"),
+        Row("2SERIES", "6"),
+        Row("0SERIES", "6"),
+        Row("8SERIES", "6"),
+        Row("5SERIES", "6"),
+        Row("3SERIES", "6"),
+        Row("6SERIES", "6"),
+        Row("9SERIES", "6"),
+        Row("1SERIES", "6"),
+        Row("4SERIES", "6"),
+        Row("7SERIES", "7"),
+        Row("2SERIES", "7"),
+        Row("0SERIES", "7"),
+        Row("8SERIES", "7"),
+        Row("5SERIES", "7"),
+        Row("6SERIES", "7"),
+        Row("1SERIES", "7"),
+        Row("4SERIES", "7"))
+    )
   })
 
 
   //TC_190
-  test("select series,gamePointId as a from Carbon_automation_test6  order by series asc limit 10", NonRunningTests)({
+  test("select series,gamePointId as a from Carbon_automation_test6  order by series asc limit  " +
+       "10 ",
+    NonRunningTests)({
     checkAnswer(
-      sql("select series,gamePointId as a from Carbon_automation_test6  order by series asc limit 10"),
-      Seq(Row("0Series", 901.0), Row("0Series", 2972.0), Row("0Series", 1841.0), Row("0Series", 1341.0), Row("0Series", 505.0), Row("0Series", 1778.0), Row("0Series", 1724.0), Row("0Series", 2436.0), Row("0Series", 202.0), Row("0Series", 2890.0)))
+      sql(
+        "select series,gamePointId as a from Carbon_automation_test6  order by series asc limit  " +
+        "    " +
+        "10"),
+      Seq(Row("0Series", 100001),
+        Row("0Series", 100002),
+        Row("0Series", 100009),
+        Row("0Series", 100011),
+        Row("0Series", 10002),
+        Row("0Series", 100021),
+        Row("0Series", 100025),
+        Row("0Series", 100027),
+        Row("0Series", 100049),
+        Row("0Series", 100065))
+    )
   })
 
   //TC_191
-  test("select series,gamePointId as a from Carbon_automation_test6  order by series desc limit 10", NonRunningTests)({
+  test(
+    "select series,gamePointId as a from Carbon_automation_test6  order by series desc limit     " +
+    " 10 ",
+    NonRunningTests)({
     checkAnswer(
-      sql("select series,gamePointId as a from Carbon_automation_test6  order by series desc limit 10"),
-      Seq(Row("9Series", 1991.0), Row("9Series", 954.0), Row("9Series", 136.0), Row("9Series", 2288.0), Row("9Series", 571.0), Row("9Series", 2952.0), Row("9Series", 1823.0), Row("9Series", 2205.0), Row("8Series", 412.0), Row("8Series", 1697.0)))
+      sql(
+        "select series,gamePointId as a from Carbon_automation_test6  order by series desc      " +
+        "limit " +
+        "10"),
+      Seq(Row("9Series", 100000),
+        Row("9Series", 100007),
+        Row("9Series", 100017),
+        Row("9Series", 100043),
+        Row("9Series", 100047),
+        Row("9Series", 100057),
+        Row("9Series", 100062),
+        Row("9Series", 100080),
+        Row("8Series", 100008),
+        Row("8Series", 100018)))
   })
 
   //TC_209
-  test("select * from (select if( Latest_areaId=3,NULL,Latest_areaId) as babu,NULL a from Carbon_automation_test6) qq where babu<=>a", NonRunningTests)({
+  test(
+    "select * from (select if( Latest_areaId=3,NULL,Latest_areaId) as babu,NULL a from " +
+    "Carbon_automation_test6) qq where babu<=>a",
+    NonRunningTests)({
     checkAnswer(
-      sql("select * from (select if( Latest_areaId=3,NULL,Latest_areaId) as babu,NULL a from Carbon_automation_test6) qq where babu<=>a"),
-      Seq(Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null), Row("null", null)))
+      sql(
+        "select * from (select if( Latest_areaId=3,NULL,Latest_areaId) as babu,NULL a from " +
+        "Carbon_automation_test6) qq where babu<=>a"),
+      sql(
+        "select * from (select if( Latest_areaId=3,NULL,Latest_areaId) as babu,NULL a from " +
+        "Carbon_automation_test6_hive) qq where babu<=>a"))
   })
 
 
   //TC_233
-  test("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR channelsId <=1 and series='7Series'", NonRunningTests)({
+  test(
+    "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId " +
+    ">=10 OR channelsId <=1 and series='7Series'",
+    NonRunningTests)({
     checkAnswer(
-      sql("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR channelsId <=1 and series='7Series'"),
-      Seq(Row("1AA10000", 2175.0, "1", "7Series"), Row("1AA100031", 1080.0, "1", "7Series")))
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where " +
+        "channelsId >=10 OR channelsId <=1 and series='7Series'"),
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6_hive where " +
+        "channelsId >=10 OR channelsId <=1 and series='7Series'"))
   })
 
   //TC_234
-  test("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR channelsId <=1 or series='7Series'", NonRunningTests)({
+  test(
+    "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId " +
+    ">=10 OR channelsId <=1 or series='7Series'",
+    NonRunningTests)({
     checkAnswer(
-      sql("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR channelsId <=1 or series='7Series'"),
-      Seq(Row("1AA1", 2738.562, "4", "7Series"), Row("1AA10", 1714.635, "4", "7Series"), Row("1AA10000", 2175.0, "1", "7Series"), Row("1AA1000000", 1600.0, "6", "7Series"), Row("1AA100005", 2593.0, "1", "1Series"), Row("1AA100008", 1442.0, "1", "8Series"), Row("1AA100011", 202.0, "1", "0Series"), Row("1AA100015", 2863.0, "1", "4Series"), Row("1AA100025", 1724.0, "1", "0Series"), Row("1AA100026", 1768.0, "7", "7Series"), Row("1AA10003", 2071.0, "4", "7Series"), Row("1AA100030", 1333.0, "3", "7Series"), Row("1AA100031", 1080.0, "1", "7Series"), Row("1AA100037", 1015.0, "6", "7Series"), Row("1AA100039", 1750.0, "1", "8Series"), Row("1AA100041", 2734.0, "1", "5Series"), Row("1AA100047", 1823.0, "1", "9Series"), Row("1AA100048", 2399.0, "1", "3Series"), Row("1AA100050", 29.0, "1", "2Series"), Row("1AA100054", 1368.0, "2", "7Series"), Row("1AA100055", 1728.0, "7", "7Series")))
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where " +
+        "channelsId >=10 OR channelsId <=1 or series='7Series'"),
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6_hive where " +
+        "channelsId >=10 OR channelsId <=1 or series='7Series'"))
   })
 
   //TC_235
-  test("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR (channelsId <=1 and series='1Series')", NonRunningTests)({
+  test(
+    "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId " +
+    ">=10 OR (channelsId <=1 and series='1Series')",
+    NonRunningTests)({
     checkAnswer(
-      sql("select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where channelsId >=10 OR (channelsId <=1 and series='1Series')"),
-      Seq(Row("1AA100005", 2593.0, "1", "1Series")))
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6 where " +
+        "channelsId >=10 OR (channelsId <=1 and series='1Series')"),
+      sql(
+        "select imei,gamePointId, channelsId,series  from Carbon_automation_test6_hive where " +
+        "channelsId >=10 OR (channelsId <=1 and series='1Series')"))
   })
 
   //TC_236
-  test("select sum(gamePointId) a from Carbon_automation_test6 where channelsId >=10 OR (channelsId <=1 and series='1Series')", NonRunningTests)({
+  test(
+    "select sum(gamePointId) a from Carbon_automation_test6 where channelsId >=10 OR      " +
+    "(channelsId " +
+    "<=1 and series='1Series')",
+    NonRunningTests)({
     checkAnswer(
-      sql("select sum(gamePointId) a from Carbon_automation_test6 where channelsId >=10 OR (channelsId <=1 and series='1Series')"),
-      Seq(Row(2593.0)))
+      sql(
+        "select sum(gamePointId) a from Carbon_automation_test6 where channelsId >=10 OR " +
+        "(channelsId <=1 and series='1Series')"),
+      sql(
+        "select sum(gamePointId) a from Carbon_automation_test6_hive where channelsId >=10 OR " +
+        "(channelsId <=1 and series='1Series')"))
   })
 
   //TC_237
-  test("select * from (select imei,if(imei='1AA100060',NULL,imei) a from Carbon_automation_test6) aa  where a IS NULL", NonRunningTests)({
+  test(
+    "select * from (select imei,if(imei='1AA100060',NULL,imei) a from Carbon_automation_test6)  " +
+    "aa" +
+    "  where a IS NULL",
+    NonRunningTests)({
     checkAnswer(
-      sql("select * from (select imei,if(imei='1AA100060',NULL,imei) a from Carbon_automation_test6) aa  where a IS NULL"),
-      Seq(Row("1AA100060", "null")))
+      sql(
+        "select * from (select imei,if(imei='1AA100060',NULL,imei) a from " +
+        "Carbon_automation_test6) aa  where a IS NULL"),
+      sql(
+        "select * from (select imei,if(imei='1AA100060',NULL,imei) a from " +
+        "Carbon_automation_test6_hive) aa  where a IS NULL"))
   })
 
 
   //TC_280
-  test("SELECT Activecity, imei, ActiveCountry, ActiveDistrict FROM (select * from Carbon_automation_test6) SUB_QRY ORDER BY ActiveCountry ASC, ActiveDistrict ASC, Activecity ASC", NonRunningTests)({
+  test(
+    "SELECT Activecity, imei, ActiveCountry, ActiveDistrict FROM (select * from " +
+    "Carbon_automation_test6) SUB_QRY ORDER BY ActiveCountry ASC, ActiveDistrict ASC,      " +
+    "Activecity " +
+    "ASC",
+    NonRunningTests)({
     checkAnswer(
-      sql("SELECT Activecity, imei, ActiveCountry, ActiveDistrict FROM (select * from Carbon_automation_test6) SUB_QRY ORDER BY ActiveCountry ASC, ActiveDistrict ASC, Activecity ASC"),
-      Seq(Row("wuhan", "1AA10", "Chinese", "hongshan"), Row("wuhan", "1AA100001", "Chinese", "hongshan"), Row("wuhan", "1AA100004", "Chinese", "hongshan"), Row("wuhan", "1AA100008", "Chinese", "hongshan"), Row("wuhan", "1AA100024", "Chinese", "hongshan"), Row("wuhan", "1AA100025", "Chinese", "hongshan"), Row("wuhan", "1AA100039", "Chinese", "hongshan"), Row("wuhan", "1AA100045", "Chinese", "hongshan"), Row("wuhan", "1AA100046", "Chinese", "hongshan"), Row("wuhan", "1AA100047", "Chinese", "hongshan"), Row("wuhan", "1AA100056", "Chinese", "hongshan"), Row("wuhan", "1AA100058", "Chinese", "hongshan"), Row("wuhan", "1AA10006", "Chinese", "hongshan"), Row("wuhan", "1AA100061", "Chinese", "hongshan"), Row("wuhan", "1AA100070", "Chinese", "hongshan"), Row("wuhan", "1AA100078", "Chinese", "hongshan"), Row("shenzhen", "1AA100013", "Chinese", "longgang"), Row("shenzhen", "1AA100020", "Chinese", "longgang"), Row("shenzhen", "1AA100028", "Chinese", "longgang"), Row("shenzhen", "1AA100032", "Chi
 nese", "longgang"), Row("shenzhen", "1AA100035", "Chinese", "longgang"), Row("shenzhen", "1AA10004", "Chinese", "longgang"), Row("shenzhen", "1AA100044", "Chinese", "longgang"), Row("shenzhen", "1AA100054", "Chinese", "longgang"), Row("shenzhen", "1AA100060", "Chinese", "longgang"), Row("shenzhen", "1AA100073", "Chinese", "longgang"), Row("shenzhen", "1AA100074", "Chinese", "longgang"), Row("shenzhen", "1AA100083", "Chinese", "longgang"), Row("guangzhou", "1AA100055", "Chinese", "longhua"), Row("guangzhou", "1AA100075", "Chinese", "longhua"), Row("guangzhou", "1AA1", "Chinese", "longhua"), Row("guangzhou", "1AA100010", "Chinese", "longhua"), Row("guangzhou", "1AA100017", "Chinese", "longhua"), Row("guangzhou", "1AA100022", "Chinese", "longhua"), Row("guangzhou", "1AA100026", "Chinese", "longhua"), Row("guangzhou", "1AA100030", "Chinese", "longhua"), Row("zhuzhou", "1AA100002", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100003", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100027", "Ch
 inese", "tianyuan"), Row("zhuzhou", "1AA100042", "Chinese", "tianyuan"), Row("zhuzhou", "1AA10005", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100052", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100053", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100062", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100063", "Chinese", "tianyuan"), Row("zhuzhou", "1AA100081", "Chinese", "tianyuan"), Row("xiangtan", "1AA10000", "Chinese", "xiangtan"), Row("xiangtan", "1AA1000000", "Chinese", "xiangtan"), Row("xiangtan", "1AA100007", "Chinese", "xiangtan"), Row("xiangtan", "1AA100009", "Chinese", "xiangtan"), Row("xiangtan", "1AA10001", "Chinese", "xiangtan"), Row("xiangtan", "1AA100011", "Chinese", "xiangtan"), Row("xiangtan", "1AA100012", "Chinese", "xiangtan"), Row("xiangtan", "1AA100016", "Chinese", "xiangtan"), Row("xiangtan", "1AA10003", "Chinese", "xiangtan"), Row("xiangtan", "1AA100031", "Chinese", "xiangtan"), Row("xiangtan", "1AA100038", "Chinese", "xiangtan"), Row("xiangtan", "1AA100041", "Ch
 inese", "xiangtan"), Row("xiangtan", "1AA100048", "Chinese", "xiangtan"), Row("xiangtan", "1AA100049", "Chinese", "xiangtan"), Row("xiangtan", "1AA100051", "Chinese", "xiangtan"), Row("xiangtan", "1AA100059", "Chinese", "xiangtan"), Row("xiangtan", "1AA100068", "Chinese", "xiangtan"), Row("xiangtan", "1AA10007", "Chinese", "xiangtan"), Row("xiangtan", "1AA100072", "Chinese", "xiangtan"), Row("xiangtan", "1AA100080", "Chinese", "xiangtan"), Row("xiangtan", "1AA100082", "Chinese", "xiangtan"), Row("xiangtan", "1AA100084", "Chinese", "xiangtan"), Row("yichang", "1AA100040", "Chinese", "yichang"), Row("yichang", "1AA100043", "Chinese", "yichang"), Row("yichang", "1AA100050", "Chinese", "yichang"), Row("yichang", "1AA100066", "Chinese", "yichang"), Row("yichang", "1AA100069", "Chinese", "yichang"), Row("yichang", "1AA100076", "Chinese", "yichang"), Row("yichang", "1AA100", "Chinese", "yichang"), Row("yichang", "1AA100000", "Chinese", "yichang"), Row("yichang", "1AA100018", "Chinese", "yi
 chang"), Row("yichang", "1AA10002", "Chinese", "yichang"), Row("yichang", "1AA100023", "Chinese", "yichang"), Row("yichang", "1AA100033", "Chinese", "yichang"), Row("changsha", "1AA100057", "Chinese", "yuhua"), Row("changsha", "1AA100064", "Chinese", "yuhua"), Row("changsha", "1AA100065", "Chinese", "yuhua"), Row("changsha", "1AA100067", "Chinese", "yuhua"), Row("changsha", "1AA100071", "Chinese", "yuhua"), Row("changsha", "1AA100077", "Chinese", "yuhua"), Row("changsha", "1AA100079", "Chinese", "yuhua"), Row("changsha", "1AA10008", "Chinese", "yuhua"), Row("changsha", "1AA1000", "Chinese", "yuhua"), Row("changsha", "1AA100005", "Chinese", "yuhua"), Row("changsha", "1AA100006", "Chinese", "yuhua"), Row("changsha", "1AA100014", "Chinese", "yuhua"), Row("changsha", "1AA100015", "Chinese", "yuhua"), Row("changsha", "1AA100019", "Chinese", "yuhua"), Row("changsha", "1AA100021", "Chinese", "yuhua"), Row("changsha", "1AA100029", "Chinese", "yuhua"), Row("changsha", "1AA100034", "Chinese",
  "yuhua"), Row("changsha", "1AA100036", "Chinese", "yuhua"), Row("changsha", "1AA100037", "Chinese", "yuhua")))
+      sql(
+        "SELECT Activecity, imei, ActiveCountry, ActiveDistrict FROM (select * from " +
+        "Carbon_automation_test6) SUB_QRY ORDER BY ActiveCountry ASC, ActiveDistrict ASC, " +
+        "Activecity ASC"),
+      sql(
+        "SELECT Activecity, imei, ActiveCountry, ActiveDistrict FROM (select * from " +
+        "Carbon_automation_test6_hive) SUB_QRY ORDER BY ActiveCountry ASC, ActiveDistrict ASC, " +
+        "Activecity ASC"))
   })
 
   //TC_281
-  test("SELECT Activecity, ActiveCountry, ActiveDistrict, MIN(imei) AS Min_imei, MAX(imei) AS Max_imei FROM (select * from Carbon_automation_test6) SUB_QRY GROUP BY Activecity, ActiveCountry, ActiveDistrict ORDER BY Activecity ASC, ActiveCountry ASC, ActiveDistrict ASC", NonRunningTests)({
+  test(
+    "SELECT Activecity, ActiveCountry, ActiveDistrict, MIN(imei) AS Min_imei, MAX(imei) AS " +
+    "Max_imei FROM (select * from Carbon_automation_test6) SUB_QRY GROUP BY Activecity, " +
+    "ActiveCountry, ActiveDistrict ORDER BY Activecity ASC, ActiveCountry ASC, ActiveDistrict    " +
+    "ASC",
+    NonRunningTests)({
     checkAnswer(
-      sql("SELECT Activecity, ActiveCountry, ActiveDistrict, MIN(imei) AS Min_imei, MAX(imei) AS Max_imei FROM (select * from Carbon_automation_test6) SUB_QRY GROUP BY Activecity, ActiveCountry, ActiveDistrict ORDER BY Activecity ASC, ActiveCountry ASC, ActiveDistrict ASC"),
-      Seq(Row("changsha", "Chinese", "yuhua", "1AA1000", "1AA10008"), Row("guangzhou", "Chinese", "longhua", "1AA1", "1AA100075"), Row("shenzhen", "Chinese", "longgang", "1AA100013", "1AA100083"), Row("wuhan", "Chinese", "hongshan", "1AA10", "1AA100078"), Row("xiangtan", "Chinese", "xiangtan", "1AA10000", "1AA100084"), Row("yichang", "Chinese", "yichang", "1AA100", "1AA100076"), Row("zhuzhou", "Chinese", "tianyuan", "1AA100002", "1AA100081")))
+      sql(
+        "SELECT Activecity, ActiveCountry, ActiveDistrict, MIN(imei) AS Min_imei, MAX(imei) AS " +
+        "Max_imei FROM (select * from Carbon_automation_test6) SUB_QRY GROUP BY Activecity, " +
+        "ActiveCountry, ActiveDistrict ORDER BY Activecity ASC, ActiveCountry ASC,    " +
+        "ActiveDistrict" +
+        " ASC"),
+      sql(
+        "SELECT Activecity, ActiveCountry, ActiveDistrict, MIN(imei) AS Min_imei, MAX(imei) AS " +
+        "Max_imei FROM (select * from Carbon_automation_test6_hive) SUB_QRY GROUP BY    " +
+        "Activecity, " +
+        "ActiveCountry, ActiveDistrict ORDER BY Activecity ASC, ActiveCountry ASC,    " +
+        "ActiveDistrict" +
+        " ASC"))
   })
 
 
   //TC_322
-  test("SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE series = \"5Series\" GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC")({
+  test(
+    "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR    " +
+    "FROM" +
+    " (select * from Carbon_automation_test6) SUB_QRY WHERE series = \"5Series\" GROUP BY " +
+    "ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict    " +
+    "ASC, " +
+    "deliveryCity ASC")({
     checkAnswer(
-      sql("SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE series = \"5Series\" GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC"),
-      Seq(Row("Chinese", "hongshan", "guangzhou", 2015), Row("Chinese", "longgang", "changsha", 2015), Row("Chinese", "longgang", "guangzhou", 2015), Row("Chinese", "longgang", "shenzhen", 2015), Row("Chinese", "longgang", "zhuzhou", 2015), Row("Chinese", "longhua", "zhuzhou", 2015), Row("Chinese", "tianyuan", "shenzhen", 2015), Row("Chinese", "tianyuan", "zhuzhou", 2015), Row("Chinese", "xiangtan", "shenzhen", 2015), Row("Chinese", "xiangtan", "xiangtan", 2015), Row("Chinese", "yichang", "guangzhou", 2015), Row("Chinese", "yichang", "xiangtan", 2015), Row("Chinese", "yuhua", "changsha", 2015), Row("Chinese", "yuhua", "shenzhen", 2015), Row("Chinese", "yuhua", "wuhan", 2015), Row("Chinese", "yuhua", "zhuzhou", 4030)))
+      sql(
+        "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS    " +
+        "Sum_Latest_YEAR " +
+        "FROM (select * from Carbon_automation_test6) SUB_QRY WHERE series = \"5Series\" GROUP   " +
+        " BY" +
+        " ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC,    " +
+        "ActiveDistrict " +
+        "ASC, deliveryCity ASC"),
+      sql(
+        "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS    " +
+        "Sum_Latest_YEAR " +
+        "FROM (select * from Carbon_automation_test6_hive) SUB_QRY WHERE series = \"5Series\" " +
+        "GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, " +
+        "ActiveDistrict ASC, deliveryCity ASC"))
   })
 
   //TC_323
-  test("SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE deliveryCity = \"zhuzhou\" GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC")({
+  test(
+    "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR    " +
+    "FROM" +
+    " (select * from Carbon_automation_test6) SUB_QRY WHERE deliveryCity = \"zhuzhou\" GROUP BY  " +
+    "  " +
+    "ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict    " +
+    "ASC, " +
+    "deliveryCity ASC")({
     checkAnswer(
-      sql("SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE deliveryCity = \"zhuzhou\" GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC"),
-      Seq(Row("Chinese", "hongshan", "zhuzhou", 2015), Row("Chinese", "longgang", "zhuzhou", 6045), Row("Chinese", "longhua", "zhuzhou", 6045), Row("Chinese", "tianyuan", "zhuzhou", 6045), Row("Chinese", "yichang", "zhuzhou", 2015), Row("Chinese", "yuhua", "zhuzhou", 8060)))
+      sql(
+        "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS    " +
+        "Sum_Latest_YEAR " +
+        "FROM (select * from Carbon_automation_test6) SUB_QRY WHERE deliveryCity = \"zhuzhou\" " +
+        "GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY ActiveCountry ASC, " +
+        "ActiveDistrict ASC, deliveryCity ASC"),
+      sql(
+        "SELECT ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS    " +
+        "Sum_Latest_YEAR " +
+        "FROM (select * from Carbon_automation_test6_hive) SUB_QRY WHERE deliveryCity = " +
+        "\"zhuzhou\" GROUP BY ActiveCountry, ActiveDistrict, deliveryCity ORDER BY    " +
+        "ActiveCountry " +
+        "ASC, ActiveDistrict ASC, deliveryCity ASC"))
   })
 
   //TC_324
-  test("SELECT modelId, ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE modelId > \"2000\" GROUP BY modelId, ActiveCountry, ActiveDistrict, deliveryCity ORDER BY modelId ASC, ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC")({
+  test(
+    "SELECT modelId, ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS " +
+    "Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE modelId > " +
+    "\"2000\" GROUP BY modelId, ActiveCountry, ActiveDistrict, deliveryCity ORDER BY modelId    " +
+    "ASC, " +
+    " ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC")({
     checkAnswer(
-      sql("SELECT modelId, ActiveCountry, ActiveDistrict, deliveryCity, SUM(Latest_YEAR) AS Sum_Latest_YEAR FROM (select * from Carbon_automation_test6) SUB_QRY WHERE modelId > \"2000\" GROUP BY modelId, ActiveCountry, ActiveDistrict, deliveryCity ORDER BY modelId ASC, ActiveCountry ASC, ActiveDistrict ASC, deliveryCity ASC"),
-      Seq(Row("2008", "Chinese", "tianyuan", "changsha", 2015), Row("2069", "Chinese", "yuhua", "changsha", 2015), Row("2074", "Chinese", "longgang", "wuhan", 2015), Row("2133", "Chinese", "xiangtan", "shenzhen", 2015), Row("2142", "Chinese", "tianyuan", "yichang", 2015), Row("2151", "Chinese", "yuhua", "zhuzhou", 2015), Row("2164", "Chinese", "yuhua", "xiangtan", 2015), Row("2167", "Chinese", "longgang", "changsha", 2015), Row("2176", "Chinese", "longgang", "xiangtan", 2015), Row("2201", "Chinese", "yichang", "wuhan", 2015), Row("2300", "Chinese", "tianyuan", "zhuzhou", 2015), Row("2319", "Chinese", "hongshan", "guangzhou", 2015), Row("2320", "Chinese", "xiangtan", "guangzhou", 2015), Row("2355", "Chinese", "xiangtan", "shenzhen", 2015), Row("2381", "Chinese", "yuhua", "xiangtan", 2015), Row("2408", "Chinese", "xiangtan", "guangzhou", 2015), Row("2415", "Chinese", "yuhua", "changsha", 2015), Row("2457", "Chinese", "yichang", "yichang", 2015), Row("2479", "Chinese", "xiangtan", "yic
 hang", 2015), Row("2531", "Chinese", "yuhua", "wuhan", 2015), Row("2563", "Chinese", "hongshan", "changsha", 2015), Row("2574", "Chinese", "longgang", "shenzhen", 2015), Row("2591", "Chinese", "yichang", "xiangtan", 2015), Row("2594", "Chinese", "tianyuan", "yichang", 2015), Row("2597", "Chinese", "longgang", "guangzhou", 2015), Row("2644", "Chinese", "xiangtan", "xiangtan", 2015), Row("2696", "Chinese", "longhua", "zhuzhou", 2015), Row("2705", "Chinese", "xiangtan", "guangzhou", 2015), Row("273", "Chinese", "yichang", "wuhan", 2015), Row("2759", "Chinese", "yuhua", "yichang", 2015), Row("2761", "Chinese", "xiangtan", "xiangtan", 2015), Row("2765", "Chinese", "hongshan", "yichang", 2015), Row("2797", "Chinese", "xiangtan", "xiangtan", 2015), Row("2799", "Chinese", "yuhua", "yichang", 2015), Row("2823", "Chinese", "longhua", "yichang", 2015), Row("2828", "Chinese", "yichang", "zhuzhou", 2015), Row("2930", "Chinese", "longhua", "yichang", 2015), Row("2940", "Chinese", "tianyuan", "zhu
 zhou", 2015), Row("2963", "Chinese", "xiangtan", "changsha", 2015), Row("297", "Chinese", "longgang", "zhuzhou", 2015), Row("396", "Chinese", "xiangtan", "changsha", 2015), Row("44", "Chinese", "hongshan", "guangzhou", 2015), Row("446", "Chinese", "yichang", "yichang", 2015), Row("466", "Chinese", "xiangtan", "guangzhou", 2015), Row("47", "Chinese", "hongshan", "guangzhou", 2015), Row("477", "Chinese", "xiangtan", "yichang", 2015), Row("499", "Chinese", "xiangtan", "shenzhen", 2015), Row("513", "Chinese", "longhua", "zhuzhou", 2015), Row("546", "Chinese", "xiangtan", "changsha", 2015), Row("631", "Chinese", "tianyuan", "shenzhen", 2015), Row("68", "Chinese", "hongshan", "wuhan", 2015), Row("716", "Chinese", "yuhua", "zhuzhou", 2015), Row("776", "Chinese", "longgang", "zhuzhou", 2015), Row("839", "Chinese", "hongshan", "zhuzhou", 2015), Row("864", "Chinese", "hongshan", "guangzhou", 2015), Row("872", "Chinese", "xiangtan", "shenzhen", 2015), Row("93", "Chin

<TRUNCATED>


[2/3] incubator-carbondata git commit: AllDataTypeTestCase6 improved

Posted by ra...@apache.org.
AllDataTypeTestCase6 improved

additional lines removed


Project: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/commit/11eefc95
Tree: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/tree/11eefc95
Diff: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/diff/11eefc95

Branch: refs/heads/master
Commit: 11eefc95a02aaca6b7f33407c5046798e13f495f
Parents: a0714f5
Author: rahulforallp <ra...@knoldus.in>
Authored: Sat Dec 3 19:19:47 2016 +0530
Committer: ravipesala <ra...@gmail.com>
Committed: Sun Dec 11 09:37:47 2016 +0530

----------------------------------------------------------------------
 .../allqueries/AllDataTypesTestCase6.scala      | 5571 +++++++++++++-----
 1 file changed, 4026 insertions(+), 1545 deletions(-)
----------------------------------------------------------------------



[3/3] incubator-carbondata git commit: [CARBONDATA-482 ]AllDataTypeTestCase6 improved This closes #394

Posted by ra...@apache.org.
[CARBONDATA-482 ]AllDataTypeTestCase6 improved This closes #394


Project: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/repo
Commit: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/commit/573e9e8c
Tree: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/tree/573e9e8c
Diff: http://git-wip-us.apache.org/repos/asf/incubator-carbondata/diff/573e9e8c

Branch: refs/heads/master
Commit: 573e9e8c93bb5bd5146b49180186439423226c2a
Parents: a0714f5 11eefc9
Author: ravipesala <ra...@gmail.com>
Authored: Sun Dec 11 09:39:57 2016 +0530
Committer: ravipesala <ra...@gmail.com>
Committed: Sun Dec 11 09:39:57 2016 +0530

----------------------------------------------------------------------
 .../allqueries/AllDataTypesTestCase6.scala      | 5571 +++++++++++++-----
 1 file changed, 4026 insertions(+), 1545 deletions(-)
----------------------------------------------------------------------