You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by br...@apache.org on 2013/10/31 19:27:46 UTC

svn commit: r1537576 [6/23] - in /hive/trunk: ./ ant/ ant/src/org/apache/hadoop/hive/ant/ beeline/ beeline/src/java/org/apache/hive/beeline/ beeline/src/test/org/apache/hive/beeline/src/test/ cli/ common/ common/src/java/conf/ common/src/scripts/ commo...

Modified: hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/security/DummyAuthenticator.java
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/security/DummyAuthenticator.java?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/security/DummyAuthenticator.java (original)
+++ hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/security/DummyAuthenticator.java Thu Oct 31 18:27:31 2013
@@ -24,11 +24,11 @@ import org.apache.hadoop.conf.Configurat
 import org.apache.hadoop.hive.ql.metadata.HiveException;
 
 public class DummyAuthenticator implements HiveAuthenticationProvider {
-  
+
   private List<String> groupNames;
   private String userName;
   private Configuration conf;
-  
+
   public DummyAuthenticator() {
     this.groupNames = new ArrayList<String>();
     groupNames.add("hive_test_group1");
@@ -55,7 +55,7 @@ public class DummyAuthenticator implemen
   public void setConf(Configuration conf) {
     this.conf = conf;
   }
-  
+
   public Configuration getConf() {
     return this.conf;
   }

Modified: hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/util/TestDosToUnix.java
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/util/TestDosToUnix.java?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/util/TestDosToUnix.java (original)
+++ hive/trunk/ql/src/test/org/apache/hadoop/hive/ql/util/TestDosToUnix.java Thu Oct 31 18:27:31 2013
@@ -27,7 +27,7 @@ import junit.framework.TestCase;
 
 public class TestDosToUnix extends TestCase {
 
-  private static final String dataFile = System.getProperty("test.data.dir", ".") + "data_TestDosToUnix";
+  private static final String dataFile = System.getProperty("test.tmp.dir", ".") + "data_TestDosToUnix";
   @Override
   protected void setUp() throws Exception {
     super.setUp();

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_concatenate_indexed_table.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_concatenate_indexed_table.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_concatenate_indexed_table.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_concatenate_indexed_table.q Thu Oct 31 18:27:31 2013
@@ -1,9 +1,9 @@
 set hive.exec.concatenate.check.index=true;
 create table src_rc_concatenate_test(key int, value string) stored as rcfile;
 
-load data local inpath '../data/files/smbbucket_1.rc' into table src_rc_concatenate_test;
-load data local inpath '../data/files/smbbucket_2.rc' into table src_rc_concatenate_test;
-load data local inpath '../data/files/smbbucket_3.rc' into table src_rc_concatenate_test;
+load data local inpath '../../data/files/smbbucket_1.rc' into table src_rc_concatenate_test;
+load data local inpath '../../data/files/smbbucket_2.rc' into table src_rc_concatenate_test;
+load data local inpath '../../data/files/smbbucket_3.rc' into table src_rc_concatenate_test;
 
 show table extended like `src_rc_concatenate_test`;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_partition_invalidspec.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_partition_invalidspec.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_partition_invalidspec.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_partition_invalidspec.q Thu Oct 31 18:27:31 2013
@@ -2,7 +2,7 @@
 create table if not exists alter_part_invalidspec(key string, value string ) partitioned by (year string, month string) stored as textfile ;
 
 -- Load data
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_invalidspec partition (year='1996', month='10');
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_invalidspec partition (year='1996', month='12');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_invalidspec partition (year='1996', month='10');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_invalidspec partition (year='1996', month='12');
 
 alter table alter_part_invalidspec partition (year='1997') enable no_drop;

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop.q Thu Oct 31 18:27:31 2013
@@ -2,8 +2,8 @@
 create table if not exists alter_part_nodrop_part(key string, value string ) partitioned by (year string, month string) stored as textfile ;
 
 -- Load data
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_nodrop_part partition (year='1996', month='10');
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_nodrop_part partition (year='1996', month='12');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_nodrop_part partition (year='1996', month='10');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_nodrop_part partition (year='1996', month='12');
 
 alter table alter_part_nodrop_part partition (year='1996') enable no_drop;
 alter table alter_part_nodrop_part drop partition (year='1996');

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop_table.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop_table.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop_table.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_partition_nodrop_table.q Thu Oct 31 18:27:31 2013
@@ -2,8 +2,8 @@
 create table if not exists alter_part_nodrop_table(key string, value string ) partitioned by (year string, month string) stored as textfile ;
 
 -- Load data
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_nodrop_table partition (year='1996', month='10');
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_nodrop_table partition (year='1996', month='12');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_nodrop_table partition (year='1996', month='10');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_nodrop_table partition (year='1996', month='12');
 
 alter table alter_part_nodrop_table partition (year='1996') enable no_drop;
 drop table alter_part_nodrop_table;

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_partition_offline.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_partition_offline.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_partition_offline.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_partition_offline.q Thu Oct 31 18:27:31 2013
@@ -2,8 +2,8 @@
 create table if not exists alter_part_offline (key string, value string ) partitioned by (year string, month string) stored as textfile ;
 
 -- Load data
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_offline partition (year='1996', month='10');
-load data local inpath '../data/files/T1.txt' overwrite into table alter_part_offline partition (year='1996', month='12');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_offline partition (year='1996', month='10');
+load data local inpath '../../data/files/T1.txt' overwrite into table alter_part_offline partition (year='1996', month='12');
 
 alter table alter_part_offline partition (year='1996') disable offline;
 select * from alter_part_offline where year = '1996';

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure.q Thu Oct 31 18:27:31 2013
@@ -1,5 +1,5 @@
 create table alter_rename_partition_src ( col1 string ) stored as textfile ;
-load data local inpath '../data/files/test.dat' overwrite into table alter_rename_partition_src ;
+load data local inpath '../../data/files/test.dat' overwrite into table alter_rename_partition_src ;
 create table alter_rename_partition ( col1 string ) partitioned by (pcol1 string , pcol2 string) stored as sequencefile;
 insert overwrite table alter_rename_partition partition (pCol1='old_part1:', pcol2='old_part2:') select col1 from alter_rename_partition_src ;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure2.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure2.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure2.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure2.q Thu Oct 31 18:27:31 2013
@@ -1,5 +1,5 @@
 create table alter_rename_partition_src ( col1 string ) stored as textfile ;
-load data local inpath '../data/files/test.dat' overwrite into table alter_rename_partition_src ;
+load data local inpath '../../data/files/test.dat' overwrite into table alter_rename_partition_src ;
 create table alter_rename_partition ( col1 string ) partitioned by (pcol1 string , pcol2 string) stored as sequencefile;
 insert overwrite table alter_rename_partition partition (pCol1='old_part1:', pcol2='old_part2:') select col1 from alter_rename_partition_src ;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure3.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure3.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure3.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/alter_rename_partition_failure3.q Thu Oct 31 18:27:31 2013
@@ -1,5 +1,5 @@
 create table alter_rename_partition_src ( col1 string ) stored as textfile ;
-load data local inpath '../data/files/test.dat' overwrite into table alter_rename_partition_src ;
+load data local inpath '../../data/files/test.dat' overwrite into table alter_rename_partition_src ;
 create table alter_rename_partition ( col1 string ) partitioned by (pcol1 string , pcol2 string) stored as sequencefile;
 insert overwrite table alter_rename_partition partition (pCol1='old_part1:', pcol2='old_part2:') select col1 from alter_rename_partition_src ;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/archive_corrupt.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/archive_corrupt.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/archive_corrupt.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/archive_corrupt.q Thu Oct 31 18:27:31 2013
@@ -14,5 +14,5 @@ create table tstsrcpart like srcpart;
 -- to be thrown during the LOAD step. This former behavior is tested
 -- in clientpositive/archive_corrupt.q
 
-load data local inpath '../data/files/archive_corrupt.rc' overwrite into table tstsrcpart partition (ds='2008-04-08', hr='11');
+load data local inpath '../../data/files/archive_corrupt.rc' overwrite into table tstsrcpart partition (ds='2008-04-08', hr='11');
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_mismatch1.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_mismatch1.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_mismatch1.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_mismatch1.q Thu Oct 31 18:27:31 2013
@@ -1,19 +1,19 @@
 CREATE TABLE srcbucket_mapjoin_part (key int, value string) 
   partitioned by (ds string) CLUSTERED BY (key) INTO 3 BUCKETS
   STORED AS TEXTFILE;
-load data local inpath '../data/files/srcbucket20.txt' 
+load data local inpath '../../data/files/srcbucket20.txt' 
   INTO TABLE srcbucket_mapjoin_part partition(ds='2008-04-08');
-load data local inpath '../data/files/srcbucket21.txt' 
+load data local inpath '../../data/files/srcbucket21.txt' 
   INTO TABLE srcbucket_mapjoin_part partition(ds='2008-04-08');
-load data local inpath '../data/files/srcbucket22.txt' 
+load data local inpath '../../data/files/srcbucket22.txt' 
   INTO TABLE srcbucket_mapjoin_part partition(ds='2008-04-08');
 
 CREATE TABLE srcbucket_mapjoin_part_2 (key int, value string)
   partitioned by (ds string) CLUSTERED BY (key) INTO 2 BUCKETS
   STORED AS TEXTFILE;
-load data local inpath '../data/files/srcbucket22.txt'
+load data local inpath '../../data/files/srcbucket22.txt'
   INTO TABLE srcbucket_mapjoin_part_2 partition(ds='2008-04-08');
-load data local inpath '../data/files/srcbucket23.txt'
+load data local inpath '../../data/files/srcbucket23.txt'
   INTO TABLE srcbucket_mapjoin_part_2 partition(ds='2008-04-08');
 
 -- The number of buckets in the 2 tables above (being joined later) dont match.

Modified: hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_1.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_1.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_1.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_1.q Thu Oct 31 18:27:31 2013
@@ -8,10 +8,10 @@ into 2 BUCKETS stored as textfile;
 create table table2(key string, value string) clustered by (value, key)
 into 2 BUCKETS stored as textfile;
 
-load data local inpath '../data/files/T1.txt' overwrite into table table1;
+load data local inpath '../../data/files/T1.txt' overwrite into table table1;
 
-load data local inpath '../data/files/T1.txt' overwrite into table table2;
-load data local inpath '../data/files/T2.txt' overwrite into table table2;
+load data local inpath '../../data/files/T1.txt' overwrite into table table2;
+load data local inpath '../../data/files/T2.txt' overwrite into table table2;
 
 set hive.optimize.bucketmapjoin = true;
 set hive.input.format = org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat;

Modified: hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_2.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_2.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_2.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/bucket_mapjoin_wrong_table_metadata_2.q Thu Oct 31 18:27:31 2013
@@ -8,13 +8,13 @@ into 2 BUCKETS stored as textfile;
 create table table2(key string, value string) clustered by (value, key)
 into 2 BUCKETS stored as textfile;
 
-load data local inpath '../data/files/T1.txt' overwrite into table table1 partition (ds='1');
-load data local inpath '../data/files/T2.txt' overwrite into table table1 partition (ds='1');
+load data local inpath '../../data/files/T1.txt' overwrite into table table1 partition (ds='1');
+load data local inpath '../../data/files/T2.txt' overwrite into table table1 partition (ds='1');
 
-load data local inpath '../data/files/T1.txt' overwrite into table table1 partition (ds='2');
+load data local inpath '../../data/files/T1.txt' overwrite into table table1 partition (ds='2');
 
-load data local inpath '../data/files/T1.txt' overwrite into table table2;
-load data local inpath '../data/files/T2.txt' overwrite into table table2;
+load data local inpath '../../data/files/T1.txt' overwrite into table table2;
+load data local inpath '../../data/files/T2.txt' overwrite into table table2;
 
 set hive.optimize.bucketmapjoin = true;
 set hive.input.format = org.apache.hadoop.hive.ql.io.BucketizedHiveInputFormat;

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_dp.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_dp.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_dp.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_dp.q Thu Oct 31 18:27:31 2013
@@ -3,12 +3,12 @@ DROP TABLE Employee_Part;
 CREATE TABLE Employee_Part(employeeID int, employeeName String) partitioned by (employeeSalary double, country string)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
 
 -- dynamic partitioning syntax
 explain 

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_incorrect_num_keys.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_incorrect_num_keys.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_incorrect_num_keys.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_incorrect_num_keys.q Thu Oct 31 18:27:31 2013
@@ -3,12 +3,12 @@ DROP TABLE Employee_Part;
 CREATE TABLE Employee_Part(employeeID int, employeeName String) partitioned by (employeeSalary double, country string)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
 
 -- don't specify all partitioning keys
 explain 

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_invalid_values.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_invalid_values.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_invalid_values.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_invalid_values.q Thu Oct 31 18:27:31 2013
@@ -3,12 +3,12 @@ DROP TABLE Employee_Part;
 CREATE TABLE Employee_Part(employeeID int, employeeName String) partitioned by (employeeSalary double, country string)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
 
 -- specify invalid values for the partitioning keys
 explain

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_multiple_part_clause.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_multiple_part_clause.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_multiple_part_clause.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_partlvl_multiple_part_clause.q Thu Oct 31 18:27:31 2013
@@ -3,12 +3,12 @@ DROP TABLE Employee_Part;
 CREATE TABLE Employee_Part(employeeID int, employeeName String) partitioned by (employeeSalary double, country string)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
-LOAD DATA LOCAL INPATH "../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='2000.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='4000.0', country='USA');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3500.0', country='UK');
+LOAD DATA LOCAL INPATH "../../data/files/employee2.dat" INTO TABLE Employee_Part partition(employeeSalary='3000.0', country='UK');
 
 -- specify partitioning clause multiple times
 explain

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl.q Thu Oct 31 18:27:31 2013
@@ -13,7 +13,7 @@ CREATE TABLE UserVisits_web_text_none (
   avgTimeOnSite int)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/UserVisits.dat" INTO TABLE UserVisits_web_text_none;
+LOAD DATA LOCAL INPATH "../../data/files/UserVisits.dat" INTO TABLE UserVisits_web_text_none;
 
 explain 
 analyze table UserVisits_web_text_none compute statistics for columns destIP;

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_complex_type.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_complex_type.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_complex_type.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_complex_type.q Thu Oct 31 18:27:31 2013
@@ -8,7 +8,7 @@ CREATE TABLE table_complex_type (
        d MAP<STRING,ARRAY<STRING>>
        ) STORED AS TEXTFILE;
 
-LOAD DATA LOCAL INPATH '../data/files/create_nested_type.txt' OVERWRITE INTO TABLE table_complex_type;
+LOAD DATA LOCAL INPATH '../../data/files/create_nested_type.txt' OVERWRITE INTO TABLE table_complex_type;
 
 
 explain 

Modified: hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_incorrect_column.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_incorrect_column.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_incorrect_column.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/columnstats_tbllvl_incorrect_column.q Thu Oct 31 18:27:31 2013
@@ -13,7 +13,7 @@ CREATE TABLE UserVisits_web_text_none (
   avgTimeOnSite int)
 row format delimited fields terminated by '|'  stored as textfile;
 
-LOAD DATA LOCAL INPATH "../data/files/UserVisits.dat" INTO TABLE UserVisits_web_text_none;
+LOAD DATA LOCAL INPATH "../../data/files/UserVisits.dat" INTO TABLE UserVisits_web_text_none;
 
 explain 
 analyze table UserVisits_web_text_none compute statistics for columns destIP;

Modified: hive/trunk/ql/src/test/queries/clientnegative/compute_stats_long.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/compute_stats_long.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/compute_stats_long.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/compute_stats_long.q Thu Oct 31 18:27:31 2013
@@ -1,7 +1,7 @@
 create table tab_int(a int);
 
 -- insert some data
-LOAD DATA LOCAL INPATH "../data/files/int.txt" INTO TABLE tab_int;
+LOAD DATA LOCAL INPATH "../../data/files/int.txt" INTO TABLE tab_int;
 
 -- compute stats should raise an error since the number of bit vectors > 1024
 select compute_stats(a, 10000) from tab_int;

Modified: hive/trunk/ql/src/test/queries/clientnegative/deletejar.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/deletejar.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/deletejar.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/deletejar.q Thu Oct 31 18:27:31 2013
@@ -1,4 +1,4 @@
 
-ADD JAR ../build/ql/test/TestSerDe.jar;
-DELETE JAR ../build/ql/test/TestSerDe.jar;
+ADD JAR ${system:maven.local.repository}/org/apache/hive/hive-it-test-serde/${system:hive.version}/hive-it-test-serde-${system:hive.version}.jar;
+DELETE JAR ${system:maven.local.repository}/org/apache/hive/hive-it-test-serde/${system:hive.version}/hive-it-test-serde-${system:hive.version}.jar;
 CREATE TABLE DELETEJAR(KEY STRING, VALUE STRING) ROW FORMAT SERDE 'org.apache.hadoop.hive.serde2.TestSerDe' STORED AS TEXTFILE;

Modified: hive/trunk/ql/src/test/queries/clientnegative/dynamic_partitions_with_whitelist.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/dynamic_partitions_with_whitelist.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/dynamic_partitions_with_whitelist.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/dynamic_partitions_with_whitelist.q Thu Oct 31 18:27:31 2013
@@ -8,7 +8,7 @@ create table source_table like srcpart;
 
 create table dest_table like srcpart;
 
-load data local inpath '../data/files/srcbucket20.txt' INTO TABLE source_table partition(ds='2008-04-08', hr=11);
+load data local inpath '../../data/files/srcbucket20.txt' INTO TABLE source_table partition(ds='2008-04-08', hr=11);
 
 -- Tests creating dynamic partitions with characters not in the whitelist (i.e. 9)
 -- If the directory is not empty the hook will throw an error, instead the error should come from the metastore

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_00_unsupported_schema.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_00_unsupported_schema.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_00_unsupported_schema.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_00_unsupported_schema.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id")
 	stored as textfile
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'nosuchschema://nosuchauthority/ql/test/data/exports/exim_department';
 drop table exim_department;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_01_nonpart_over_loaded.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_01_nonpart_over_loaded.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_01_nonpart_over_loaded.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_01_nonpart_over_loaded.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id")
 	stored as textfile
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -16,9 +16,9 @@ use importer;
 create table exim_department ( dep_id int comment "department identifier")
 	stored as textfile
 	tblproperties("maker"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
+load data local inpath "../../data/files/test.dat" into table exim_department;	
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_02_all_part_over_overlap.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_02_all_part_over_overlap.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_02_all_part_over_overlap.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_02_all_part_over_overlap.q Thu Oct 31 18:27:31 2013
@@ -6,16 +6,16 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "two char iso code", emp_state string comment "free text")
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="ka");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="ka");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_employee/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_employee/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 export table exim_employee to 'ql/test/data/exports/exim_employee';
 drop table exim_employee;
 
@@ -27,12 +27,12 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "iso code", emp_state string comment "free-form text")
 	stored as textfile	
 	tblproperties("maker"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="ka");			
 import from 'ql/test/data/exports/exim_employee';
 describe extended exim_employee;
 select * from exim_employee;
 drop table exim_employee;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_03_nonpart_noncompat_colschema.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_03_nonpart_noncompat_colschema.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_03_nonpart_noncompat_colschema.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_03_nonpart_noncompat_colschema.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,6 +18,6 @@ create table exim_department ( dep_key i
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_04_nonpart_noncompat_colnumber.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_04_nonpart_noncompat_colnumber.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_04_nonpart_noncompat_colnumber.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_04_nonpart_noncompat_colnumber.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,6 +18,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_05_nonpart_noncompat_coltype.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_05_nonpart_noncompat_coltype.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_05_nonpart_noncompat_coltype.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_05_nonpart_noncompat_coltype.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,6 +18,6 @@ create table exim_department ( dep_id bi
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_06_nonpart_noncompat_storage.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_06_nonpart_noncompat_storage.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_06_nonpart_noncompat_storage.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_06_nonpart_noncompat_storage.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,6 +18,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_07_nonpart_noncompat_ifof.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_07_nonpart_noncompat_ifof.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_07_nonpart_noncompat_ifof.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_07_nonpart_noncompat_ifof.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -21,6 +21,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_08_nonpart_noncompat_serde.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_08_nonpart_noncompat_serde.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_08_nonpart_noncompat_serde.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_08_nonpart_noncompat_serde.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -19,6 +19,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_09_nonpart_noncompat_serdeparam.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_09_nonpart_noncompat_serdeparam.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_09_nonpart_noncompat_serdeparam.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_09_nonpart_noncompat_serdeparam.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -23,6 +23,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_10_nonpart_noncompat_bucketing.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_10_nonpart_noncompat_bucketing.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_10_nonpart_noncompat_bucketing.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_10_nonpart_noncompat_bucketing.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -19,6 +19,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_11_nonpart_noncompat_sorting.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_11_nonpart_noncompat_sorting.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_11_nonpart_noncompat_sorting.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_11_nonpart_noncompat_sorting.q Thu Oct 31 18:27:31 2013
@@ -5,9 +5,9 @@ create table exim_department ( dep_id in
 	clustered by (dep_id) sorted by (dep_id desc) into 10 buckets
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;	
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;	
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -20,6 +20,6 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_13_nonnative_import.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_13_nonnative_import.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_13_nonnative_import.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_13_nonnative_import.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,7 +18,7 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;
 	
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_14_nonpart_part.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_14_nonpart_part.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_14_nonpart_part.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_14_nonpart_part.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -19,7 +19,7 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;
 	
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_15_part_nonpart.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_15_part_nonpart.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_15_part_nonpart.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_15_part_nonpart.q Thu Oct 31 18:27:31 2013
@@ -5,9 +5,9 @@ create table exim_department ( dep_id in
 	partitioned by (dep_org string)
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department partition (dep_org="hr");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department partition (dep_org="hr");		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -19,7 +19,7 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;
 	
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_16_part_noncompat_schema.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_16_part_noncompat_schema.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_16_part_noncompat_schema.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_16_part_noncompat_schema.q Thu Oct 31 18:27:31 2013
@@ -5,9 +5,9 @@ create table exim_department ( dep_id in
 	partitioned by (dep_org string)
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department partition (dep_org="hr");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department partition (dep_org="hr");		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -20,7 +20,7 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import from 'ql/test/data/exports/exim_department';
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 
 drop database importer;
 	
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_17_part_spec_underspec.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_17_part_spec_underspec.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_17_part_spec_underspec.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_17_part_spec_underspec.q Thu Oct 31 18:27:31 2013
@@ -6,16 +6,16 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "two char iso code", emp_state string comment "free text")
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="ka");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="ka");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_employee/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_employee/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 export table exim_employee to 'ql/test/data/exports/exim_employee';
 drop table exim_employee;
 
@@ -25,6 +25,6 @@ import table exim_employee partition (em
 describe extended exim_employee;
 select * from exim_employee;
 drop table exim_employee;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_18_part_spec_missing.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_18_part_spec_missing.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_18_part_spec_missing.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_18_part_spec_missing.q Thu Oct 31 18:27:31 2013
@@ -6,16 +6,16 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "two char iso code", emp_state string comment "free text")
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="ka");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="ka");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_employee/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_employee/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 export table exim_employee to 'ql/test/data/exports/exim_employee';
 drop table exim_employee;
 
@@ -25,6 +25,6 @@ import table exim_employee partition (em
 describe extended exim_employee;
 select * from exim_employee;
 drop table exim_employee;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_19_external_over_existing.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_19_external_over_existing.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_19_external_over_existing.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_19_external_over_existing.q Thu Oct 31 18:27:31 2013
@@ -4,9 +4,9 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -17,7 +17,7 @@ create  table exim_department ( dep_id i
 	stored as textfile
 	tblproperties("creator"="krishna");
 import external table exim_department from 'ql/test/data/exports/exim_department';
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 drop table exim_department;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_20_managed_location_over_existing.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_20_managed_location_over_existing.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_20_managed_location_over_existing.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_20_managed_location_over_existing.q Thu Oct 31 18:27:31 2013
@@ -4,17 +4,17 @@ set hive.test.mode.prefix=;
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" into table exim_department;		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;		
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
 create database importer;
 use importer;
 
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/tablestore/exim_department/temp;
-dfs -rmr ../build/ql/test/data/tablestore/exim_department;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/tablestore/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/tablestore/exim_department;
 
 create table exim_department ( dep_id int comment "department id") 	
 	stored as textfile
@@ -22,9 +22,9 @@ create table exim_department ( dep_id in
 	tblproperties("creator"="krishna");
 import table exim_department from 'ql/test/data/exports/exim_department'
 	location 'ql/test/data/tablestore2/exim_department';
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 drop table exim_department;
-dfs -rmr ../build/ql/test/data/tablestore/exim_department;
+dfs -rmr target/tmp/ql/test/data/tablestore/exim_department;
 
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_21_part_managed_external.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_21_part_managed_external.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_21_part_managed_external.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_21_part_managed_external.q Thu Oct 31 18:27:31 2013
@@ -6,16 +6,16 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "two char iso code", emp_state string comment "free text")
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="ka");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="tn");	
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="us", emp_state="ka");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_employee/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_employee/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 export table exim_employee to 'ql/test/data/exports/exim_employee';
 drop table exim_employee;
 
@@ -29,7 +29,7 @@ create table exim_employee ( emp_id int 
 	tblproperties("creator"="krishna");
 import external table exim_employee partition (emp_country="us", emp_state="tn") 
 	from 'ql/test/data/exports/exim_employee';
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 drop table exim_employee;
 
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_22_export_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_22_export_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_22_export_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_22_export_authfail.q Thu Oct 31 18:27:31 2013
@@ -5,8 +5,8 @@ create table exim_department ( dep_id in
 
 set hive.security.authorization.enabled=true;
 
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 
 set hive.security.authorization.enabled=false;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_23_import_exist_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_23_import_exist_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_23_import_exist_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_23_import_exist_authfail.q Thu Oct 31 18:27:31 2013
@@ -2,9 +2,9 @@ set hive.test.mode=true;
 set hive.test.mode.prefix=;
 
 create table exim_department ( dep_id int) stored as textfile;
-load data local inpath "../data/files/test.dat" into table exim_department;
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -18,5 +18,5 @@ import from 'ql/test/data/exports/exim_d
 set hive.security.authorization.enabled=false;
 drop table exim_department;
 drop database importer;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_24_import_part_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_24_import_part_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_24_import_part_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_24_import_part_authfail.q Thu Oct 31 18:27:31 2013
@@ -7,10 +7,10 @@ create table exim_employee ( emp_id int 
 	partitioned by (emp_country string comment "two char iso code", emp_state string comment "free text")
 	stored as textfile	
 	tblproperties("creator"="krishna");
-load data local inpath "../data/files/test.dat" 
+load data local inpath "../../data/files/test.dat" 
 	into table exim_employee partition (emp_country="in", emp_state="tn");		
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_employee/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_employee/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 export table exim_employee to 'ql/test/data/exports/exim_employee';
 drop table exim_employee;
 
@@ -26,6 +26,6 @@ set hive.security.authorization.enabled=
 import from 'ql/test/data/exports/exim_employee';
 set hive.security.authorization.enabled=false;
 
-dfs -rmr ../build/ql/test/data/exports/exim_employee;
+dfs -rmr target/tmp/ql/test/data/exports/exim_employee;
 drop table exim_employee;
 drop database importer;

Modified: hive/trunk/ql/src/test/queries/clientnegative/exim_25_import_nonexist_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/exim_25_import_nonexist_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/exim_25_import_nonexist_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/exim_25_import_nonexist_authfail.q Thu Oct 31 18:27:31 2013
@@ -3,9 +3,9 @@ set hive.test.mode.prefix=;
 set hive.test.mode.nosamplelist=exim_department,exim_employee;
 
 create table exim_department ( dep_id int) stored as textfile;
-load data local inpath "../data/files/test.dat" into table exim_department;
-dfs ${system:test.dfs.mkdir} ../build/ql/test/data/exports/exim_department/temp;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+load data local inpath "../../data/files/test.dat" into table exim_department;
+dfs ${system:test.dfs.mkdir} target/tmp/ql/test/data/exports/exim_department/temp;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 export table exim_department to 'ql/test/data/exports/exim_department';
 drop table exim_department;
 
@@ -19,5 +19,5 @@ set hive.security.authorization.enabled=
 select * from exim_department;
 drop table exim_department;
 drop database importer;
-dfs -rmr ../build/ql/test/data/exports/exim_department;
+dfs -rmr target/tmp/ql/test/data/exports/exim_department;
 

Modified: hive/trunk/ql/src/test/queries/clientnegative/fetchtask_ioexception.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/fetchtask_ioexception.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/fetchtask_ioexception.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/fetchtask_ioexception.q Thu Oct 31 18:27:31 2013
@@ -2,6 +2,6 @@ CREATE TABLE fetchtask_ioexception (
   KEY STRING,
   VALUE STRING) STORED AS SEQUENCEFILE;
 
-LOAD DATA LOCAL INPATH '../data/files/kv1_broken.seq' OVERWRITE INTO TABLE fetchtask_ioexception;
+LOAD DATA LOCAL INPATH '../../data/files/kv1_broken.seq' OVERWRITE INTO TABLE fetchtask_ioexception;
 
 SELECT * FROM fetchtask_ioexception;

Modified: hive/trunk/ql/src/test/queries/clientnegative/illegal_partition_type.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/illegal_partition_type.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/illegal_partition_type.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/illegal_partition_type.q Thu Oct 31 18:27:31 2013
@@ -1,6 +1,6 @@
 -- begin part(string, int) pass(string, string)
 CREATE TABLE tab1 (id1 int,id2 string) PARTITIONED BY(month string,day int) ROW FORMAT DELIMITED FIELDS TERMINATED BY ',' ;
-LOAD DATA LOCAL INPATH '../data/files/T1.txt' overwrite into table tab1 PARTITION(month='June', day='second');
+LOAD DATA LOCAL INPATH '../../data/files/T1.txt' overwrite into table tab1 PARTITION(month='June', day='second');
 
 select * from tab1;
 drop table tab1;

Modified: hive/trunk/ql/src/test/queries/clientnegative/insertover_dynapart_ifnotexists.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/insertover_dynapart_ifnotexists.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/insertover_dynapart_ifnotexists.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/insertover_dynapart_ifnotexists.q Thu Oct 31 18:27:31 2013
@@ -4,6 +4,6 @@ create table srcpart_dp like srcpart;
 
 create table destpart_dp like srcpart;
 
-load data local inpath '../data/files/srcbucket20.txt' INTO TABLE srcpart_dp partition(ds='2008-04-08', hr=11);
+load data local inpath '../../data/files/srcbucket20.txt' INTO TABLE srcpart_dp partition(ds='2008-04-08', hr=11);
 
 insert overwrite table destpart_dp partition (ds='2008-04-08', hr) if not exists select key, value, hr from srcpart_dp where ds='2008-04-08';
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/invalid_columns.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/invalid_columns.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/invalid_columns.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/invalid_columns.q Thu Oct 31 18:27:31 2013
@@ -1,4 +1,4 @@
-ADD JAR ../build/ql/test/TestSerDe.jar;
+ADD JAR ${system:maven.local.repository}/org/apache/hive/hive-it-test-serde/${system:hive.version}/hive-it-test-serde-${system:hive.version}.jar;
 CREATE TABLE DELETEJAR(KEY STRING, VALUE STRING) ROW FORMAT SERDE 'org.apache.hadoop.hive.serde2.TestSerDe' 
 STORED AS TEXTFILE
 TBLPROPERTIES('columns'='valid_colname,invalid.colname');

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_exist_part_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_exist_part_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_exist_part_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_exist_part_authfail.q Thu Oct 31 18:27:31 2013
@@ -1,4 +1,4 @@
 create table hive_test_src ( col1 string ) partitioned by (pcol1 string) stored as textfile;
 alter table hive_test_src add partition (pcol1 = 'test_part');
 set hive.security.authorization.enabled=true;
-load data local inpath '../data/files/test.dat' overwrite into table hive_test_src partition (pcol1 = 'test_part');
+load data local inpath '../../data/files/test.dat' overwrite into table hive_test_src partition (pcol1 = 'test_part');

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_non_native.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_non_native.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_non_native.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_non_native.q Thu Oct 31 18:27:31 2013
@@ -2,4 +2,4 @@
 CREATE TABLE non_native2(key int, value string) 
 STORED BY 'org.apache.hadoop.hive.ql.metadata.DefaultStorageHandler';
 
-LOAD DATA LOCAL INPATH '../data/files/kv1.txt' INTO TABLE non_native2;
+LOAD DATA LOCAL INPATH '../../data/files/kv1.txt' INTO TABLE non_native2;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_nonpart_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_nonpart_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_nonpart_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_nonpart_authfail.q Thu Oct 31 18:27:31 2013
@@ -1,3 +1,3 @@
 create table hive_test_src ( col1 string ) stored as textfile;
 set hive.security.authorization.enabled=true;
-load data local inpath '../data/files/test.dat' overwrite into table hive_test_src ;
+load data local inpath '../../data/files/test.dat' overwrite into table hive_test_src ;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_part_authfail.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_part_authfail.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_part_authfail.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_part_authfail.q Thu Oct 31 18:27:31 2013
@@ -1,3 +1,3 @@
 create table hive_test_src ( col1 string ) partitioned by (pcol1 string) stored as textfile;
 set hive.security.authorization.enabled=true;
-load data local inpath '../data/files/test.dat' overwrite into table hive_test_src partition (pcol1 = 'test_part');
+load data local inpath '../../data/files/test.dat' overwrite into table hive_test_src partition (pcol1 = 'test_part');

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_part_nospec.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_part_nospec.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_part_nospec.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_part_nospec.q Thu Oct 31 18:27:31 2013
@@ -1,2 +1,2 @@
 create table hive_test_src ( col1 string ) partitioned by (pcol1 string) stored as textfile;
-load data local inpath '../data/files/test.dat' into table hive_test_src;
+load data local inpath '../../data/files/test.dat' into table hive_test_src;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_stored_as_dirs.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_stored_as_dirs.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_stored_as_dirs.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_stored_as_dirs.q Thu Oct 31 18:27:31 2013
@@ -4,4 +4,4 @@ set hive.mapred.supports.subdirectories=
 CREATE TABLE  if not exists stored_as_dirs_multiple (col1 STRING, col2 int, col3 STRING) 
 SKEWED BY (col1, col2) ON (('s1',1), ('s3',3), ('s13',13), ('s78',78))  stored as DIRECTORIES;
 
-LOAD DATA LOCAL INPATH '../data/files/kv1.txt' INTO TABLE stored_as_dirs_multiple;
+LOAD DATA LOCAL INPATH '../../data/files/kv1.txt' INTO TABLE stored_as_dirs_multiple;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_view_failure.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_view_failure.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_view_failure.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_view_failure.q Thu Oct 31 18:27:31 2013
@@ -1,3 +1,3 @@
 DROP VIEW xxx11;
 CREATE VIEW xxx11 AS SELECT * FROM src;
-LOAD DATA LOCAL INPATH '../data/files/kv1.txt' INTO TABLE xxx11;
+LOAD DATA LOCAL INPATH '../../data/files/kv1.txt' INTO TABLE xxx11;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat.q Thu Oct 31 18:27:31 2013
@@ -3,4 +3,4 @@
 
 
 CREATE TABLE load_wrong_fileformat_T1(name STRING) STORED AS SEQUENCEFILE;
-LOAD DATA LOCAL INPATH '../data/files/kv1.txt' INTO TABLE load_wrong_fileformat_T1;
+LOAD DATA LOCAL INPATH '../../data/files/kv1.txt' INTO TABLE load_wrong_fileformat_T1;

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_rc_seq.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_rc_seq.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_rc_seq.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_rc_seq.q Thu Oct 31 18:27:31 2013
@@ -3,4 +3,4 @@
 
 
 CREATE TABLE T1(name STRING) STORED AS RCFILE;
-LOAD DATA LOCAL INPATH '../data/files/kv1.seq' INTO TABLE T1;
\ No newline at end of file
+LOAD DATA LOCAL INPATH '../../data/files/kv1.seq' INTO TABLE T1;
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_txt_seq.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_txt_seq.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_txt_seq.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_wrong_fileformat_txt_seq.q Thu Oct 31 18:27:31 2013
@@ -3,4 +3,4 @@
 
 
 CREATE TABLE T1(name STRING) STORED AS TEXTFILE;
-LOAD DATA LOCAL INPATH '../data/files/kv1.seq' INTO TABLE T1;
\ No newline at end of file
+LOAD DATA LOCAL INPATH '../../data/files/kv1.seq' INTO TABLE T1;
\ No newline at end of file

Modified: hive/trunk/ql/src/test/queries/clientnegative/load_wrong_noof_part.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/load_wrong_noof_part.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/load_wrong_noof_part.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/load_wrong_noof_part.q Thu Oct 31 18:27:31 2013
@@ -1,3 +1,3 @@
 
 CREATE TABLE loadpart1(a STRING, b STRING) PARTITIONED BY (ds STRING,ds1 STRING);
-LOAD DATA LOCAL INPATH '../data1/files/kv1.txt' INTO TABLE loadpart1 PARTITION(ds='2009-05-05');
+LOAD DATA LOCAL INPATH '../../data1/files/kv1.txt' INTO TABLE loadpart1 PARTITION(ds='2009-05-05');

Modified: hive/trunk/ql/src/test/queries/clientnegative/local_mapred_error_cache.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/local_mapred_error_cache.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/local_mapred_error_cache.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/local_mapred_error_cache.q Thu Oct 31 18:27:31 2013
@@ -1,4 +1,4 @@
 set hive.exec.mode.local.auto=true;
 set hive.exec.failure.hooks=org.apache.hadoop.hive.ql.hooks.VerifySessionStateLocalErrorsHook;
 
-FROM src SELECT TRANSFORM(key, value) USING 'python ../data/scripts/cat_error.py' AS (key, value);
+FROM src SELECT TRANSFORM(key, value) USING 'python ../../data/scripts/cat_error.py' AS (key, value);

Modified: hive/trunk/ql/src/test/queries/clientnegative/nested_complex_neg.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/nested_complex_neg.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/nested_complex_neg.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/nested_complex_neg.q Thu Oct 31 18:27:31 2013
@@ -10,6 +10,6 @@ simple_string string)
 
 
 -- This should fail in as extended nesting levels are not enabled using the serdeproperty hive.serialization.extend.nesting.levels
-load data local inpath '../data/files/nested_complex.txt' overwrite into table nestedcomplex;
+load data local inpath '../../data/files/nested_complex.txt' overwrite into table nestedcomplex;
 
 select * from nestedcomplex sort by simple_int;

Modified: hive/trunk/ql/src/test/queries/clientnegative/nopart_insert.q
URL: http://svn.apache.org/viewvc/hive/trunk/ql/src/test/queries/clientnegative/nopart_insert.q?rev=1537576&r1=1537575&r2=1537576&view=diff
==============================================================================
--- hive/trunk/ql/src/test/queries/clientnegative/nopart_insert.q (original)
+++ hive/trunk/ql/src/test/queries/clientnegative/nopart_insert.q Thu Oct 31 18:27:31 2013
@@ -2,6 +2,6 @@
 CREATE TABLE nopart_insert(a STRING, b STRING) PARTITIONED BY (ds STRING);
 
 INSERT OVERWRITE TABLE nopart_insert 
-SELECT TRANSFORM(src.key, src.value) USING '../data/scripts/error_script' AS (tkey, tvalue)
+SELECT TRANSFORM(src.key, src.value) USING '../../data/scripts/error_script' AS (tkey, tvalue)
 FROM src;