You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by kw...@apache.org on 2011/09/29 17:29:37 UTC

svn commit: r1177333 - in /qpid/trunk/qpid/java: ./ systests/src/main/java/org/apache/qpid/test/utils/ test-profiles/

Author: kwall
Date: Thu Sep 29 15:29:36 2011
New Revision: 1177333

URL: http://svn.apache.org/viewvc?rev=1177333&view=rev
Log:
QPID-3513: Avoid use of shell script clean-dir during test cycle

Removed:
    qpid/trunk/qpid/java/test-profiles/clean-dir
Modified:
    qpid/trunk/qpid/java/common.xml
    qpid/trunk/qpid/java/module.xml
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/utils/QpidBrokerTestCase.java
    qpid/trunk/qpid/java/test-profiles/cpp.testprofile
    qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/java-bdb.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-bdb.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/java-dby.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-dby.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/java-mms.0-10.testprofile
    qpid/trunk/qpid/java/test-profiles/java-mms.0-9-1.testprofile
    qpid/trunk/qpid/java/test-profiles/testprofile.defaults

Modified: qpid/trunk/qpid/java/common.xml
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/common.xml?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/common.xml (original)
+++ qpid/trunk/qpid/java/common.xml Thu Sep 29 15:29:36 2011
@@ -42,7 +42,6 @@
   <property name="build.report"          location="${build}/report"/>
   <property name="build.release"         location="${build}/release"/>
   <property name="build.release.prepare" location="${build.release}/prepare"/>
-  <property name="build.data"            location="${build.scratch}/data"/>
   <property name="build.plugins"         location="${build}/lib/plugins"/>
   <property name="build.coveragereport"  location="${build}/coverage"/>
   <property name="build.findbugs"        location="${build}/findbugs"/>

Modified: qpid/trunk/qpid/java/module.xml
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/module.xml?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/module.xml (original)
+++ qpid/trunk/qpid/java/module.xml Thu Sep 29 15:29:36 2011
@@ -207,7 +207,6 @@
     <mkdir dir="${build.etc}"/>
     <mkdir dir="${build.lib}"/>
     <mkdir dir="${build.results}"/>
-    <mkdir dir="${build.data}"/>
     <mkdir dir="${build.plugins}"/>
     <mkdir dir="${module.classes}"/>
     <mkdir dir="${module.precompiled}"/>
@@ -670,7 +669,6 @@
       <sysproperty key="java.naming.factory.initial" value="${java.naming.factory.initial}"/>
       <sysproperty key="java.naming.provider.url" value="${java.naming.provider.url}"/>
       <sysproperty key="broker" value="${broker}"/>
-      <sysproperty key="broker.clean" value="${broker.clean}"/>
       <sysproperty key="broker.version" value="${broker.version}"/>
       <sysproperty key="broker.ready" value="${broker.ready}" />
       <sysproperty key="test.output" value="${module.results}"/>

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/utils/QpidBrokerTestCase.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/utils/QpidBrokerTestCase.java?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/utils/QpidBrokerTestCase.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/utils/QpidBrokerTestCase.java Thu Sep 29 15:29:36 2011
@@ -114,7 +114,6 @@ public class QpidBrokerTestCase extends 
     private static final String BROKER_LANGUAGE = "broker.language";
     private static final String BROKER_TYPE = "broker.type";
     private static final String BROKER_COMMAND = "broker.command";
-    private static final String BROKER_CLEAN = "broker.clean";
     private static final String BROKER_CLEAN_BETWEEN_TESTS = "broker.clean.between.tests";
     private static final String BROKER_EXISTING_QPID_WORK = "broker.existing.qpid.work";
     private static final String BROKER_VERSION = "broker.version";
@@ -142,7 +141,6 @@ public class QpidBrokerTestCase extends 
     protected String _brokerLanguage = System.getProperty(BROKER_LANGUAGE, JAVA);
     protected BrokerType _brokerType = BrokerType.valueOf(System.getProperty(BROKER_TYPE, "").toUpperCase());
     protected String _brokerCommand = System.getProperty(BROKER_COMMAND);
-    private String _brokerClean = System.getProperty(BROKER_CLEAN, null);
     private Boolean _brokerCleanBetweenTests = Boolean.getBoolean(BROKER_CLEAN_BETWEEN_TESTS);
     private final AmqpProtocolVersion _brokerVersion = AmqpProtocolVersion.valueOf(System.getProperty(BROKER_VERSION, ""));
     protected String _output = System.getProperty(TEST_OUTPUT);
@@ -263,14 +261,9 @@ public class QpidBrokerTestCase extends 
 
             if(_brokerCleanBetweenTests)
             {
-            	try
-            	{
-            		cleanBroker();
-            	}
-            	catch (Exception e)
-            	{
-            		_logger.error("exception cleaning up broker", e);
-            	}
+                final String qpidWork = System.getProperty("QPID_WORK");
+                cleanBrokerWork(qpidWork);
+                createBrokerWork(qpidWork);
             }
 
             _logger.info("==========  stop " + getTestName() + " ==========");
@@ -302,11 +295,11 @@ public class QpidBrokerTestCase extends 
         String existingQpidWorkPath = System.getProperty(BROKER_EXISTING_QPID_WORK);
         if(existingQpidWorkPath != null && !existingQpidWorkPath.equals(""))
         {
-            cleanBroker();
 
+            String qpidWork = getQpidWork(_brokerType, getPort());
             File existing = new File(existingQpidWorkPath);
-            File qpidWork = new File(getQpidWork(_brokerType, getPort()));
-            FileUtils.copyRecursive(existing, qpidWork);
+            cleanBrokerWork(qpidWork);
+            FileUtils.copyRecursive(existing, new File(qpidWork));
         }
 
         startBroker();
@@ -498,25 +491,22 @@ public class QpidBrokerTestCase extends 
         }
         else if (!_brokerType.equals(BrokerType.EXTERNAL))
         {
+            // Add the port to QPID_WORK to ensure unique working dirs for multi broker tests
+            final String qpidWork = getQpidWork(_brokerType, port);
             String cmd = getBrokerCommand(port);
             _logger.info("starting external broker: " + cmd);
             ProcessBuilder pb = new ProcessBuilder(cmd.split("\\s+"));
             pb.redirectErrorStream(true);
-
             Map<String, String> env = pb.environment();
-
             String qpidHome = System.getProperty(QPID_HOME);
             env.put(QPID_HOME, qpidHome);
-
             //Augment Path with bin directory in QPID_HOME.
             env.put("PATH", env.get("PATH").concat(File.pathSeparator + qpidHome + "/bin"));
 
             //Add the test name to the broker run.
             // DON'T change PNAME, qpid.stop needs this value.
             env.put("QPID_PNAME", "-DPNAME=QPBRKR -DTNAME=\"" + getTestName() + "\"");
-            // Add the port to QPID_WORK to ensure unique working dirs for multi broker tests
-            env.put("QPID_WORK", getQpidWork(_brokerType, port));
-
+            env.put("QPID_WORK", qpidWork);
 
             // Use the environment variable to set amqj.logging.level for the broker
             // The value used is a 'server' value in the test configuration to
@@ -567,6 +557,10 @@ public class QpidBrokerTestCase extends 
                     env.put("QPID_OPTS", QPID_OPTS);
                 }
             }
+
+            // cpp broker requires that the work directory is created
+            createBrokerWork(qpidWork);
+
             Process process = pb.start();;
 
             Piper p = new Piper(process.getInputStream(),
@@ -581,7 +575,7 @@ public class QpidBrokerTestCase extends 
                 _logger.info("broker failed to become ready (" + p.ready + "):" + p.getStopLine());
                 //Ensure broker has stopped
                 process.destroy();
-                cleanBroker();
+                cleanBrokerWork(qpidWork);
                 throw new RuntimeException("broker failed to become ready:"
                                            + p.getStopLine());
             }
@@ -591,7 +585,7 @@ public class QpidBrokerTestCase extends 
                 //test that the broker is still running and hasn't exited unexpectedly
                 int exit = process.exitValue();
                 _logger.info("broker aborted: " + exit);
-                cleanBroker();
+                cleanBrokerWork(qpidWork);
                 throw new RuntimeException("broker aborted: " + exit);
             }
             catch (IllegalThreadStateException e)
@@ -671,7 +665,7 @@ public class QpidBrokerTestCase extends 
 
     protected void saveTestConfiguration() throws ConfigurationException
     {
-        // Specifiy the test config file
+        // Specify the test config file
         String testConfig = getTestConfigFile();
         setSystemProperty("test.config", testConfig);
 
@@ -685,7 +679,7 @@ public class QpidBrokerTestCase extends 
 
     protected void saveTestVirtualhosts() throws ConfigurationException
     {
-        // Specifiy the test virtualhosts file
+        // Specify the test virtualhosts file
         String testVirtualhosts = getTestVirtualhostsFile();
         setSystemProperty("test.virtualhosts", testVirtualhosts);
 
@@ -697,30 +691,33 @@ public class QpidBrokerTestCase extends 
         _testVirtualhosts.save(testVirtualhosts);
     }
 
-    public void cleanBroker()
+    protected void cleanBrokerWork(final String qpidWork)
     {
-        if (_brokerClean != null)
+        if (qpidWork != null)
         {
-            _logger.info("clean: " + _brokerClean);
-
-            try
-            {
-                ProcessBuilder pb = new ProcessBuilder(_brokerClean.split("\\s+"));
-                pb.redirectErrorStream(true);
-                Process clean = pb.start();
-                new Piper(clean.getInputStream(),_brokerOutputStream).start();
-
-                clean.waitFor();
+            _logger.info("Cleaning broker work dir: " + qpidWork);
 
-                _logger.info("clean exited: " + clean.exitValue());
-            }
-            catch (IOException e)
+            File file = new File(qpidWork);
+            if (file.exists())
             {
-                throw new RuntimeException(e);
+                final boolean success = FileUtils.delete(file, true);
+                if(!success)
+                {
+                    throw new RuntimeException("Failed to recursively delete beneath : " + file);
+                }
             }
-            catch (InterruptedException e)
+        }
+    }
+
+    protected void createBrokerWork(final String qpidWork)
+    {
+        if (qpidWork != null)
+        {
+            final File dir = new File(qpidWork);
+            dir.mkdirs();
+            if (!dir.isDirectory())
             {
-                throw new RuntimeException(e);
+                throw new RuntimeException("Failed to created Qpid work directory : " + qpidWork);
             }
         }
     }
@@ -734,7 +731,7 @@ public class QpidBrokerTestCase extends 
     {
         port = getPort(port);
 
-        _logger.info("stopping broker: " + getBrokerCommand(port));
+        _logger.info("stopping broker on port : " + port);
         BrokerHolder broker = _brokers.remove(port);
         broker.shutdown();
     }
@@ -910,7 +907,7 @@ public class QpidBrokerTestCase extends 
     }
 
     /**
-     * Add an environtmen variable for the external broker environment
+     * Add an environment variable for the external broker environment
      *
      * @param property the property to set
      * @param value    the value to set it to
@@ -994,9 +991,9 @@ public class QpidBrokerTestCase extends 
      * Get the default connection factory for the currently used broker
      * Default factory is "local"
      *
-     * @return A conection factory
+     * @return A connection factory
      *
-     * @throws Exception if there is an error getting the tactory
+     * @throws Exception if there is an error getting the factory
      */
     public AMQConnectionFactory getConnectionFactory() throws NamingException
     {
@@ -1020,7 +1017,7 @@ public class QpidBrokerTestCase extends 
      *
      * @param factoryName The factory name
      *
-     * @return A conection factory
+     * @return A connection factory
      *
      * @throws Exception if there is an error getting the tactory
      */
@@ -1058,7 +1055,7 @@ public class QpidBrokerTestCase extends 
     {
         _logger.info("get connection");
         Connection con = getConnectionFactory().createConnection(username, password);
-        //add the connection in the lis of connections
+        //add the connection in the list of connections
         _connections.add(con);
         return con;
     }
@@ -1067,7 +1064,7 @@ public class QpidBrokerTestCase extends 
     {
         _logger.info("get Connection");
         Connection con = getConnectionFactory().createConnection(username, password, id);
-        //add the connection in the lis of connections
+        //add the connection in the list of connections
         _connections.add(con);
         return con;
     }
@@ -1158,7 +1155,7 @@ public class QpidBrokerTestCase extends 
     /**
      * Send messages to the given destination.
      *
-     * If session is transacted then messages will be commited before returning
+     * If session is transacted then messages will be committed before returning
      *
      * @param session the session to use for sending
      * @param destination where to send them to
@@ -1166,7 +1163,7 @@ public class QpidBrokerTestCase extends 
      *
      * @param batchSize the batchSize in which to commit, 0 means no batching,
      * but a single commit at the end
-     * @return the sent messgse
+     * @return the sent message
      *
      * @throws Exception
      */
@@ -1179,7 +1176,7 @@ public class QpidBrokerTestCase extends 
     /**
      * Send messages to the given destination.
      *
-     * If session is transacted then messages will be commited before returning
+     * If session is transacted then messages will be committed before returning
      *
      * @param session the session to use for sending
      * @param destination where to send them to
@@ -1188,7 +1185,7 @@ public class QpidBrokerTestCase extends 
      * @param offset offset allows the INDEX value of the message to be adjusted.
      * @param batchSize the batchSize in which to commit, 0 means no batching,
      * but a single commit at the end
-     * @return the sent messgse
+     * @return the sent message
      *
      * @throws Exception
      */

Modified: qpid/trunk/qpid/java/test-profiles/cpp.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/cpp.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/cpp.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/cpp.testprofile Thu Sep 29 15:29:36 2011
@@ -33,7 +33,7 @@ broker.modules=
 broker.args=
 
 broker.type=spawned
-broker.command=${broker.executable} -p @PORT --data-dir ${build.data}/@PORT -t --auth no --no-module-dir ${broker.modules} ${broker.args}
+broker.command=${broker.executable} -p @PORT --data-dir ${project.root}/build/work/@PORT -t --auth no --no-module-dir ${broker.modules} ${broker.args}
 
 profile.excludes=CPPPrefetchExcludes CPPTransientExcludes
 test.excludes=Excludes CPPExcludes ${profile}.excludes ${profile.excludes} cpp.excludes

Modified: qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@
 broker.language=java
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work/*
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-bdb.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-bdb-spawn.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@
 broker.language=java
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work/*
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-bdb.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-bdb.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-bdb.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-bdb.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-bdb.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@
 broker.language=java
 broker.type=internal
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work/*
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-bdb.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-bdb.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-bdb.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-bdb.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-bdb.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@
 broker.language=java
 broker.type=internal
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work/*
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-bdb.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.language=java
 broker.version=v0_10
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-derby.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-dby-spawn.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.version=v0_9_1
 broker.language=java
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-derby.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-dby.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-dby.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-dby.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-dby.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.language=java
 broker.version=v0_10
 broker.type=internal
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-derby.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-dby.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-dby.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-dby.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-dby.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.version=v0_9_1
 broker.language=java
 broker.type=internal
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.config=${project.root}/build/etc/config-systests-derby.xml

Modified: qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.version=v0_10
 broker.language=java
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 #

Modified: qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-mms-spawn.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.version=v0_9_1
 broker.language=java
 broker.type=spawned
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.protocol.excludes=--exclude-0-10 @PORT --exclude-0-10 @SSL_PORT

Modified: qpid/trunk/qpid/java/test-profiles/java-mms.0-10.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-mms.0-10.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-mms.0-10.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-mms.0-10.testprofile Thu Sep 29 15:29:36 2011
@@ -20,7 +20,6 @@ broker.language=java
 broker.version=v0_10
 broker.type=internal
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 

Modified: qpid/trunk/qpid/java/test-profiles/java-mms.0-9-1.testprofile
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/java-mms.0-9-1.testprofile?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/java-mms.0-9-1.testprofile (original)
+++ qpid/trunk/qpid/java/test-profiles/java-mms.0-9-1.testprofile Thu Sep 29 15:29:36 2011
@@ -21,7 +21,6 @@ broker.version=v0_9_1
 broker.type=internal
 #broker.command only used for the second broker during failover tests in this profile
 broker.command=${project.root}/build/bin/qpid-server -p @PORT -m @MPORT @EXCLUDES -c @CONFIG_FILE -l ${test.profiles}/log4j-test.xml
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=BRK-1004
 broker.stopped=Exception
 broker.protocol.excludes=--exclude-0-10 @PORT --exclude-0-10 @SSL_PORT

Modified: qpid/trunk/qpid/java/test-profiles/testprofile.defaults
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/testprofile.defaults?rev=1177333&r1=1177332&r2=1177333&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/testprofile.defaults (original)
+++ qpid/trunk/qpid/java/test-profiles/testprofile.defaults Thu Sep 29 15:29:36 2011
@@ -19,7 +19,6 @@
 java.naming.factory.initial=org.apache.qpid.jndi.PropertiesFileInitialContextFactory
 java.naming.provider.url=${test.profiles}/test-provider.properties
 
-broker.clean=${test.profiles}/clean-dir ${build.data} ${project.root}/build/work
 broker.ready=Listening on TCP
 broker.config=${project.root}/build/etc/config-systests.xml
 messagestore.class.name=org.apache.qpid.server.store.MemoryMessageStore



---------------------------------------------------------------------
Apache Qpid - AMQP Messaging Implementation
Project:      http://qpid.apache.org
Use/Interact: mailto:commits-subscribe@qpid.apache.org