You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by bh...@apache.org on 2007/04/25 16:46:04 UTC

svn commit: r532372 - in /incubator/qpid/branches/M2/java/perftests: etc/scripts/ src/main/java/org/apache/qpid/ping/ src/main/java/org/apache/qpid/requestreply/ src/test/java/org/apache/qpid/ping/ src/test/java/org/apache/qpid/requestreply/

Author: bhupendrab
Date: Wed Apr 25 07:46:03 2007
New Revision: 532372

URL: http://svn.apache.org/viewvc?view=rev&rev=532372
Log:
Made the return type of getTestMessage() to a generic type for subclass to override.

Added:
    incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh   (with props)
Modified:
    incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/ping/PingSendOnlyClient.java
    incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/requestreply/PingPongProducer.java
    incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingLatencyTestPerf.java
    incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingTestPerf.java
    incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/requestreply/PingPongTestPerf.java

Added: incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh?view=auto&rev=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh (added)
+++ incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh Wed Apr 25 07:46:03 2007
@@ -0,0 +1,22 @@
+#!/bin/bash
+#
+# 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.
+#
+#
+
+$JAVA_HOME/bin/java -Dlog4j.configuration=backup-log4j.xml -cp qpid-perftests-1.0-incubating-M2-SNAPSHOT-all-test-deps.jar org.apache.qpid.ping.PingSendOnlyClient messageSize=512

Propchange: incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/qpid/branches/M2/java/perftests/etc/scripts/sendAndWaitClient.sh
------------------------------------------------------------------------------
    svn:executable = *

Modified: incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/ping/PingSendOnlyClient.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/ping/PingSendOnlyClient.java?view=diff&rev=532372&r1=532371&r2=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/ping/PingSendOnlyClient.java (original)
+++ incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/ping/PingSendOnlyClient.java Wed Apr 25 07:46:03 2007
@@ -6,6 +6,12 @@
 import org.apache.log4j.Logger;
 
 import org.apache.qpid.util.CommandLineParser;
+import org.apache.qpid.client.message.TestMessageFactory;
+
+import javax.jms.ObjectMessage;
+import javax.jms.Destination;
+import javax.jms.JMSException;
+import javax.jms.Message;
 
 /**
  * <p><table id="crc"><caption>CRC Card</caption>
@@ -32,7 +38,7 @@
         {
             // Create a ping producer overriding its defaults with all options passed on the command line.
             Properties options = CommandLineParser.processCommandLine(args, new CommandLineParser(new String[][] {}));
-            PingDurableClient pingProducer = new PingSendOnlyClient(options);
+            PingSendOnlyClient pingProducer = new PingSendOnlyClient(options);
 
             // Create a shutdown hook to terminate the ping-pong producer.
             Runtime.getRuntime().addShutdownHook(pingProducer.getShutdownHook());
@@ -53,5 +59,15 @@
             log.error("Top level handler caught execption.", e);
             System.exit(1);
         }
+    }
+
+    public Message getTestMessage(Destination replyQueue, int messageSize, boolean persistent) throws JMSException
+    {
+        Message msg = TestMessageFactory.newTextMessage(_producerSession, messageSize);
+
+        // Timestamp the message in nanoseconds.
+        msg.setLongProperty(MESSAGE_TIMESTAMP_PROPNAME, System.nanoTime());
+
+        return msg;
     }
 }

Modified: incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/requestreply/PingPongProducer.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/requestreply/PingPongProducer.java?view=diff&rev=532372&r1=532371&r2=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/requestreply/PingPongProducer.java (original)
+++ incubator/qpid/branches/M2/java/perftests/src/main/java/org/apache/qpid/requestreply/PingPongProducer.java Wed Apr 25 07:46:03 2007
@@ -1049,7 +1049,7 @@
         try
         {
             // Generate a sample message and time stamp it.
-            ObjectMessage msg = getTestMessage(_replyDestination, _messageSize, _persistent);
+            Message msg = getTestMessage(_replyDestination, _messageSize, _persistent);
             msg.setLongProperty(MESSAGE_TIMESTAMP_PROPNAME, System.nanoTime());
 
             // Send the message and wait for a reply.
@@ -1096,7 +1096,7 @@
      *
      * @throws javax.jms.JMSException All underlying JMSException are allowed to fall through.
      */
-    public ObjectMessage getTestMessage(Destination replyQueue, int messageSize, boolean persistent) throws JMSException
+    public Message getTestMessage(Destination replyQueue, int messageSize, boolean persistent) throws JMSException
     {
         ObjectMessage msg = TestMessageFactory.newObjectMessage(_producerSession, replyQueue, messageSize, persistent);
 

Modified: incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingLatencyTestPerf.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingLatencyTestPerf.java?view=diff&rev=532372&r1=532371&r2=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingLatencyTestPerf.java (original)
+++ incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingLatencyTestPerf.java Wed Apr 25 07:46:03 2007
@@ -168,7 +168,7 @@
         pingClient.setChainedMessageListener(batchedResultsListener);
 
         // Generate a sample message of the specified size.
-        ObjectMessage msg =
+        Message msg =
             pingClient.getTestMessage(perThreadSetup._pingClient.getReplyDestinations().get(0),
                                       testParameters.getPropertyAsInteger(PingPongProducer.MESSAGE_SIZE_PROPNAME),
                                       testParameters.getPropertyAsBoolean(PingPongProducer.PERSISTENT_MODE_PROPNAME));

Modified: incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingTestPerf.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingTestPerf.java?view=diff&rev=532372&r1=532371&r2=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingTestPerf.java (original)
+++ incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/ping/PingTestPerf.java Wed Apr 25 07:46:03 2007
@@ -140,7 +140,7 @@
         }
 
         // Generate a sample message. This message is already time stamped and has its reply-to destination set.
-        ObjectMessage msg =
+        Message msg =
             perThreadSetup._pingClient.getTestMessage(perThreadSetup._pingClient.getReplyDestinations().get(0),
                 testParameters.getPropertyAsInteger(PingPongProducer.MESSAGE_SIZE_PROPNAME),
                 testParameters.getPropertyAsBoolean(PingPongProducer.PERSISTENT_MODE_PROPNAME));

Modified: incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/requestreply/PingPongTestPerf.java
URL: http://svn.apache.org/viewvc/incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/requestreply/PingPongTestPerf.java?view=diff&rev=532372&r1=532371&r2=532372
==============================================================================
--- incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/requestreply/PingPongTestPerf.java (original)
+++ incubator/qpid/branches/M2/java/perftests/src/test/java/org/apache/qpid/requestreply/PingPongTestPerf.java Wed Apr 25 07:46:03 2007
@@ -148,7 +148,7 @@
         PerThreadSetup perThreadSetup = threadSetup.get();
 
         // Generate a sample message. This message is already time stamped and has its reply-to destination set.
-        ObjectMessage msg =
+        Message msg =
             perThreadSetup._testPingProducer.getTestMessage(perThreadSetup._testPingProducer.getReplyDestinations().get(0),
                 testParameters.getPropertyAsInteger(PingPongProducer.MESSAGE_SIZE_PROPNAME),
                 testParameters.getPropertyAsBoolean(PingPongProducer.PERSISTENT_MODE_PROPNAME));