You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@hive.apache.org by gu...@apache.org on 2013/08/06 00:31:32 UTC

svn commit: r1510788 [10/10] - in /hive/branches/tez: ./ cli/src/java/org/apache/hadoop/hive/cli/ cli/src/test/org/apache/hadoop/hive/cli/ common/src/java/org/apache/hadoop/hive/conf/ conf/ data/files/ eclipse-templates/ hcatalog/storage-handlers/hbase...

Modified: hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/AbstractSSHCommand.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/AbstractSSHCommand.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/AbstractSSHCommand.java (original)
+++ hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/AbstractSSHCommand.java Mon Aug  5 22:31:28 2013
@@ -21,50 +21,50 @@ package org.apache.hive.ptest.execution.
 import java.util.concurrent.Callable;
 
 public abstract class AbstractSSHCommand<RESULT> implements Callable<RESULT> {
-    private final String privateKey;
-    private final String user;
-    private final String host;
-    private final int instance;
-    private int exitCode = -1;
-    private Exception exception;
-    private String output;
+  private final String privateKey;
+  private final String user;
+  private final String host;
+  private final int instance;
+  private int exitCode = -1;
+  private Exception exception;
+  private String output;
 
-    public AbstractSSHCommand(String privateKey,
-        String user, String host, int instance) {
-      this.privateKey = privateKey;
-      this.user = user;
-      this.host = host;
-      this.instance = instance;
-    }
+  public AbstractSSHCommand(String privateKey,
+      String user, String host, int instance) {
+    this.privateKey = privateKey;
+    this.user = user;
+    this.host = host;
+    this.instance = instance;
+  }
 
-    public void setException(Exception exception) {
-      this.exception = exception;
-    }
-    public void setExitCode(int exitCode) {
-      this.exitCode = exitCode;
-    }
-    public void setOutput(String output) {
-      this.output = output;
-    }
-    public int getExitCode() {
-      return exitCode;
-    }
-    public Exception getException() {
-      return exception;
-    }
-    public String getOutput() {
-      return output;
-    }
-    public String getPrivateKey() {
-      return privateKey;
-    }
-    public String getUser() {
-      return user;
-    }
-    public String getHost() {
-      return host;
-    }
-    public int getInstance() {
-      return instance;
-    }
+  public void setException(Exception exception) {
+    this.exception = exception;
+  }
+  public void setExitCode(int exitCode) {
+    this.exitCode = exitCode;
+  }
+  public void setOutput(String output) {
+    this.output = output;
+  }
+  public int getExitCode() {
+    return exitCode;
+  }
+  public Exception getException() {
+    return exception;
+  }
+  public String getOutput() {
+    return output;
+  }
+  public String getPrivateKey() {
+    return privateKey;
+  }
+  public String getUser() {
+    return user;
+  }
+  public String getHost() {
+    return host;
+  }
+  public int getInstance() {
+    return instance;
+  }
 }

Modified: hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/RSyncCommandExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/RSyncCommandExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/RSyncCommandExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/RSyncCommandExecutor.java Mon Aug  5 22:31:28 2013
@@ -53,12 +53,12 @@ public class RSyncCommandExecutor {
         retry = false;
         if(command.getType() == RSyncCommand.Type.TO_LOCAL) {
           cmd = new LocalCommand(mLogger, collector,
-              String.format("rsync -qaPe \"ssh -i %s\" %s@%s:%s %s",
+              String.format("timeout 1h rsync -qaPe \"ssh -i %s\" --timeout 600 %s@%s:%s %s",
                   command.getPrivateKey(), command.getUser(), command.getHost(),
                   command.getRemoteFile(), command.getLocalFile()));
         } else if(command.getType() == RSyncCommand.Type.FROM_LOCAL) {
           cmd = new LocalCommand(mLogger, collector,
-              String.format("rsync -qaPe \"ssh -i %s\" --delete --delete-during --force %s %s@%s:%s",
+              String.format("timeout 1h rsync -qaPe \"ssh -i %s\" --timeout 600 --delete --delete-during --force %s %s@%s:%s",
                   command.getPrivateKey(), command.getLocalFile(), command.getUser(), command.getHost(),
                   command.getRemoteFile()));
         } else {

Modified: hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/SSHCommandExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/SSHCommandExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/SSHCommandExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/main/java/org/apache/hive/ptest/execution/ssh/SSHCommandExecutor.java Mon Aug  5 22:31:28 2013
@@ -50,11 +50,14 @@ public class SSHCommandExecutor {
         if(attempts++ <= 3 && cmd.getExitCode() == Constants.EXIT_CODE_UNKNOWN) {
           mLogger.warn("Command exited with " + cmd.getExitCode() + ", will retry: " + command);
           retry = true;
-          TimeUnit.SECONDS.sleep(20);
+          TimeUnit.SECONDS.sleep(5);
         }
       } while (retry); // an error occurred, re-try
       command.setExitCode(cmd.getExitCode());
     } catch (Exception e) {
+      if(command.getExitCode() == Constants.EXIT_CODE_SUCCESS) {
+        command.setExitCode(Constants.EXIT_CODE_EXCEPTION);
+      }
       command.setException(e);
     } finally {
       command.setOutput(collector.getOutput());

Modified: hive/branches/tez/testutils/ptest2/src/main/resources/batch-exec.vm
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/resources/batch-exec.vm?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/resources/batch-exec.vm (original)
+++ hive/branches/tez/testutils/ptest2/src/main/resources/batch-exec.vm Mon Aug  5 22:31:28 2013
@@ -40,7 +40,7 @@ cd $localDir/$instanceName/${repositoryN
 ret=$?
 if [[ $ret -ne 0 ]]
 then
-  if [[ $numOfFailedTests -lt 5 ]]
+  if [[ $numOfFailedTests -lt $maxSourceDirs ]]
   then
     cp -R $localDir/$instanceName/${repositoryName}-source $logDir/source
   else

Modified: hive/branches/tez/testutils/ptest2/src/main/resources/log4j.properties
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/resources/log4j.properties?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/resources/log4j.properties (original)
+++ hive/branches/tez/testutils/ptest2/src/main/resources/log4j.properties Mon Aug  5 22:31:28 2013
@@ -20,7 +20,7 @@ log4j.threshhold=ALL
 
 log4j.appender.FILE=org.apache.log4j.RollingFileAppender
 log4j.appender.FILE.File=${hive.ptest.logdir}/ptest.log
-log4j.appender.FILE.MaxFileSize=10MB
+log4j.appender.FILE.MaxFileSize=50MB
 log4j.appender.FILE.MaxBackupIndex=1
 log4j.appender.FILE.layout=org.apache.log4j.PatternLayout
 log4j.appender.FILE.layout.ConversionPattern=%d{yyyy-MM-dd HH:mm:ss} %-5p %c{1}:%L - %m%n
@@ -29,6 +29,5 @@ log4j.logger.org.apache.http=INFO
 log4j.logger.org.springframework=INFO
 log4j.logger.org.jclouds=INFO
 log4j.logger.jclouds=INFO
-log4j.logger.jclouds.compute=TRACE
 log4j.logger.org.apache.hive=DEBUG
-log4j.logger.org.apache.http=TRACE
\ No newline at end of file
+log4j.logger.org.apache.http=TRACE

Modified: hive/branches/tez/testutils/ptest2/src/main/resources/source-prep.vm
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/main/resources/source-prep.vm?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/main/resources/source-prep.vm (original)
+++ hive/branches/tez/testutils/ptest2/src/main/resources/source-prep.vm Mon Aug  5 22:31:28 2013
@@ -79,10 +79,9 @@ cd $workingDir/
   fi
   if [[ "$clearLibraryCache" == "true" ]]
   then
-  	rm -rf $workingDir/ivy $workingDir/maven
-  	mkdir $workingDir/ivy $workingDir/maven
+    rm -rf $workingDir/ivy $workingDir/maven
+    mkdir $workingDir/ivy $workingDir/maven
   fi
-  ant $antArgs -Divy.default.ivy.user.dir=$workingDir/ivy -Dmvn.local.repo=$workingDir/maven clean package
-  ant $antArgs -Divy.default.ivy.user.dir=$workingDir/ivy -Dmvn.local.repo=$workingDir/maven -Dtestcase=nothing test
+  ant $antArgs -Divy.default.ivy.user.dir=$workingDir/ivy -Dmvn.local.repo=$workingDir/maven clean package test -Dtestcase=nothing
 ) 2>&1 | tee $logDir/source-prep.txt
-exit ${PIPESTATUS[0]}
+exit ${PIPESTATUS[0]}
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/api/server/TestTestExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/api/server/TestTestExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/api/server/TestTestExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/api/server/TestTestExecutor.java Mon Aug  5 22:31:28 2013
@@ -92,7 +92,7 @@ public class TestTestExecutor {
     profilePropertiesOutputStream.close();
     ptestBuilder = new PTest.Builder() {
       @Override
-    public PTest build(TestConfiguration configuration, ExecutionContext executionContext,
+      public PTest build(TestConfiguration configuration, ExecutionContext executionContext,
           String buildTag, File logDir, LocalCommandFactory localCommandFactory, SSHCommandExecutor sshCommandExecutor,
           RSyncCommandExecutor rsyncCommandExecutor, Logger logger) throws Exception {
         return ptest;

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/AbstractTestPhase.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/AbstractTestPhase.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/AbstractTestPhase.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/AbstractTestPhase.java Mon Aug  5 22:31:28 2013
@@ -29,7 +29,9 @@ import java.util.concurrent.Executors;
 
 import junit.framework.Assert;
 
+import org.apache.hive.ptest.api.server.TestLogger;
 import org.apache.hive.ptest.execution.conf.Host;
+import org.apache.hive.ptest.execution.context.ExecutionContext;
 import org.slf4j.Logger;
 import org.slf4j.LoggerFactory;
 
@@ -71,6 +73,8 @@ public abstract class AbstractTestPhase 
   protected ImmutableMap<String, String> templateDefaults;
   protected ImmutableList<HostExecutor> hostExecutors;
   protected HostExecutor hostExecutor;
+  protected ExecutionContext executionContext;
+  protected HostExecutorBuilder hostExecutorBuilder;
   protected Logger logger;
 
   public void initialize(String name) throws Exception {
@@ -80,12 +84,14 @@ public abstract class AbstractTestPhase 
     succeededLogDir = Dirs.create(new File(logDir, "succeeded"));
     failedLogDir = Dirs.create(new File(logDir, "failed"));
     executor = MoreExecutors.listeningDecorator(Executors.newFixedThreadPool(2));
+    executionContext = mock(ExecutionContext.class);
+    hostExecutorBuilder = mock(HostExecutorBuilder.class);
     localCommandFactory = new MockLocalCommandFactory(LOG);
     localCommand = mock(LocalCommand.class);
     localCommandFactory.setInstance(localCommand);
     sshCommandExecutor = spy(new MockSSHCommandExecutor(LOG));
     rsyncCommandExecutor = spy(new MockRSyncCommandExecutor(LOG));
-    logger = LOG;
+    logger = new TestLogger(System.err, TestLogger.LEVEL.TRACE);
     templateDefaults = ImmutableMap.<String, String>builder()
         .put("localDir", LOCAL_DIR)
         .put("workingDir", WORKING_DIR)

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockLocalCommandFactory.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockLocalCommandFactory.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockLocalCommandFactory.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockLocalCommandFactory.java Mon Aug  5 22:31:28 2013
@@ -39,7 +39,7 @@ public class MockLocalCommandFactory ext
     return commands;
   }
   @Override
-public LocalCommand create(LocalCommand.CollectPolicy policy, String command)
+  public LocalCommand create(LocalCommand.CollectPolicy policy, String command)
       throws IOException {
     commands.add(command);
     return this.instance;

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockRSyncCommandExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockRSyncCommandExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockRSyncCommandExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockRSyncCommandExecutor.java Mon Aug  5 22:31:28 2013
@@ -62,7 +62,7 @@ public class MockRSyncCommandExecutor ex
     if(queue == null || queue.isEmpty()) {
       command.setExitCode(0);
     } else {
-     command.setExitCode(queue.remove());
+      command.setExitCode(queue.remove());
     }
   }
 

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockSSHCommandExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockSSHCommandExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockSSHCommandExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/MockSSHCommandExecutor.java Mon Aug  5 22:31:28 2013
@@ -38,7 +38,7 @@ public class MockSSHCommandExecutor exte
     mCommands = Lists.newArrayList();
     mFailures = Maps.newHashMap();
   }
-  public List<String> getCommands() {
+  public synchronized List<String> getCommands() {
     return mCommands;
   }
   public synchronized void putFailure(String command, Integer... exitCodes) {
@@ -54,14 +54,14 @@ public class MockSSHCommandExecutor exte
     }
   }
   @Override
-public synchronized void execute(SSHCommand command) {
+  public synchronized void execute(SSHCommand command) {
     mCommands.add(command.getCommand());
     command.setOutput("");
     Queue<Integer> queue = mFailures.get(command.getCommand());
     if(queue == null || queue.isEmpty()) {
       command.setExitCode(0);
     } else {
-     command.setExitCode(queue.remove());
+      command.setExitCode(queue.remove());
     }
   }
 }

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.java Mon Aug  5 22:31:28 2013
@@ -1,43 +0,0 @@
-/*
- * Licensed to the Apache Software Foundation (ASF) under one
- * or more contributor license agreements.  See the NOTICE file
- * distributed with this work for additional information
- * regarding copyright ownership.  The ASF licenses this file
- * to you under the Apache License, Version 2.0 (the
- * "License"); you may not use this file except in compliance
- * with the License.  You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing,
- * software distributed under the License is distributed on an
- * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
- * KIND, either express or implied.  See the License for the
- * specific language governing permissions and limitations
- * under the License.
- */
-package org.apache.hive.ptest.execution;
-
-import org.approvaltests.Approvals;
-import org.approvaltests.reporters.JunitReporter;
-import org.approvaltests.reporters.UseReporter;
-import org.junit.Before;
-import org.junit.Test;
-
-@UseReporter(JunitReporter.class)
-public class TestCleanupPhase extends AbstractTestPhase {
-  private CleanupPhase phase;
-
-  @Before
-  public void setup() throws Exception {
-    initialize(getClass().getSimpleName());
-    createHostExecutor();
-  }
-  @Test
-  public void testExecute() throws Exception {
-    phase = new CleanupPhase(hostExecutors, localCommandFactory,
-        templateDefaults, logger);
-    phase.execute();
-    Approvals.verify(getExecutedCommands());
-  }
-}

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.testExecute.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.testExecute.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.testExecute.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestCleanupPhase.testExecute.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,4 +0,0 @@
-killall -q -9 -f java || true
-rm -rf /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/logs
-rm -rf /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/logs
-rm -rf /some/working/dir/scratch
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.java Mon Aug  5 22:31:28 2013
@@ -61,9 +61,9 @@ public class TestExecutionPhase extends 
   }
   private ExecutionPhase getPhase() throws IOException {
     createHostExecutor();
-    phase = new ExecutionPhase(hostExecutors, localCommandFactory, templateDefaults,
-        succeededLogDir, failedLogDir, Suppliers.ofInstance(testBatches),
-        executedTests, failedTests, logger);
+    phase = new ExecutionPhase(hostExecutors, executionContext, hostExecutorBuilder, 
+        localCommandFactory, templateDefaults, succeededLogDir, failedLogDir,
+        Suppliers.ofInstance(testBatches), executedTests, failedTests, logger);
     return phase;
   }
   private void setupQFile(boolean isParallel) throws Exception {
@@ -126,4 +126,4 @@ public class TestExecutionPhase extends 
     Assert.assertEquals(Sets.newHashSet("SomeTest." + QFILENAME), executedTests);
     Assert.assertEquals(Sets.newHashSet("SomeTest." + QFILENAME), failedTests);
   }
-}
+}
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingQFile.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingQFile.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingQFile.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingQFile.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,3 +1,14 @@
+/some/working/dir/ivy /some/local/dir/somehost-someuser-0
+/some/working/dir/maven /some/local/dir/somehost-someuser-0
+/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-0
 /tmp/hive-ptest-units/TestExecutionPhase/logs/failed/driver-sometest /some/local/dir/somehost-someuser-0/logs/
 /tmp/hive-ptest-units/TestExecutionPhase/scratch/hiveptest-driver-sometest.sh /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
-bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
\ No newline at end of file
+bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
+killall -q -9 -f java || true
+mkdir -p /some/local/dir/somehost-someuser-0/logs /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-0/repositoryName-source
+mkdir -p /some/local/dir/somehost-someuser-1/logs /some/local/dir/somehost-someuser-1/maven /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/ivy /some/local/dir/somehost-someuser-1/repositoryName-source
+rm -rf /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/logs
+rm -rf /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/logs
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/repositoryName-source /some/local/dir/somehost-someuser-1/
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingUnitTest.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingUnitTest.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingUnitTest.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testFailingUnitTest.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,3 +1,14 @@
+/some/working/dir/ivy /some/local/dir/somehost-someuser-0
+/some/working/dir/maven /some/local/dir/somehost-someuser-0
+/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-0
 /tmp/hive-ptest-units/TestExecutionPhase/logs/failed/driver /some/local/dir/somehost-someuser-0/logs/
 /tmp/hive-ptest-units/TestExecutionPhase/scratch/hiveptest-driver.sh /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
-bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
\ No newline at end of file
+bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
+killall -q -9 -f java || true
+mkdir -p /some/local/dir/somehost-someuser-0/logs /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-0/repositoryName-source
+mkdir -p /some/local/dir/somehost-someuser-1/logs /some/local/dir/somehost-someuser-1/maven /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/ivy /some/local/dir/somehost-someuser-1/repositoryName-source
+rm -rf /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/logs
+rm -rf /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/logs
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/repositoryName-source /some/local/dir/somehost-someuser-1/
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingQFileTest.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingQFileTest.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingQFileTest.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingQFileTest.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,3 +1,14 @@
+/some/working/dir/ivy /some/local/dir/somehost-someuser-0
+/some/working/dir/maven /some/local/dir/somehost-someuser-0
+/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-0
 /tmp/hive-ptest-units/TestExecutionPhase/logs/succeeded/driver-sometest /some/local/dir/somehost-someuser-0/logs/
 /tmp/hive-ptest-units/TestExecutionPhase/scratch/hiveptest-driver-sometest.sh /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
-bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
\ No newline at end of file
+bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-sometest.sh
+killall -q -9 -f java || true
+mkdir -p /some/local/dir/somehost-someuser-0/logs /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-0/repositoryName-source
+mkdir -p /some/local/dir/somehost-someuser-1/logs /some/local/dir/somehost-someuser-1/maven /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/ivy /some/local/dir/somehost-someuser-1/repositoryName-source
+rm -rf /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/logs
+rm -rf /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/logs
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/repositoryName-source /some/local/dir/somehost-someuser-1/
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingUnitTest.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingUnitTest.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingUnitTest.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestExecutionPhase.testPassingUnitTest.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,3 +1,14 @@
+/some/working/dir/ivy /some/local/dir/somehost-someuser-0
+/some/working/dir/maven /some/local/dir/somehost-someuser-0
+/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-0
 /tmp/hive-ptest-units/TestExecutionPhase/logs/succeeded/driver /some/local/dir/somehost-someuser-0/logs/
 /tmp/hive-ptest-units/TestExecutionPhase/scratch/hiveptest-driver.sh /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
-bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
\ No newline at end of file
+bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver.sh
+killall -q -9 -f java || true
+mkdir -p /some/local/dir/somehost-someuser-0/logs /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-0/repositoryName-source
+mkdir -p /some/local/dir/somehost-someuser-1/logs /some/local/dir/somehost-someuser-1/maven /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/ivy /some/local/dir/somehost-someuser-1/repositoryName-source
+rm -rf /some/local/dir/somehost-someuser-0/scratch /some/local/dir/somehost-someuser-0/logs
+rm -rf /some/local/dir/somehost-someuser-1/scratch /some/local/dir/somehost-someuser-1/logs
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-1/
+rsync -qaPe --delete --delete-during --force /some/local/dir/somehost-someuser-0/repositoryName-source /some/local/dir/somehost-someuser-1/
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestHostExecutor.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestHostExecutor.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestHostExecutor.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestHostExecutor.java Mon Aug  5 22:31:28 2013
@@ -148,7 +148,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testBasic()
-  throws Exception {
+      throws Exception {
     HostExecutor executor = createHostExecutor();
     parallelWorkQueue.addAll(Lists.newArrayList(testBatchParallel1, testBatchParallel2));
     parallelWorkQueue.addAll(Lists.newArrayList(testBatchIsolated1, testBatchIsolated2));
@@ -158,7 +158,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testParallelFailsOnExec()
-  throws Exception {
+      throws Exception {
     sshCommandExecutor.putFailure("bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-parallel-1.sh",
         Constants.EXIT_CODE_UNKNOWN);
     HostExecutor executor = createHostExecutor();
@@ -170,7 +170,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testIsolatedFailsOnExec()
-  throws Exception {
+      throws Exception {
     sshCommandExecutor.putFailure("bash /some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-isolated-1.sh",
         Constants.EXIT_CODE_UNKNOWN);
     HostExecutor executor = createHostExecutor();
@@ -182,7 +182,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testParallelFailsOnRsync()
-  throws Exception {
+      throws Exception {
     rsyncCommandExecutor.putFailure("/tmp/hive-ptest-units/TestHostExecutor/scratch/hiveptest-driver-parallel-1.sh "
         + "/some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-parallel-1.sh", Constants.EXIT_CODE_UNKNOWN);
     HostExecutor executor = createHostExecutor();
@@ -194,7 +194,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testIsolatedFailsOnRsyncUnknown()
-  throws Exception {
+      throws Exception {
     rsyncCommandExecutor.putFailure("/tmp/hive-ptest-units/TestHostExecutor/scratch/hiveptest-driver-isolated-1.sh "+
         "/some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-isolated-1.sh", Constants.EXIT_CODE_UNKNOWN);
     HostExecutor executor = createHostExecutor();
@@ -206,7 +206,7 @@ public class TestHostExecutor {
   }
   @Test
   public void testIsolatedFailsOnRsyncOne()
-  throws Exception {
+      throws Exception {
     rsyncCommandExecutor.putFailure("/tmp/hive-ptest-units/TestHostExecutor/scratch/hiveptest-driver-isolated-1.sh "+
         "/some/local/dir/somehost-someuser-0/scratch/hiveptest-driver-isolated-1.sh", 1);
     HostExecutor executor = createHostExecutor();

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.java Mon Aug  5 22:31:28 2013
@@ -46,10 +46,10 @@ public class TestPhase extends AbstractT
   public void testExecLocallyFails() throws Throwable {
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            execLocally("local");
-          }
+      @Override
+      public void execute() throws Exception {
+        execLocally("local");
+      }
     };
     when(localCommand.getExitCode()).thenReturn(1);
     phase.execute();
@@ -58,10 +58,10 @@ public class TestPhase extends AbstractT
   public void testExecLocallySucceeds() throws Throwable {
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            execLocally("local");
-          }
+      @Override
+      public void execute() throws Exception {
+        execLocally("local");
+      }
     };
     phase.execute();
     List<String> commands = localCommandFactory.getCommands();
@@ -73,10 +73,10 @@ public class TestPhase extends AbstractT
     sshCommandExecutor.putFailure("echo", Constants.EXIT_CODE_UNKNOWN);
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            execInstances("echo");
-          }
+      @Override
+      public void execute() throws Exception {
+        execInstances("echo");
+      }
     };
     phase.execute();
     Approvals.verify(getExecutedCommands());
@@ -87,10 +87,10 @@ public class TestPhase extends AbstractT
     sshCommandExecutor.putFailure("echo", Constants.EXIT_CODE_UNKNOWN);
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            execHosts("echo");
-          }
+      @Override
+      public void execute() throws Exception {
+        execHosts("echo");
+      }
     };
     phase.execute();
     Approvals.verify(getExecutedCommands());
@@ -101,10 +101,10 @@ public class TestPhase extends AbstractT
     rsyncCommandExecutor.putFailure("local remote", Constants.EXIT_CODE_UNKNOWN);
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            rsyncFromLocalToRemoteInstances("local", "remote");
-          }
+      @Override
+      public void execute() throws Exception {
+        rsyncFromLocalToRemoteInstances("local", "remote");
+      }
     };
     phase.execute();
     Approvals.verify(getExecutedCommands());
@@ -115,10 +115,10 @@ public class TestPhase extends AbstractT
     rsyncCommandExecutor.putFailure("local remote", 1);
     phase = new Phase(hostExecutors, localCommandFactory,
         templateDefaults, logger) {
-          @Override
-          public void execute() throws Exception {
-            rsyncFromLocalToRemoteInstances("local", "remote");
-          }
+      @Override
+      public void execute() throws Exception {
+        rsyncFromLocalToRemoteInstances("local", "remote");
+      }
     };
     phase.execute();
     Approvals.verify(getExecutedCommands());

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureOne.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureOne.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureOne.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureOne.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,2 +1,3 @@
 local remote
-local remote
\ No newline at end of file
+local remote
+rsync -qaPe --delete --delete-during --force remote/local remote
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureUnknown.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureUnknown.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureUnknown.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPhase.testRsyncFromLocalToRemoteInstancesWithFailureUnknown.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,2 +1,3 @@
 local remote
-local remote
\ No newline at end of file
+local remote
+rsync -qaPe --delete --delete-during --force remote/local remote
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPrepPhase.testExecute.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPrepPhase.testExecute.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPrepPhase.testExecute.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestPrepPhase.testExecute.approved.txt Mon Aug  5 22:31:28 2013
@@ -1,12 +1,3 @@
-/some/working/dir/ivy /some/local/dir/somehost-someuser-0/
-/some/working/dir/ivy /some/local/dir/somehost-someuser-1/
-/some/working/dir/maven /some/local/dir/somehost-someuser-0/
-/some/working/dir/maven /some/local/dir/somehost-someuser-1/
-/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-0/
-/some/working/dir/repositoryName-source /some/local/dir/somehost-someuser-1/
 bash /tmp/hive-ptest-units/TestPrepPhase/source-prep.sh
-mkdir -p /some/local/dir/somehost-someuser-0/ivy /some/local/dir/somehost-someuser-0/repositoryName-source
-mkdir -p /some/local/dir/somehost-someuser-0/logs /some/local/dir/somehost-someuser-0/maven /some/local/dir/somehost-someuser-0/scratch
-mkdir -p /some/local/dir/somehost-someuser-1/ivy /some/local/dir/somehost-someuser-1/repositoryName-source
-mkdir -p /some/local/dir/somehost-someuser-1/logs /some/local/dir/somehost-someuser-1/maven /some/local/dir/somehost-someuser-1/scratch
-mkdir -p /some/working/dir/scratch
\ No newline at end of file
+mkdir -p /some/working/dir/scratch
+rm -rf /some/working/dir/scratch
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestReportParser.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestReportParser.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestReportParser.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestReportParser.java Mon Aug  5 22:31:28 2013
@@ -60,8 +60,27 @@ public class TestReportParser {
     Assert.assertEquals(3, parser.getFailedTests().size());
     Assert.assertEquals(Sets.
         newHashSet("org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_skewjoin_union_remove_1",
-        "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_union_remove_9",
-        "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_skewjoin"),
-        parser.getFailedTests());
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_union_remove_9",
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_skewjoin"),
+            parser.getFailedTests());
+    Assert.assertEquals(Sets.
+        newHashSet("org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_shutdown", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_binary_constant", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_skewjoin_union_remove_1", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_udf_regexp_extract", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_index_auth", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_auto_join17", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_authorization_2", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_load_dyn_part3", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_index_bitmap2", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_groupby_rollup1", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_bucketcontext_3", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_ppd_join", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_rcfile_lazydecompress", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_notable_alias1", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_union_remove_9", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_skewjoin", 
+            "org.apache.hadoop.hive.cli.TestCliDriver.testCliDriver_multi_insert_gby"),
+            parser.getExecutedTests());
   }
 }

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.java
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.java?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.java (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.java Mon Aug  5 22:31:28 2013
@@ -68,6 +68,7 @@ public class TestScripts  {
     templateVariables.put("instanceName", "instance-1");
     templateVariables.put("batchName","batch-1");
     templateVariables.put("numOfFailedTests", "20");
+    templateVariables.put("maxSourceDirs", String.valueOf(5));
     templateVariables.put("testArguments", "-Dtest=arg1");
     templateVariables.put("clearLibraryCache", "true");
     templateVariables.put("javaHome", "/usr/java/jdk1.7");

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepGit.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepGit.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepGit.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepGit.approved.txt Mon Aug  5 22:31:28 2013
@@ -78,10 +78,9 @@ cd /some/working/dir/
   fi
   if [[ "true" == "true" ]]
   then
-  	rm -rf /some/working/dir/ivy /some/working/dir/maven
-  	mkdir /some/working/dir/ivy /some/working/dir/maven
+    rm -rf /some/working/dir/ivy /some/working/dir/maven
+    mkdir /some/working/dir/ivy /some/working/dir/maven
   fi
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven -Dtestcase=nothing test
+  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package test -Dtestcase=nothing
 ) 2>&1 | tee /some/log/dir/source-prep.txt
-exit ${PIPESTATUS[0]}
+exit ${PIPESTATUS[0]}
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepNone.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepNone.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepNone.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepNone.approved.txt Mon Aug  5 22:31:28 2013
@@ -78,10 +78,9 @@ cd /some/working/dir/
   fi
   if [[ "false" == "true" ]]
   then
-  	rm -rf /some/working/dir/ivy /some/working/dir/maven
-  	mkdir /some/working/dir/ivy /some/working/dir/maven
+    rm -rf /some/working/dir/ivy /some/working/dir/maven
+    mkdir /some/working/dir/ivy /some/working/dir/maven
   fi
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven -Dtestcase=nothing test
+  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package test -Dtestcase=nothing
 ) 2>&1 | tee /some/log/dir/source-prep.txt
-exit ${PIPESTATUS[0]}
+exit ${PIPESTATUS[0]}
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepSvn.approved.txt
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepSvn.approved.txt?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
--- hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepSvn.approved.txt (original)
+++ hive/branches/tez/testutils/ptest2/src/test/java/org/apache/hive/ptest/execution/TestScripts.testPrepSvn.approved.txt Mon Aug  5 22:31:28 2013
@@ -78,10 +78,9 @@ cd /some/working/dir/
   fi
   if [[ "true" == "true" ]]
   then
-  	rm -rf /some/working/dir/ivy /some/working/dir/maven
-  	mkdir /some/working/dir/ivy /some/working/dir/maven
+    rm -rf /some/working/dir/ivy /some/working/dir/maven
+    mkdir /some/working/dir/ivy /some/working/dir/maven
   fi
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package
-  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven -Dtestcase=nothing test
+  ant -Dant=arg1 -Divy.default.ivy.user.dir=/some/working/dir/ivy -Dmvn.local.repo=/some/working/dir/maven clean package test -Dtestcase=nothing
 ) 2>&1 | tee /some/log/dir/source-prep.txt
-exit ${PIPESTATUS[0]}
+exit ${PIPESTATUS[0]}
\ No newline at end of file

Modified: hive/branches/tez/testutils/ptest2/src/test/resources/SomeTest-success.xml
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/resources/SomeTest-success.xml?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
Binary files - no diff available.

Modified: hive/branches/tez/testutils/ptest2/src/test/resources/test-outputs/SomeTest-truncated.xml
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/resources/test-outputs/SomeTest-truncated.xml?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
Binary files - no diff available.

Modified: hive/branches/tez/testutils/ptest2/src/test/resources/test-outputs/skewjoin_union_remove_1.q-TEST-org.apache.hadoop.hive.cli.TestCliDriver.xml
URL: http://svn.apache.org/viewvc/hive/branches/tez/testutils/ptest2/src/test/resources/test-outputs/skewjoin_union_remove_1.q-TEST-org.apache.hadoop.hive.cli.TestCliDriver.xml?rev=1510788&r1=1510787&r2=1510788&view=diff
==============================================================================
Binary files - no diff available.