You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2011/08/18 16:43:11 UTC

svn commit: r1159252 - in /qpid/trunk/qpid/java: systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java test-profiles/CPPExcludes

Author: robbie
Date: Thu Aug 18 14:43:11 2011
New Revision: 1159252

URL: http://svn.apache.org/viewvc?rev=1159252&view=rev
Log:
NO-JIRA: delete dead test (only runs against CPP brokers when run on linux, but is excluded from all CPP broker profiles)

Modified:
    qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java
    qpid/trunk/qpid/java/test-profiles/CPPExcludes

Modified: qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java?rev=1159252&r1=1159251&r2=1159252&view=diff
==============================================================================
--- qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java (original)
+++ qpid/trunk/qpid/java/systests/src/main/java/org/apache/qpid/test/unit/client/AMQConnectionTest.java Thu Aug 18 14:43:11 2011
@@ -272,113 +272,5 @@ public class AMQConnectionTest extends Q
             }
         }
     }
-    
-    /**
-     * Test Strategy : Kill -STOP the broker and see
-     * if the client terminates the connection with a
-     * read timeout.
-     * The broker process is cleaned up in the test itself
-     * and avoids using process.waitFor() as it hangs. 
-     */
-    public void testHeartBeat() throws Exception
-    {
-       boolean windows = 
-            ((String) System.getProperties().get("os.name")).matches("(?i).*windows.*");
- 
-       if (!isCppBroker() || windows)
-       {
-           return;
-       }
-       
-       Process process = null;
-       int port = getPort(0);
-       String pid = null;
-       try
-       {
-           // close the connection and shutdown the broker started by QpidTest
-           _connection.close();
-           stopBroker(port);
-           
-           setSystemProperty("qpid.heartbeat", "1");
-           
-           // in case this broker gets stuck, atleast the rest of the tests will not fail.
-           port = port + 200;
-           String startCmd = getBrokerCommand(port);
-           
-           // start a broker using a script
-           ProcessBuilder pb = new ProcessBuilder(System.getProperty("broker.start"));
-           pb.redirectErrorStream(true);
 
-           Map<String, String> env = pb.environment();
-           env.put("BROKER_CMD",startCmd);
-           env.put("BROKER_READY",System.getProperty(BROKER_READY));
-           
-           Process startScript = pb.start();
-           startScript.waitFor();
-           startScript.destroy();
-           
-           Connection con = 
-               new AMQConnection("amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:" + port + "'");
-           final AtomicBoolean lock = new AtomicBoolean(false);
-           
-           String cmd = "/usr/bin/pgrep -f " + port;
-           process = Runtime.getRuntime().exec("/bin/bash");
-           LineNumberReader reader = new LineNumberReader(new InputStreamReader(process.getInputStream()));
-           PrintWriter out = new PrintWriter(new BufferedWriter(new OutputStreamWriter(process.getOutputStream())), true); 
-           out.println(cmd); 
-           pid = reader.readLine();
-           try
-           {
-               Integer.parseInt(pid);
-           }
-           catch (NumberFormatException e) 
-           {
-               // Error! try to read further to gather the error msg.
-               String line;
-               _logger.debug(pid);
-               while ((line = reader.readLine()) != null )
-               {
-                   _logger.debug(line);
-               }
-               throw new Exception( "Unable to get the brokers pid " + pid);
-           }
-           _logger.debug("pid : " + pid);
-           
-           con.setExceptionListener(new ExceptionListener(){
-               
-               public void onException(JMSException e)
-               {
-                   synchronized(lock) {
-                       lock.set(true);
-                       lock.notifyAll();
-                  }
-               }           
-           });   
-
-           out.println("kill -STOP " + pid);           
-           
-           synchronized(lock){
-               lock.wait(2500);
-           }
-           out.close();
-           reader.close();
-           assertTrue("Client did not terminate the connection, check log for details",lock.get());
-       }
-       catch(Exception e)
-       {
-           throw e;
-       }
-       finally
-       {           
-           if (process != null)
-           {
-               process.destroy();
-           }
-           
-           Process killScript = Runtime.getRuntime().exec(System.getProperty("broker.kill") + " " + pid);
-           killScript.waitFor();
-           killScript.destroy();
-           cleanBroker();
-       }
-    }
 }

Modified: qpid/trunk/qpid/java/test-profiles/CPPExcludes
URL: http://svn.apache.org/viewvc/qpid/trunk/qpid/java/test-profiles/CPPExcludes?rev=1159252&r1=1159251&r2=1159252&view=diff
==============================================================================
--- qpid/trunk/qpid/java/test-profiles/CPPExcludes (original)
+++ qpid/trunk/qpid/java/test-profiles/CPPExcludes Thu Aug 18 14:43:11 2011
@@ -144,9 +144,6 @@ org.apache.qpid.test.unit.ack.FailoverBe
 
 org.apache.qpid.test.client.RollbackOrderTest#testOrderingAfterRollbackOnMessage#*
 
-// Temporarily adding the following until the issues are sorted out.
-org.apache.qpid.test.unit.client.AMQConnectionTest#testHeartBeat
-
 //Excluded due to QPID-1447 : CPP broker does not have SlowConsumer Disconnection
 org.apache.qpid.systest.GlobalQueuesTest#*
 org.apache.qpid.systest.GlobalTopicsTest#*



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