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 2017/10/22 15:33:43 UTC

[5/5] qpid-broker-j git commit: QPID-7984: [Qpid Broker-J] [Tools] Remove unused tools.

QPID-7984: [Qpid Broker-J] [Tools] Remove unused tools.


Project: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/repo
Commit: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/commit/a48234d2
Tree: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/tree/a48234d2
Diff: http://git-wip-us.apache.org/repos/asf/qpid-broker-j/diff/a48234d2

Branch: refs/heads/master
Commit: a48234d2bb5b7851a4e410e84062b97e07f2a5d4
Parents: d896a0d
Author: Keith Wall <ke...@gmail.com>
Authored: Sun Oct 22 16:26:39 2017 +0100
Committer: Keith Wall <ke...@gmail.com>
Committed: Sun Oct 22 16:26:39 2017 +0100

----------------------------------------------------------------------
 tools/README.txt                                | 153 ----
 tools/bin/Profile-run-from-source               |  70 --
 tools/bin/check-qpid-java-env                   |  38 -
 tools/bin/jms-quick-perf-report                 | 137 ---
 tools/bin/mercury-controller                    | 132 ---
 tools/bin/mercury-start-consumers               | 119 ---
 tools/bin/mercury-start-producers               | 136 ---
 tools/bin/qpid-bench                            |  23 -
 tools/bin/qpid-jms-benchmark                    | 316 -------
 tools/bin/qpid-jms-receive                      | 193 ----
 tools/bin/qpid-jms-send                         | 261 ------
 tools/bin/qpid-python-testkit                   |  33 -
 tools/bin/run-pub                               |  28 -
 tools/bin/run-sub                               |  32 -
 tools/bin/testkit.py                            | 278 ------
 tools/etc/perf-report.gnu                       |  61 --
 tools/pom.xml                                   |   6 -
 .../java/org/apache/qpid/testkit/Client.java    | 154 ----
 .../org/apache/qpid/testkit/ErrorHandler.java   |  27 -
 .../java/org/apache/qpid/testkit/Receiver.java  | 216 -----
 .../java/org/apache/qpid/testkit/Sender.java    | 197 ----
 .../org/apache/qpid/testkit/TestLauncher.java   | 346 -------
 .../main/java/org/apache/qpid/tools/Clock.java  | 123 ---
 .../java/org/apache/qpid/tools/JNDICheck.java   | 201 ----
 .../apache/qpid/tools/JVMArgConfiguration.java  | 450 ---------
 .../qpid/tools/MemoryConsumptionTestClient.java |  18 +-
 .../java/org/apache/qpid/tools/MercuryBase.java | 190 ----
 .../qpid/tools/MercuryConsumerController.java   | 233 -----
 .../qpid/tools/MercuryProducerController.java   | 213 -----
 .../qpid/tools/MercuryTestController.java       | 452 ---------
 .../org/apache/qpid/tools/MessageFactory.java   |  66 --
 .../java/org/apache/qpid/tools/QpidBench.java   | 914 -------------------
 .../java/org/apache/qpid/tools/QpidReceive.java | 206 -----
 .../java/org/apache/qpid/tools/QpidSend.java    | 306 -------
 .../apache/qpid/tools/RestStressTestClient.java |  14 +-
 .../apache/qpid/tools/TestConfiguration.java    | 134 ---
 .../apache/qpid/tools/report/BasicReporter.java | 113 ---
 .../qpid/tools/report/MercuryReporter.java      | 179 ----
 .../org/apache/qpid/tools/report/Reporter.java  |  40 -
 .../apache/qpid/tools/report/Statistics.java    | 147 ---
 40 files changed, 17 insertions(+), 6938 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/README.txt
----------------------------------------------------------------------
diff --git a/tools/README.txt b/tools/README.txt
deleted file mode 100644
index aad2d05..0000000
--- a/tools/README.txt
+++ /dev/null
@@ -1,153 +0,0 @@
-Introduction
-============
-
-The Test kit for the Apache Qpid JMS Client for AMQP 0-9-1/0-10 consists of 2 components.
-
-1) A Simple Perf Test that can be used to,
-   a) Run a predefined perf report consisting of 8 use cases (see below)
-   b) Run a producer and a consumer with a number of different options
-
-2) Soak tests that can be run for longer durations (hours or days).
-
-I am planning to add some stress tests to this module as well.
-Please note this is not a replacement for the existing perf/systests etc.
-But rather a small test kit thats focused on providing a packaged set of tests that can be quickly deployed on an environment to do quick smoke testing or easily setup a soak test.
-
-Table of Contents
-=================
-1. Perf Kit
-2. Soak Kit
-3. Perf Test use cases
-4. Soak Test use cases
-5. Running the sample perf test report
-6. Running the sample soak test report
-
-1.0 Perf Kit
-------------
-1.1 The perf kit can be packaged as an RPM or a tar file and deploy on a target environment and run the perf report.
-Or else a perf report can be automated to run every day or so an record numbers to catch perf regressions.
-
-1.2 It calculates the following results in msg/sec.
-    
-    System throuhgput : no_of_msgs / (time_last_msg_rcvd - time_first_msg_send)
-
-    Producer rate : no_of_msgs / (time_after_sending - time_before_sending)
-
-    Producer rate : no_of_msgs / (time_last_msg_rcvd - time_first_msg_rcvd)
-
-    Latency : time_msg_rcvd - time_msg_sent
-
-The test will print min, max and avg latency.
-
-1.3 The test assume that both producer and consumer are run on the same machine or different machines that are time synced.
-
-1.4 You can also use run_sub.sh and run_pub.sh to run different use cases with several options.
-    Please look at TestParams.java for all the configurable options.
-
-1.5 You can also use the test kit to benchmark against any vendor.
-
-
-2.0 Soak tests
---------------
-2.0 This includes a set of soak tests that can be run for a longer duration.
-
-2.1 A typical test will send x-1 messages and the xth message will contain an "End" marker.
-    The producer will print the timestamp as soon as it sends the xth message.
-    The consumer will reply with an empty message to the replyTo destination given in the xth message.
-    The consumer prints the throuhgput for the iteration and the latency for the xth message.
-    A typical value for x is 100k
-
-2.2 The feedback loop prevents the producer from overrunning the consumer.
-    And the printout for every xth message will let you know how many iterations been completed at any given time.
-    (Ex a simple cat log | wc -l will give you the how many iterations have been completed so far).
-
-2.2 The following results can be calculated for these tests.
-    
-    Memory, CPU for each producer/consumer - look at testkit/bin/run_soak_client.sh for an example
-    
-    You can find the Avg, Min & Max for throughput, latency, CPU and memory for the entire test run.
-    (look at testkit/bin/soak_report.sh) for an example).
-
-    You could also graph throughput, latency, CPU and memory using the comma separated log files.
-
-2.2 If you use different machines for producer and consumer the machines have to be time synced to have meaningful latency samples.
- 
-3.0 Perf Test report use cases
--------------------------------
-3.1 Please check testkit/bin/perf_report.sh for more details
-
-3.2 A typical test run will send 1000 msgs during warmup and 200k msgs for result calculation.
-
-Test 1 Trans Queue
-
-Test 2 Dura Queue
-
-Test 3 Dura Queue Sync
-
-Test 4 Topic
-
-Test 5 Durable Topic
-
-Test 6 Fanout
-
-Test 7 Small TX (about 2 msgs per tx)
-
-Test 8 Large TX (about 1000 msgs per tx)
-
-
-4.0 Soak tests use cases
--------------------------
-4.1 Following are the current tests available in the test kit.
-
-4.2 Please refer to the source to see the javadoc and options
-
-
-1. SimpleProducer/Consumer sends X messages at a time and will wait for confirmation from producer before proceeding with the next iteration. A no of options can be configured.
-
-2. MultiThreadedProducer/Consumer does the same thing as above but runs each session in a separate thread.
-   It can also send messages transactionally. Again a no of options can be configured.
-
-3. ResourceLeakTest will setup consumer/producers sends x messages and then teard down everything and continue again.
-
-
-5.0 Running the sample perf test report
----------------------------------------
-The testkit/bin contains perf_report.sh.
-It runs the above 8 use cases against a broker and print the results in a tabular format. 
-
-For example
-================================================================================================
-|Test           |System throuput|Producer rate|Consumer Rate|Avg Latency|Min Latency|Max Latency|
-------------------------------------------------------------------------------------------------
-|Trans_Queue    |       xxxxx.xx|     xxxxx.xx|     xxxxx.xx|      xx.xx|          x|         xx|
-
-
-5.1 running perf_report.sh
-
-5.1.1 set JAVA_HOME to point to Java 1.5 and above
-5.1.2 set QPID_TEST_HOME to point to the testkit dir
-5.1.3 set VENDOR_LIB to point to the Qpid (or other JMS providers) jar files.
-5.1.4 start a broker
-5.1.5 update the testkit/etc/jndi.properties to point to the correct broker
-5.1.6 execute perf_report.sh
-
-
-6.0 Running the sample soak test report
----------------------------------------
-The testkit/bin contains soak_report.sh
-It runs MultiThreadedProducer/Consumer for the duration specified and prints a report for the following stats.
-Avg, Min and Max for System Throughput, letency, CPU and memory.
-
-6.1 running soak_report.sh
-
-5.1.1 set JAVA_HOME to point to Java 1.5 and above
-5.1.2 set QPID_TEST_HOME to point to the testkit dir
-5.1.3 set JAR_PATH to point to the Qpid jars
-5.1.4 start a broker
-5.1.5 execute soak_report.sh with correct params. 
-      Ex sh soak_report.sh 1 36000 will run for 10 hours colllecting CPU, memory every second.
-
-5.1.6 Please note the total duration for the test is log_freq * log_iterations
-      So if you want to run the test for 10 hours and collect 10 second samples then do the following
-      sh soak_report.sh 10 3600 
-

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/Profile-run-from-source
----------------------------------------------------------------------
diff --git a/tools/bin/Profile-run-from-source b/tools/bin/Profile-run-from-source
deleted file mode 100755
index 5485057..0000000
--- a/tools/bin/Profile-run-from-source
+++ /dev/null
@@ -1,70 +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.
-#
-
-# Sets the environment for running the scripts from a source checkout.
-txtbld=$(tput bold)             # Bold
-txtrst=$(tput sgr0)             # Reset
-txtred=$(tput setaf 1)          # red
-txtgreen=$(tput setaf 2)        # green
-
-echo "${txtbld}Setting the environment to run qpid java tools from a source checkout${txtrst}"
-
-abs_path()
-{
-  D=`dirname "$1"` 
-  echo "`cd \"$D\" 2>/dev/null && pwd`"
-}
-
-export QPID_CHECKOUT=`abs_path "../../../../"`
-echo "${txtgreen}Using source checkout at $QPID_CHECKOUT${txtrst}"
-
-export PATH=$QPID_CHECKOUT/java/tools/bin:$PATH
-
-if [ "$JAVA" = "" ] ; then
-    export JAVA=$(which java)
-fi
-
-#------------- Required for perf_report, qpid-bench & qpid-python-testkit ----------------
-
-export VENDOR_LIB=$QPID_CHECKOUT/java/build/lib
-export CLASSPATH=`find $VENDOR_LIB -name '*.jar' | tr '\n' ':'`
-
-
-#------------- Required for qpid-python-testkit -----------------------------------------
-
-PYTHONPATH=$QPID_CHECKOUT/python:$QPID_CHECKOUT/cpp/src/test/brokertest.py:$PYTHONPATH
-export PATH=$QPID_CHECKOUT/python:$PATH
-
-if [ -x $QPID_CHECKOUT/cpp/src/qpidd ]; then
-   QPIDD_EXEC=$QPID_CHECKOUT/cpp/src/qpidd
-else
-      echo "${txtred}WARNING: Qpid CPP broker executable not found. You will not be able to run qpid-python-testkit${txtrst}"
-fi
-
-if [ -x $QPID_CHECKOUT/cpp/src/.libs/cluster.so ]; then
-      CLUSTER_LIB=$QPID_CHECKOUT/cpp/src/.libs/cluster.so
-else
-     echo "${txtred}WARNING: Qpid cluster.so not found.You will not be able to run qpid-python-testkit${txtrst}"
-fi
-
-if [ "$STORE_LIB" = "" ] ; then
-     echo "${txtred}WARNING: Please point the STORE_LIB variable to the message store module. If not persistence tests will not write messages to disk.${txtrst}"
-fi
-
-export PYTHONPATH QPIDD_EXEC CLUSTER_LIB

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/check-qpid-java-env
----------------------------------------------------------------------
diff --git a/tools/bin/check-qpid-java-env b/tools/bin/check-qpid-java-env
deleted file mode 100755
index 47224e0..0000000
--- a/tools/bin/check-qpid-java-env
+++ /dev/null
@@ -1,38 +0,0 @@
-#!/usr/bin/env 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.
-#
-
-if  [ -z "$LOG_CONFIG" ]; then
-  echo "Please set the appropriate parameters for logging as it may affect performance. Ex logback defaults to DEBUG if not configured"
-  exit -1
-fi
-
-if [ -z "$JAVA_MEM" ]; then
-   JAVA_MEM=-Xmx1024m 
-fi
-
-if [ -z "$JAVA" ]; then
-   echo "Please set the path to the correct java executable to JAVA"
-   exit -1
-fi
-
-if [ -z "$CLASSPATH" ]; then
-   echo "Please set the $CLASSPATH variable to point to the jar/class files"
-   exit -1
-fi

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/jms-quick-perf-report
----------------------------------------------------------------------
diff --git a/tools/bin/jms-quick-perf-report b/tools/bin/jms-quick-perf-report
deleted file mode 100755
index 7de3f2b..0000000
--- a/tools/bin/jms-quick-perf-report
+++ /dev/null
@@ -1,137 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This will run the following test cases defined below and produce
-# a report in tabular format.
-
-QUEUE="queue;{create:always,node:{x-declare:{auto-delete:true}}}"
-DURA_QUEUE="dqueue;{create:always,node:{durable:true,x-declare:{auto-delete:true}}}"
-TOPIC="amq.topic/test"
-DURA_TOPIC="amq.topic/test;{create:always,link:{durable:true}}"
-
-COMMON_CONFIG="-server -Durl=amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672'"
-
-waitfor() { until grep -a -l "$2" $1 >/dev/null 2>&1 ; do sleep 1 ; done ; }
-cleanup()
-{  
-  pids=`ps aux | grep java | grep Perf | awk '{print $2}'`
-  if [ "$pids" != "" ]; then
-    kill -3 $pids
-    kill -9 $pids >/dev/null 2>&1
-  fi
-}
-
-# $1 test name
-# $2 consumer options
-# $3 producer options
-run_testcase()
-{  
-  sh run-sub $COMMON_CONFIG $2 > sub.out &
-  sh run-pub $COMMON_CONFIG $3 > pub.out &
-  waitfor pub.out "Controller: Completed the test"
-  sleep 2 #give a grace period to shutdown
-  print_result $1
-  mv pub.out $1.pub.out
-  mv sub.out $1.sub.out
-}
-
-print_result()
-{
-  prod_rate=`cat pub.out | grep "Avg Producer rate" | awk '{print $5}'`
-  sys_rate=`cat pub.out | grep "System Throughput" | awk '{print $4}'`
-  cons_rate=`cat pub.out | grep "Avg Consumer rate" | awk '{print $5}'` 
-  avg_latency=`cat pub.out | grep "Avg System Latency" | awk '{print $5}'`
-  min_latency=`cat pub.out | grep "Min System Latency" | awk '{print $5}'`
-  max_latency=`cat pub.out | grep "Max System Latency" | awk '{print $5}'`
-
-  printf "|%-15s|%15.2f|%13.2f|%13.2f|%11.2f|%11.2f|%11.2f|\n" $1 $sys_rate $prod_rate $cons_rate $avg_latency $min_latency $max_latency
-  echo "------------------------------------------------------------------------------------------------"
-}
-
-trap cleanup EXIT
-rm -rf *.out #cleanup old files.
-
-echo "Test report on " `date +%F`
-echo "================================================================================================"
-echo "|Test           |System throuput|Producer rate|Consumer Rate|Avg Latency|Min Latency|Max Latency|"
-echo "------------------------------------------------------------------------------------------------"
-
-# The message counts and warmup counts are set to very low values for quick testing of the script.
-# For a real performance run I recommend setting warmup count to 10k and message count in excess of 100k
-# However for transactions, sync_publish and especially small durable transactions (which is quite slow) I recommend
-# setting very low values to start with and experiment while increasing them slowly.
-
-# Test 1 Trans Queue
-run_testcase "Trans_Queue" "-Daddress=$QUEUE" "-Daddress=$QUEUE -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 2 Dura Queue
-run_testcase "Dura_Queue" "-Daddress=$DURA_QUEUE -Ddurable=true" "-Daddress=$DURA_QUEUE -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 3 Dura Queue Sync
-run_testcase "Dura_Queue_Sync" "-Daddress=$DURA_QUEUE -Ddurable=true" "-Daddress=$DURA_QUEUE -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10 -Dsync_publish=persistent"
-
-# Test 4 Dura Queue Sync Publish and Ack
-run_testcase "Dura_SyncPubAck" "-Daddress=$DURA_QUEUE -Ddurable=true -Dsync_ack=true" "-Daddress=$DURA_QUEUE -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10 -Dsync_publish=persistent"
-
-# Test 5 Topic
-run_testcase "Topic" "-Daddress=$TOPIC" "-Daddress=$TOPIC -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 6 Durable Topic
-run_testcase "Dura_Topic" "-Daddress=$DURA_TOPIC -Ddurable=true" "-Daddress=$DURA_TOPIC -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 7 Fanout
-run_testcase "Fanout" "-Daddress=amq.fanout" "-Daddress=amq.fanout -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 8 Small TX
-run_testcase "Small_Txs_2" "-Daddress=$DURA_QUEUE -Ddurable=true -Dtransacted=true -Dtrans_size=1" \
- "-Daddress=$DURA_QUEUE -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10 -Dtransacted=true -Dtrans_size=1"
-
-# Test 9 Large TX
-run_testcase "Large_Txs_1000" "-Daddress=$DURA_QUEUE -Ddurable=true -Dtransacted=true -Dtrans_size=10" \
- "-Daddress=$DURA_QUEUE -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10 -Dtransacted=true -Dtrans_size=10"
-
-# Test 10 256 MSG
-run_testcase "Msg_256b" "-Daddress=$QUEUE" "-Daddress=$QUEUE -Dmsg_size=256 -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 11 512 MSG
-run_testcase "Msg_512b" "-Daddress=$QUEUE" "-Daddress=$QUEUE -Dmsg_size=512 -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 12 2048 MSG
-run_testcase "Msg_2048b" "-Daddress=$QUEUE" "-Daddress=$QUEUE -Dmsg_size=2048 -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 13 Random size MSG
-run_testcase "Random_Msg_Size" "-Daddress=$QUEUE" "-Daddress=$QUEUE -Drandom_msg_size=true -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 14 Random size MSG Durable
-run_testcase "Rand_Msg_Dura" "-Daddress=$DURA_QUEUE -Ddurable=true" "-Daddress=$DURA_QUEUE -Ddurable=true -Drandom_msg_size=true -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 15 64K MSG
-run_testcase "Msg_64K" "-Daddress=$QUEUE -Damqj.tcpNoDelay=true" "-Daddress=$QUEUE -Damqj.tcpNoDelay=true -Dmsg_size=64000 -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 16 Durable 64K MSG
-run_testcase "Msg_Durable_64K" "-Daddress=$DURA_QUEUE -Ddurable=true -Damqj.tcpNoDelay=true" \
- "-Daddress=$DURA_QUEUE -Damqj.tcpNoDelay=true -Dmsg_size=64000 -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 17 500K MSG
-run_testcase "Msg_500K" "-Daddress=$QUEUE -Damqj.tcpNoDelay=true" "-Daddress=$QUEUE -Damqj.tcpNoDelay=true -Dmsg_size=500000 -Dwarmup_count=1 -Dmsg_count=10"
-
-# Test 18 Durable 500K MSG
-run_testcase "Msg_Dura_500K" "-Daddress=$DURA_QUEUE -Damqj.tcpNoDelay=true -Ddurable=true" \
- "-Daddress=$DURA_QUEUE -Damqj.tcpNoDelay=true -Dmsg_size=500000 -Ddurable=true -Dwarmup_count=1 -Dmsg_count=10"

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/mercury-controller
----------------------------------------------------------------------
diff --git a/tools/bin/mercury-controller b/tools/bin/mercury-controller
deleted file mode 100755
index fab8614..0000000
--- a/tools/bin/mercury-controller
+++ /dev/null
@@ -1,132 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This starts the controller for coordinating perf tests/
-
-. check-qpid-java-env
-
-PROGRAM_NAME=controller
-CONSUMER_COUNT=1
-PRODUCER_COUNT=1
-DURATION=-1
-TEST_NAME="TEST_NAME"
-EXTRA_JVM_ARGS=""
-
-TEMP=$(getopt -n $PROGRAM_NAME -o c:p:d:n:a:h --long consumers:,producers:,jvm-args:help -- "$@")                                                            
-
-usage()
-{
-  printf "\n%s\n" "Usage: controller [option].."
-
-  printf "\n%31s\n%52s\n"  "-c, --consumer-count=count" "No of consumers participating in the test"
-
-  printf "\n%31s\n%52s\n"  "-p, --producer-count=count" "No of producers participating in the test"
-
-  printf "\n%24s\n%94s\n"  "-d, --duration=mins" "The duration of the test in mins. If not specified, it will just run one iteration."
-
-  printf "\n%27s\n%32s\n"  "-n, --name=<test-name>" "The name of the test."
-
-  printf "\n%19s\n%50s\n"  "-a, --jvm-args" "Extra jvm arguments you want to specify"
-}
-
-eval set -- "$TEMP"
-while true; do     
-        case $1 in 
-                -c|--consumer-count)
-                        CONSUMER_COUNT="$2"; shift; shift; continue
-                ;;                                    
-                -p|--producer-count)                            
-                        PRODUCER_COUNT="$2"; shift; shift; continue  
-                ;;                                 
-                -d|--duration)
-                        DURATION="$2"; shift; shift; continue
-                ;;
-                -n|--name)
-                        TEST_NAME="$2"; shift; shift; continue
-                ;;
-                -h|--help)                            
-                        usage                         
-                        exit 0                        
-                ;;                                    
-                -a|--jvm-args)               
-                        EXTRA_JVM_ARGS="$2"; shift; shift; continue 
-                ;;                                                                  
-                --)                                                                 
-                        # no more arguments to parse                                
-                        break                                                       
-                ;;                                                                  
-                *)       
-                        # no more arguments to parse                                                                                            
-                        break                                                      
-                ;;                                                                  
-        esac                                                                        
-done     
-
-CONTROLLER_ARGS="-server -Durl=amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672' -Dprecision=mili -Dprod_count=$PRODUCER_COUNT -Dcons_count=$CONSUMER_COUNT -Dprint_std_dev=true -Dduration=${DURATION}"
-
-
-waitfor() { until grep -a -l "$2" $1 >/dev/null 2>&1 ; do sleep 1 ; done ; }
-cleanup()
-{
-  pids=`ps aux | grep java | grep PerfTestController | awk '{print $2}'`
-  if [ "$pids" != "" ]; then
-    kill -3 $pids
-    kill -9 $pids >/dev/null 2>&1
-  fi
-}
-
-run_controller()
-{
-  TEST_ARGS="$LOG_CONFIG $JAVA_MEM $CONTROLLER_ARGS $EXTRA_JVM_ARGS"
-  echo "Running controller with : $TEST_ARGS" > test.out
-  $JAVA -cp $CLASSPATH $TEST_ARGS org.apache.qpid.tools.PerfTestController >> test.out &
-  waitfor test.out "Controller: Completed the test"
-  sleep 2 #give a grace period to shutdown
-  print_result $TEST_NAME
-}
-
-print_result()
-{
-  prod_rate=`cat test.out | grep "Avg Producer rate" | awk '{print $5}'`
-  sys_rate=`cat test.out | grep "System Throughput" | awk '{print $4}'`
-  cons_rate=`cat test.out | grep "Avg Consumer rate" | awk '{print $5}'` 
-  avg_latency=`cat test.out | grep "Avg System Latency" | awk '{print $5}'`
-  min_latency=`cat test.out | grep "Min System Latency" | awk '{print $5}'`
-  max_latency=`cat test.out | grep "Max System Latency" | awk '{print $5}'`
-  std_dev=`cat test.out | grep "Avg System Std Dev" | awk '{print $6}'`
-
-  printf "|%-15s|%15.2f|%13.2f|%13.2f|%11.2f|%11.2f|%11.2f|%7.2f|\n" $1 $sys_rate $prod_rate $cons_rate $avg_latency $min_latency $max_latency $std_dev
-  echo "--------------------------------------------------------------------------------------------------------"
-}
-
-trap cleanup EXIT
-
-rm -rf *.out
-
-if [ "$DURATION" = -1  ]; then
-   echo "Test report on " `date +%F`
-   echo "========================================================================================================"
-   echo "|Test           |System throuput|Producer rate|Consumer Rate|Avg Latency|Min Latency|Max Latency|Std Dev|"
-   echo "--------------------------------------------------------------------------------------------------------"
-else
-   echo "Test in progress....Tail stats-csv.log to see results being printed for each iteration."
-fi
-
-run_controller 

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/mercury-start-consumers
----------------------------------------------------------------------
diff --git a/tools/bin/mercury-start-consumers b/tools/bin/mercury-start-consumers
deleted file mode 100755
index c71fc0c..0000000
--- a/tools/bin/mercury-start-consumers
+++ /dev/null
@@ -1,119 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This starts the controller for coordinating perf tests/
-
-. check-qpid-java-env
-
-PROGRAM_NAME="start-consumers"
-PROCESS_COUNT=1
-CON_COUNT=1
-MSG_COUNT=10000
-ADDRESS="queue;{create:always}"
-UNIQUE_DEST="false"
-
-EXTRA_JVM_ARGS=" -Dmax_prefetch=500 "
-
-TEST_ID=`echo ${HOSTNAME} |  awk -F . '{print $1}'`
-
-TEMP=$(getopt -n $PROGRAM_NAME -o C:P:uc:p:a:s:t:w:h\
- --long connection-count:,process-count:,create-unique-queues-topics,\
-jvm-args:,queue:,topic:,address:,\
-msg-count:,help -- "$@")                                                            
-
-usage()
-{
-  printf "\n%s\n" "Usage: start-producers [option].."
-
-  printf "\n%32s\n%51s\n"  "-C, --connection-count=count" "No of consumers participating in the test"
-
-  printf "\n%29s\n%51s\n"  "-P, --process-count=count" "No of producers participating in the test"
-
-  printf "\n%37s\n%105s\n"  "-u, --create-unique-queues-topics" "This will create unique queue names and topics based on what you specify for --queue or --topic"
-
-  printf "\n%11s\n%55s\n"  "--queue" "The Queue you want to publish to. Ex my-queue"
-
-  printf "\n%11s\n%84s\n"  "--topic" "The Topic you want to publish to in amq.topic exchange. Ex amq.topic/topic"
-
-  printf "\n%13s\n%44s\n"  "--address" "The address you want to publish to"
-
-  printf "\n%25s\n%50s\n"  "-c, --msg-count=count" "message count per test (default 500,000)"
-
-  printf "\n%18s\n%49s\n"  "-a, --jvm-args" "Extra jvm arguments you want to specify"
-}
-
-eval set -- "$TEMP"
-while true; do     
-        case $1 in 
-                -C|--connection-count)
-                        CON_COUNT="$2"; shift; shift; continue
-                ;;                                    
-                -P|--process-count)                            
-                        PROCESS_COUNT="$2"; shift; shift; continue  
-                ;;
-		-u|--create-unique-queues-topics)                            
-                        UNIQUE_DEST="true"; shift; continue  
-                ;;                                     
-                --queue)                            
-                        ADDRESS="$2;{create: always}"; shift; shift; continue  
-                ;;                                    
-                --topic)                            
-                        ADDRESS="amq.topic/$2"; shift; shift; continue  
-                ;;                                    
-                --address)                            
-                        ADDRESS="$2"; shift; shift; continue  
-                ;;                                 
-                -h|--help)                            
-                        usage                         
-                        exit 0                        
-                ;;                                    
-                -a|--jvm-args)               
-                        EXTRA_JVM_ARGS="$2"; shift; shift; continue 
-                ;;   
-                -c|--msg-count)               
-                        MSG_COUNT="$2"; shift; shift; continue 
-                ;;                                                                  
-                --)                                                                 
-                        # no more arguments to parse                                
-                        break                                                       
-                ;;                                                                  
-                *)       
-                        # no more arguments to parse                                                                                            
-                        break                                                      
-                ;;                                                                  
-        esac                                                                        
-done     
-
-CONSUMER_ARGS="-server -Durl=amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672' -Dprecision=mili -Dcon_count=$CON_COUNT -Dprint_std_dev=true"
-
-start_consumers()
-{
-  for ((i=0; i<$PROCESS_COUNT; i++))
-  do
-     if [ "$UNIQUE_DEST" = "true" ]; then
-     	sh run-sub "$CONSUMER_ARGS $@" "${TEST_ID}_$i" > ${TEST_ID}_$i.sub.out 2>&1  &    
-     else
-        sh run-sub "$CONSUMER_ARGS $@" > ${TEST_ID}_$i.sub.out 2>&1  &    
-     fi 
-  done
-}
-
-start_consumers "-Daddress=$ADDRESS -Duse_unique_dest=$UNIQUE_DEST -Dmsg_count=$MSG_COUNT -Dcon_count=$CON_COUNT $EXTRA_JVM_ARGS"
-

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/mercury-start-producers
----------------------------------------------------------------------
diff --git a/tools/bin/mercury-start-producers b/tools/bin/mercury-start-producers
deleted file mode 100755
index 7ba0286..0000000
--- a/tools/bin/mercury-start-producers
+++ /dev/null
@@ -1,136 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This starts the controller for coordinating perf tests/
-
-. check-qpid-java-env
-
-PROGRAM_NAME="start-producers"
-PROCESS_COUNT=1
-CON_COUNT=1
-MSG_TYPE="bytes"
-WARMUP_MSG_COUNT=1000
-MSG_COUNT=10000
-MSG_SIZE=1024
-ADDRESS="queue;{create:always}"
-UNIQUE_DEST="false"
-
-EXTRA_JVM_ARGS=""
-TEST_ID=`echo ${HOSTNAME} |  awk -F . '{print $1}'`
-
-TEMP=$(getopt -n $PROGRAM_NAME -o C:P:uc:p:a:s:t:w:h\
- --long connection-count:,process-count:,create-unique-queues-topics,\
-jvm-args:,queue:,topic:,address:,\
-msg-count:,msg-size:msg-type:,warmup-msg-count,help -- "$@")                                                            
-
-usage()
-{
-  printf "\n%s\n" "Usage: start-producers [option].."
-
-  printf "\n%32s\n%51s\n"  "-C, --connection-count=count" "No of consumers participating in the test"
-
-  printf "\n%29s\n%51s\n"  "-P, --process-count=count" "No of producers participating in the test"
-
-  printf "\n%37s\n%105s\n"  "-u, --create-unique-queues-topics" "This will create unique queue names and topics based on what you specify for --queue or --topic"
-
-  printf "\n%11s\n%55s\n"  "--queue" "The Queue you want to publish to. Ex my-queue"
-
-  printf "\n%11s\n%84s\n"  "--topic" "The Topic you want to publish to in amq.topic exchange. Ex amq.topic/topic"
-
-  printf "\n%13s\n%44s\n"  "--address" "The address you want to publish to"
-
-  printf "\n%23s\n%37s\n"  "-s, --msg-size=size" "message size (default 1024)"
-
-  printf "\n%25s\n%50s\n"  "-c, --msg-count=count" "message count per test (default 500,000)"
-
-  printf "\n%18s\n%38s\n"  "-t, --msg-type" "{bytes|text} (default bytes)"
-
-  printf "\n%26s\n%49s\n"  "-w, --warmup-msg-count" "warm up message count (default 100,000)"
-
-  printf "\n%18s\n%49s\n"  "-a, --jvm-args" "Extra jvm arguments you want to specify"
-}
-
-eval set -- "$TEMP"
-while true; do     
-        case $1 in 
-                -C|--connection-count)
-                        CON_COUNT="$2"; shift; shift; continue
-                ;;                                    
-                -P|--process-count)                            
-                        PROCESS_COUNT="$2"; shift; shift; continue  
-                ;;
-		-u|--create-unique-queues-topics)                            
-                        UNIQUE_DEST="true"; shift; continue  
-                ;;                                     
-                --queue)                            
-                        ADDRESS="$2;{create: always}"; shift; shift; continue  
-                ;;                                    
-                --topic)                            
-                        ADDRESS="amq.topic/$2"; shift; shift; continue  
-                ;;                                    
-                --address)                            
-                        ADDRESS="$2"; shift; shift; continue  
-                ;;                                 
-                -h|--help)                            
-                        usage                         
-                        exit 0                        
-                ;;                                    
-                -a|--jvm-args)               
-                        EXTRA_JVM_ARGS="$2"; shift; shift; continue 
-                ;;   
-                -s|--msg-size)               
-                        MSG_SIZE="$2"; shift; shift; continue 
-                ;;                                                                  
-                -c|--msg-count)               
-                        MSG_COUNT="$2"; shift; shift; continue 
-                ;;                                                                  
-                -t|--msg_type)               
-                        MSG_TYPE="$2"; shift; shift; continue 
-                ;;                                                                  
-                -w|--warmup-msg-count)               
-                        WARMUP_MSG_COUNT="$2"; shift; shift; continue 
-                ;;                              
-                --)                                                                 
-                        # no more arguments to parse                                
-                        break                                                       
-                ;;                                                                  
-                *)       
-                        # no more arguments to parse                                                                                            
-                        break                                                      
-                ;;                                                                  
-        esac                                                                        
-done     
-
-PRODUCER_ARGS="-server -Durl=amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672' -Dext_controller=true -Dprecision=mili -Dcon_count=$CON_COUNT"
-
-start_producers()
-{
-  for ((i=0; i<$PROCESS_COUNT; i++))
-  do
-     if [ "$UNIQUE_DEST" = "true" ]; then
-     	sh run-pub "$PRODUCER_ARGS $@" "${TEST_ID}_$i" > ${TEST_ID}_$i.pub.out 2>&1 &    
-     else
-        sh run-pub "$PRODUCER_ARGS $@" > ${TEST_ID}_$i.pub.out 2>&1 &    
-     fi 
-  done
-}
-
-start_producers "-Daddress=$ADDRESS -Duse_unique_dest=$UNIQUE_DEST -Dmsg_count=$MSG_COUNT -Dmsg_size=$MSG_SIZE -Dwarmup_count=$WARMUP_MSG_COUNT -Dmsg_type=$MSG_TYPE -Dcon_count=$CON_COUNT $EXTRA_JVM_ARGS"
-

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/qpid-bench
----------------------------------------------------------------------
diff --git a/tools/bin/qpid-bench b/tools/bin/qpid-bench
deleted file mode 100755
index 4773320..0000000
--- a/tools/bin/qpid-bench
+++ /dev/null
@@ -1,23 +0,0 @@
-#!/usr/bin/env 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.
-#
-
-. check-qpid-java-env
-
-$JAVA -cp $CLASSPATH -server $JAVA_MEM $LOG_CONFIG org.apache.qpid.tools.QpidBench "$@"

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/qpid-jms-benchmark
----------------------------------------------------------------------
diff --git a/tools/bin/qpid-jms-benchmark b/tools/bin/qpid-jms-benchmark
deleted file mode 100755
index 3d712a2..0000000
--- a/tools/bin/qpid-jms-benchmark
+++ /dev/null
@@ -1,316 +0,0 @@
-#!/usr/bin/env python
-#
-# 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.
-#
-
-import optparse, time, qpid.messaging, re
-from threading import Thread
-from subprocess import Popen, PIPE, STDOUT
-
-op = optparse.OptionParser(usage="usage: %prog [options]",
-                           description="simple performance benchmarks")
-op.add_option("-b", "--broker", default=[], action="append", type="str",
-              help="url of broker(s) to connect to, round robin on multiple brokers")
-op.add_option("-c", "--client-host", default=[], action="append", type="str",
-              help="host(s) to run clients on via ssh, round robin on mulple hosts")
-op.add_option("-q", "--queues", default=1, type="int", metavar="N",
-              help="create N queues (default %default)")
-op.add_option("-s", "--senders", default=1, type="int", metavar="N",
-              help="start N senders per queue (default %default)")
-op.add_option("-r", "--receivers", default=1, type="int", metavar="N",
-              help="start N receivers per queue (default %default)")
-op.add_option("-m", "--messages", default=100000, type="int", metavar="N",
-              help="send N messages per sender (default %default)")
-op.add_option("--queue-name", default="benchmark", metavar="NAME",
-              help="base name for queues (default %default)")
-op.add_option("--send-rate", default=0, metavar="N",
-              help="send rate limited to N messages/second, 0 means no limit (default %default)")
-op.add_option("--receive-rate", default=0, metavar="N",
-              help="receive rate limited to N messages/second, 0 means no limit (default %default)")
-op.add_option("--content-size", default=1024, type="int", metavar="BYTES",
-              help="message size in bytes (default %default)")
-op.add_option("--ack-frequency", default=100, metavar="N", type="int",
-              help="receiver ack's every N messages, 0 means unconfirmed (default %default)")
-op.add_option("--no-report-header", dest="report_header", default=True,
-              action="store_false", help="don't print header on report")
-op.add_option("--summarize", default=False, action="store_true",
-              help="print summary statistics for multiple senders/receivers: total throughput, average latency")
-op.add_option("--repeat", default=1, metavar="N", help="repeat N times", type="int")
-op.add_option("--send-option", default=[], action="append", type="str",
-              help="Additional option for sending addresses")
-op.add_option("--receive-option", default=[], action="append", type="str",
-              help="Additional option for receiving addresses")
-op.add_option("--create-option", default=[], action="append", type="str",
-              help="Additional option for creating addresses")
-op.add_option("--send-arg", default=[], action="append", type="str",
-              help="Additional argument for qpid-send")
-op.add_option("--receive-arg", default=[], action="append", type="str",
-              help="Additional argument for qpid-receive")
-op.add_option("--no-timestamp", dest="timestamp", default=True,
-              action="store_false", help="don't add a timestamp, no latency results")
-op.add_option("--sequence", dest="sequence", default=False,
-              action="store_true", help="add a sequence number to each message")
-op.add_option("--connection-options", type="str",
-              help="Connection options for senders & receivers")
-op.add_option("--durable", default=False, action="store_true",
-              help="Use durable queues and messages")
-op.add_option("--save-received", default=False, action="store_true",
-              help="Save received message content to files <queuename>-receiver-<n>.msg")
-op.add_option("--verbose", default=False, action="store_true",
-              help="Show commands executed")
-op.add_option("--no-delete", default=False, action="store_true",
-              help="Don't delete the test queues.")
-op.add_option("--fill-drain", default=False, action="store_true",
-              help="First fill the queues, then drain them")
-
-single_quote_re = re.compile("'")
-def posix_quote(string):
-    """ Quote a string for use as an argument in a posix shell"""
-    return "'" + single_quote_re.sub("\\'", string) + "'";
-
-def ssh_command(host, command):
-    """ Convert command into an ssh command on host with quoting"""
-    return ["ssh", host] + [posix_quote(arg) for arg in command]
-
-class Clients:
-    def __init__(self): self.clients=[]
-
-    def add(self, client):
-        self.clients.append(client)
-        return client
-
-    def kill(self):
-        for c in self.clients:
-            try: c.kill()
-            except: pass
-
-class  PopenCommand(Popen):
-    """Like Popen but you can query for the command"""
-    def __init__(self, command, *args, **kwargs):
-        self.command = command
-        Popen.__init__(self, command, *args, **kwargs)
-
-clients = Clients()
-
-def start_receive(queue, index, opts, ready_queue, broker, host):
-    address_opts=opts.receive_option
-    if opts.durable: address_opts += ["node:{durable:true}"]
-    address="%s;{%s}"%(queue,",".join(address_opts))
-    msg_total=opts.senders*opts.messages
-    messages = msg_total/opts.receivers;
-    if (index < msg_total%opts.receivers): messages += 1
-    if (messages == 0): return None
-    command = ["qpid-jms-receive",
-               #"-b", broker,
-               "--ready-address", "benchmark-ready;{create:always}",
-               "-a", address,
-               "-m", str(messages),
-               "--forever",
-               "--print-content=no",
-              # "--receive-rate", str(opts.receive_rate),
-               "--report-total",
-               "--ack-frequency", str(opts.ack_frequency),
-              # "--ready-address", "%s;{create:always}"%ready_queue,
-               "--report-header=no -v"
-               ]
-    if opts.save_received:
-        command += ["--save-content=%s-receiver-%s.msg"%(queue,index)]
-    command += opts.receive_arg
-    if opts.connection_options:
-        command += ["--connection-options",opts.connection_options]
-    if host: command = ssh_command(host, command)
-    if opts.verbose: print "Receiver: ", command
-    return clients.add(PopenCommand(command, stdout=PIPE, stderr=PIPE))
-
-def start_send(queue, opts, broker, host):
-    address="%s;{%s}"%(queue,",".join(opts.send_option + ["create:always"]))
-    command = ["qpid-jms-send",
-               #"-b", broker,
-               "-a", address,
-               "--messages", str(opts.messages),
-               "--content-size", str(opts.content_size),
-               "--send-rate", str(opts.send_rate),
-               "--report-total",
-               "--report-header=no",
-               "--timestamp=%s"%(opts.timestamp and "yes" or "no"),
-               "--sequence=%s"%(opts.sequence and "yes" or "no"),
-               "--durable", str(opts.durable)
-               ]
-    command += opts.send_arg
-    if opts.connection_options:
-        command += ["--connection-options",opts.connection_options]
-    if host: command = ssh_command(host, command)
-    if opts.verbose: print "Sender: ", command
-    return clients.add(PopenCommand(command, stdout=PIPE, stderr=PIPE))
-
-def error_msg(out, err):
-    return ("\n[stdout]\n%s\n[stderr]\n%s[end]"%(out, err))
-
-def first_line(p):
-    out,err=p.communicate()
-    if p.returncode != 0:
-        raise Exception("Process exit %d: %s"%(p.returncode, error_msg(out,err)))
-
-    print str(out)
-    print str(err)
-    return out.split("\n")[0]
-
-def recreate_queues(queues, brokers, no_delete, opts):
-    c = qpid.messaging.Connection(brokers[0])
-    c.open()
-    s = c.session()
-    for q in queues:
-        if not no_delete:
-            try: s.sender("%s;{delete:always}"%(q)).close()
-            except qpid.messaging.exceptions.NotFound: pass
-        address = "%s;{%s}"%(q, ",".join(opts.create_option + ["create:always"]))
-        if opts.verbose: print "Creating", address
-        s.sender(address)
-    c.close()
-
-def print_header(timestamp):
-    if timestamp: latency_header="\tl-min\tl-max\tl-avg\ttotal-tp"
-    else: latency_header=""
-    print "send-tp\trecv-tp%s"%latency_header
-
-def parse(parser, lines):               # Parse sender/receiver output
-    return [map(lambda p: p[0](p[1]), zip(parser,line.split())) for line in lines]
-
-def parse_senders(senders):
-    return parse([int],[first_line(p) for p in senders])
-
-def parse_receivers(receivers):
-    return parse([int,float,float,float],[first_line(p) for p in receivers if p])
-
-def print_data(send_stats, recv_stats, total_tp):
-    for send,recv in map(None, send_stats, recv_stats):
-        line=""
-        if send: line += "%d"%send[0]
-        if recv:
-            line += "\t%d"%recv[0]
-            if len(recv) == 4: line += "\t%.2f\t%.2f\t%.2f"%tuple(recv[1:])
-        if total_tp is not None:
-            line += "\t%d"%total_tp
-            total_tp = None
-        print line
-
-def print_summary(send_stats, recv_stats, total_tp):
-    def avg(s): sum(s) / len(s)
-    send_tp = sum([l[0] for l in send_stats])
-    recv_tp = sum([l[0] for l in recv_stats])
-    summary = "%d\t%d"%(send_tp, recv_tp)
-    if recv_stats and len(recv_stats[0]) == 4:
-        l_min = sum(l[1] for l in recv_stats)/len(recv_stats)
-        l_max = sum(l[2] for l in recv_stats)/len(recv_stats)
-        l_avg = sum(l[3] for l in recv_stats)/len(recv_stats)
-        summary += "\t%.2f\t%.2f\t%.2f"%(l_min, l_max, l_avg)
-    summary += "\t%d"%total_tp
-    print summary
-
-
-class ReadyReceiver:
-    """A receiver for ready messages"""
-    def __init__(self, queue, broker):
-        self.connection = qpid.messaging.Connection(broker)
-        self.connection.open()
-        self.receiver = self.connection.session().receiver(
-            "%s;{create:receiver,delete:receiver,node:{durable:false}}"%(queue))
-        self.receiver.session.sync()
-        self.timeout=10
-
-    def wait(self, receivers):
-        try:
-            for i in receivers: self.receiver.fetch(self.timeout)
-            self.connection.close()
-        except qpid.messaging.Empty:
-            for r in receivers:
-                if (r.poll() is not None):
-                    out,err=r.communicate()
-                    raise Exception("Receiver error: %s\n%s" %
-                                    (" ".join(r.command), error_msg(out,err)))
-            raise Exception("Timed out waiting for receivers to be ready")
-
-def flatten(l):
-    return sum(map(lambda s: re.split(re.compile("\s*,\s*|\s+"), s), l), [])
-
-class RoundRobin:
-    def __init__(self,items):
-        self.items = items
-        self.index = 0
-
-    def next(self):
-        if not self.items: return None
-        ret = self.items[self.index]
-        self.index = (self.index+1)%len(self.items)
-        return ret
-
-def main():
-    opts, args = op.parse_args()
-    opts.client_host = flatten(opts.client_host)
-    if not opts.broker:
-        if opts.client_host:
-            raise Exception("--broker must be specified if --client_host is.")
-        opts.broker = ["127.0.0.1"] # Deafult to local broker
-    opts.broker = flatten(opts.broker)
-    brokers = RoundRobin(opts.broker)
-    client_hosts = RoundRobin(opts.client_host)
-    send_out = ""
-    receive_out = ""
-    ready_queue="%s-ready"%(opts.queue_name)
-    queues = ["%s-%s"%(opts.queue_name, i) for i in xrange(opts.queues)]
-    try:
-        for i in xrange(opts.repeat):
-            recreate_queues(queues, opts.broker, opts.no_delete, opts)
-            ready_receiver = ReadyReceiver(ready_queue, opts.broker[0])
-
-            def start_receivers():
-                return [ start_receive(q, j, opts, ready_queue, brokers.next(), client_hosts.next())
-                         for q in queues for j in xrange(opts.receivers) ]
-
-
-            def start_senders():
-                return  [ start_send(q, opts,brokers.next(), client_hosts.next())
-                          for q in queues for j in xrange(opts.senders) ]
-
-            if opts.report_header and i == 0: print_header(opts.timestamp)
-
-            if opts.fill_drain:
-                # First fill the queues, then drain them
-                start = time.time()
-                senders = start_senders()
-                for p in senders: p.wait()
-                receivers = start_receivers()
-                for p in receivers: p.wait()
-            else:
-                # Run senders and receivers in parallel
-                receivers = start_receivers()
-                ready_receiver.wait(filter(None, receivers)) # Wait for receivers ready
-                start = time.time()
-                senders = start_senders()
-                for p in senders + receivers: p.wait()
-
-            total_sent = opts.queues * opts.senders * opts.messages
-            total_tp = total_sent / (time.time()-start)
-            #send_stats=parse_senders(senders)
-            recv_stats=parse_receivers(receivers)
-            #if opts.summarize: print_summary(send_stats, recv_stats, total_tp)
-            #else: print_data(send_stats, recv_stats, total_tp)
-    finally: clients.kill()             # No strays
-
-if __name__ == "__main__": main()
-

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/qpid-jms-receive
----------------------------------------------------------------------
diff --git a/tools/bin/qpid-jms-receive b/tools/bin/qpid-jms-receive
deleted file mode 100755
index 57abe87..0000000
--- a/tools/bin/qpid-jms-receive
+++ /dev/null
@@ -1,193 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This starts the controller for coordinating perf tests/
-
-. check-qpid-java-env
-
-PROGRAM_NAME="qpid-jms-receive"
-URL="amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672'"
-ADDRESS="queue;{create:always}"
-TIMEOUT="0"
-FOREVER="false"
-MESSAGES="1"
-IGNORE_DUPLICATES="false"
-CHECK_REDELIVERED="false"
-CAPACITY="1000"
-ACK_FREQUENCY="100"
-TX="0"
-ROLLBACL_FREQUENCY="0"
-PRINT_CONTENT="false"
-PRINT_HEADERS="false"
-REPORT_TOTAL="false"
-REPORT_EVERY="0"
-REPORT_HEADER="true"
-READY_ADDRES="''"
-EXTRA_JVM_ARGS=""
-VERBOSE="0"
-
-TEST_ID=`echo ${HOSTNAME} |  awk -F . '{print $1}'`
-
-TEMP=$(getopt -n $PROGRAM_NAME -o b:a:f:m:vh\
- --long broker:,address:,timeout:,forever\
-,messages:,ignore-duplicates,check-redelivered\
-,capacity:,ack-frequency:,tx:,rollback-frequency:\
-,print-content:,print-headers:,report-total\
-,report-every:,report-header:,ready-address:\
-,jvm-args:,verbose,help -- "$@")                                                            
-
-# padding the option string with 4 spaces
-# padding the desc string with 30 spaces
-usage()
-{
-  printf "\n%s\n" "Usage: $PROGRAM_NAME [option].."
-
-  printf "\n%20s\n%57s\n"  "-b, --broker URL" "url of broker to connect to"
-
-  printf "\n%24s\n%53s\n"  "-a,--address ADDRESS" "address to receive from"
-
-  printf "\n%25s\n%71s\n"  "--timeout TIMEOUT (0)" "timeout in seconds to wait before exiting"
-
-  printf "\n%17s\n%61s\n"  "-f, --forever" "ignore timeout and wait forever"
-
-  printf "\n%24s\n%89s\n"  "-m, --messages N (0)" "Number of messages to receive; 0 means receive indefinitely"
-
-  printf "\n%23s\n%84s\n"  "--ignore-duplicates" "Detect and ignore duplicates (by checking 'sn' header)"
-
-  printf "\n%23s\n%82s\n%92s\n"  "--check-redelivered" "Fails with exception if a duplicate is not marked as" " redelivered (only relevant when ignore-duplicates is selected)"
-
-  printf "\n%23s\n%71s\n"  "--capacity N (1000)" "Pre-fetch window (0 implies no pre-fetch)"
-
-  printf "\n%27s\n%94s\n"  "--ack-frequency N (100)" "Ack frequency (0 implies none of the messages will get accepted)"
-
-  printf "\n%14s\n%94s\n"  "--tx N (0)" "batch size for transactions (0 implies transaction are not used)"
-
-  printf "\n%30s\n%94s\n"  "--rollback-frequency N (0)" "rollback frequency (0 implies no transaction will be rolledback)"
-
-  printf "\n%30s\n%55s\n"  "--print-content yes|no (0)" "print out message content"
-
-  printf "\n%30s\n%55s\n"  "--print-headers yes|no (0)" "print out message headers"
-
-  printf "\n%18s\n%76s\n"  "--report-total" "Report total throughput and latency statistics"
-
-  printf "\n%24s\n%87s\n"  "--report-every N (0)" "Report throughput and latency statistics every N messages"
-
-  printf "\n%30s\n%47s\n"  "--report-header yes|no (1)" "Headers on report"
-
-  printf "\n%27s\n%82s\n"  "--ready-address ADDRESS" "send a message to this address when ready to receive"
-
-  printf "\n%14s\n%69s\n"  "--jvm-args" "Extra jvm arguments you want to specify"
-
-  printf "\n%17s\n%69s\n\n"  "-v, --verbose" "Print debug information for this script"
-}
-
-eval set -- "$TEMP"
-while true; do     
-        case $1 in
-                -b|--broker)
-                        URL="$2"; shift; shift; continue
-                ;;
-                -a|--address)
-                        ADDRESS="$2"; shift; shift; continue
-                ;;
-                --timeout)
-                        TIMEOUT="$2"; shift; shift; continue
-                ;;
-                -f|--forever)
-                        FOREVER="$2"; shift; shift; continue
-                ;;
-                -m|--messages)
-                        MESSAGES="$2"; shift; shift; continue
-                ;;
-                --ignore-duplicates)
-                        IGNORE_DUPLICATES="true"; shift; continue
-                ;;
-                --check-redelivered)
-                        CHECK_REDELIVERED="true"; shift; continue
-                ;;
-                --capacity)
-                        CAPACITY="$2"; shift; shift; continue
-                ;;
-                --ack-frequency)
-                        ACK_FREQUENCY="$2"; shift; shift; continue
-                ;;
-                --tx)
-                        TX="$2"; shift; shift; continue
-                ;;
-                --rollback-frequency)
-                        ROLLBACK_FREQUENCY="$2"; shift; shift; continue
-                ;;
-                --print-content)
-                        if [ "$2" == "yes" ]; then PRINT_CONTENT="true"; else PRINT_CONTENT="false"; fi; shift; shift; continue
-                ;;
-                --print-headers)
-                        if [ "$2" == "yes" ]; then PRINT_HEADERS="true"; else PRINT_HEADERS="false"; fi; shift; shift; continue
-                ;;
-                --report-total)
-                        REPORT_TOTAL="true"; shift; continue
-                ;;
-                --report-every)
-                        REPORT_EVERY="$2"; shift; shift; continue
-                ;;
-                --report-header)
-                        if [ "$2" == "yes" ]; then REPORT_HEADER="true"; else REPORT_HEADER="false"; fi; shift; shift; continue
-                ;;
-                --ready-address)
-                        READY_ADDRESS="$2"; shift; shift; continue
-                ;;
-                -a|--jvm-args)
-                        EXTRA_JVM_ARGS="$2"; shift; shift; continue
-                ;;
-                -h|--help)
-                        usage
-                        exit 0
-                ;;   
-                -v|--verbose)
-                        VERBOSE="1"; shift; continue
-                ;;                                                              
-                --)                                                                 
-                        # no more arguments to parse                                
-                        break                                                       
-                ;;                                                                  
-                *)       
-                        # no more arguments to parse                                                                                            
-                        break                                                      
-                ;;                                                                  
-        esac                                                                        
-done     
-
-RECEIVER_ARGS="-server -Durl=$URL \
--Daddress=$ADDRESS \
--Dtimeout=$TIMEOUT \
--Dmsg-count=$MESSAGES \
--Dack-frequency=$ACK_FREQUENCY \
--Dtx=$TX \
--Drollback-frequnecy=$ROLLBACL_FREQUENCY \
--Dprint-content=$PRINT_CONTENT \
--Dprint-headers=$PRINT_HEADERS \
--Dreport-total=$REPORT_TOTAL \
--Dreport-every=$REPORT_EVERY \
--Dreport-header=$REPORT_HEADER \
--Dmax_prefetch=$CAPACITY "
-
-if [ "x$READY_ADDRESS" != "x" ]; then RECEIVER_ARGS="$RECEIVER_ARGS -Dready-address=$READY_ADDRESS"; fi
-if [ "$VERBOSE" == "1" ]; then echo $RECEIVER_ARGS; fi
-echo $RECEIVER_ARGS
-$JAVA -cp $CLASSPATH $LOG_CONFIG $JAVA_MEM $RECEIVER_ARGS org.apache.qpid.tools.QpidReceive

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/qpid-jms-send
----------------------------------------------------------------------
diff --git a/tools/bin/qpid-jms-send b/tools/bin/qpid-jms-send
deleted file mode 100755
index d769592..0000000
--- a/tools/bin/qpid-jms-send
+++ /dev/null
@@ -1,261 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-# This starts the controller for coordinating perf tests/
-
-. check-qpid-java-env
-
-PROGRAM_NAME="qpid-jms-send"
-URL="amqp://guest:guest@clientid/testpath?brokerlist='tcp://localhost:5672'"
-ADDRESS="queue;{create:always}"
-MESSAGES="1"
-ID=""
-REPLY_TO=""
-SEND_EOS="1"
-DURABLE="false"
-TTL="0"
-PRIORITY="0"
-PROPERTY=""
-CORRELATION_ID=""
-USER_ID=""
-CONTENT_STRING=""
-CONTENT_SIZE="1024"
-CONTENT_MAP=""
-CAPACITY="1000"
-ACK_FREQUENCY="100"
-TX="0"
-ROLLBACL_FREQUENCY="0"
-PRINT_CONTENT="true"
-PRINT_HEADERS="false"
-REPORT_TOTAL="false"
-REPORT_EVERY="0"
-REPORT_HEADER="true"
-SEND_RATE="-1"
-SEQUNCE="1"
-DISABLE_TIMESTAMP="false"
-EXTRA_JVM_ARGS=""
-VERBOSE="0"
-
-TEST_ID=`echo ${HOSTNAME} |  awk -F . '{print $1}'`
-
-TEMP=$(getopt -n $PROGRAM_NAME -o b:a:m:i:P:M:vh\
- --long broker:,address:,messages:,id:,reply-to:\
-,send-eos:,durable:,ttl:,property:,correlational-id:\
-,user-id:,content-string:,content-size:,content-map:\
-,capacity:,ack-frequency:,tx:,rollback-frequency:\
-,print-content:,print-headers:,report-total\
-,report-every:,report-header:,send-rate:,sequence:,timestamp:\
-,jvm-args:,verbose,help -- "$@")                                                            
-
-# padding the option string with 4 spaces
-# padding the desc string with 30 spaces
-usage()
-{
-  printf "\n%s\n" "Usage: $PROGRAM_NAME [option].."
-
-  printf "\n%20s\n%57s\n"  "-b, --broker URL" "url of broker to connect to"
-
-  printf "\n%24s\n%53s\n"  "-a,--address ADDRESS" "address to receive from"
-
-  printf "\n%24s\n%89s\n"  "-m, --messages N (0)" "Number of messages to receive; 0 means receive indefinitely"
-
-  printf "\n%15s\n%75s\n"  "-i, --id ID" "use the supplied id instead of generating one"
-
-  printf "\n%23s\n%54s\n"  "--reply-to REPLY-TO" "specify reply-to address"
-
-  printf "\n%20s\n%70s\n"  "--send-eos N (0)" "send N EOS messages to mark end of input"
-
-  printf "\n%24s\n%54s\n"  "--durable yes|no (0)" "mark messages as durable"
-
-  printf "\n%19s\n%72s\n"  "--ttl msecs (0)" "time-to-live for messages, in milliseconds"
-
-  printf "\n%27s\n%72s\n"  "--priority PRIORITY (0)" "time-to-live for messages, in milliseconds"
-
-  printf "\n%29s\n%54s\n"  "-P, --property NAME=VALUE" "specify message property"
-
-  printf "\n%23s\n%57s\n"  "--correlation-id ID" "correlation-id for message"
-
-  printf "\n%20s\n%48s\n"  "--user-id USERID" "userid for message"
-
-  printf "\n%28s\n%60s\n"  "--content-string CONTENT" "use CONTENT as message content"
-
-  printf "\n%24s\n%62s\n"  "--content-size N (0)" "create an N-byte message content"
-
-  printf "\n%32s\n%59s\n"  "-M, --content-map NAME=VALUE" "specify entry for map content"
-
-  printf "\n%23s\n%71s\n"  "--capacity N (1000)" "Pre-fetch window (0 implies no pre-fetch)"
-
-  printf "\n%27s\n%94s\n"  "--ack-frequency N (100)" "Ack frequency (0 implies none of the messages will get accepted)"
-
-  printf "\n%14s\n%94s\n"  "--tx N (0)" "batch size for transactions (0 implies transaction are not used)"
-
-  printf "\n%30s\n%94s\n"  "--rollback-frequency N (0)" "rollback frequency (0 implies no transaction will be rolledback)"
-
-  printf "\n%30s\n%55s\n"  "--print-content yes|no (1)" "print out message content"
-
-  printf "\n%30s\n%55s\n"  "--print-headers yes|no (0)" "print out message headers"
-
-  printf "\n%18s\n%76s\n"  "--report-total" "Report total throughput and latency statistics"
-
-  printf "\n%24s\n%87s\n"  "--report-every N (0)" "Report throughput and latency statistics every N messages"
-
-  printf "\n%30s\n%47s\n"  "--report-header yes|no (1)" "Headers on report"
-
-  printf "\n%21s\n%64s\n%62s\n"  "--send-rate N (0)" "Send at rate of N messages/second." "0 means send as fast as possible"
-
-  printf "\n%25s\n%69s\n%77s\n"  "--sequence yes|no (1)" "Add a sequence number messages property" "(required for duplicate/lost message detection)"
-
-  printf "\n%26s\n%64s\n%77s\n"  "--timestamp yes|no (1)" "Add a time stamp messages property" "(required for duplicate/lost message detection)"
-
-  printf "\n%14s\n%69s\n"  "--jvm-args" "Extra jvm arguments you want to specify"
-
-  printf "\n%17s\n%69s\n\n"  "-v, --verbose" "Print debug information for this script"
-}
-
-eval set -- "$TEMP"
-while true; do     
-        case $1 in
-                -b|--broker)
-                        URL="$2"; shift; shift; continue
-                ;;
-                -a|--address)
-                        ADDRESS="$2"; shift; shift; continue
-                ;;
-                -m|--messages)
-                        MESSAGES="$2"; shift; shift; continue
-                ;;
-                -i|--id)
-                        ID="$2"; shift; shift; continue
-                ;;
-                --reply-to)
-                        REPLY_TO="$2"; shift; shift; continue
-                ;;
-                --send-eos)
-                        SEND_EOS="$2"; shift; shift; continue
-                ;;
-                --durable)
-                        if [ "$2" == "1" ]; then DURABLE="true"; else DURABLE="false"; fi; shift; shift; continue
-                ;;
-                --ttl)
-                        TTL="$2"; shift; shift; continue
-                ;;
-                --priority)
-                        PRIORITY="$2"; shift; shift; continue
-                ;;
-                -P|--property)
-                        PROPERTY="$2,$PROPERTY"; shift; shift; continue
-                ;;
-                --correlation-id)
-                        CORRELATION_ID="$2"; shift; shift; continue
-                ;;
-                --user-id)
-                        USER_ID="$2"; shift; shift; continue
-                ;;
-                --content-string)
-                        CONTENT_STRING="$2"; shift; shift; continue
-                ;;
-                --content-size)
-                        CONTENT_SIZE="$2"; shift; shift; continue
-                ;;
-                -M|--content-map)
-                        CONTENT_MAP="$2,$CONTENT_MAP"; shift; shift; continue
-                ;;
-                --capacity)
-                        CAPACITY="$2"; shift; shift; continue
-                ;;
-                --ack-frequency)
-                        ACK_FREQUENCY="$2"; shift; shift; continue
-                ;;
-                --tx)
-                        TX="$2"; shift; shift; continue
-                ;;
-                --rollback-frequency)
-                        ROLLBACK_FREQUENCY="$2"; shift; shift; continue
-                ;;
-                --print-content)
-                        if [ "$2" == "yes" ]; then PRINT_CONTENT="true"; else PRINT_CONTENT="false"; fi; shift; shift; continue
-                ;;
-                --print-headers)
-                        if [ "$2" == "yes" ]; then PRINT_HEADERS="true"; else PRINT_HEADERS="false"; fi; shift; shift; continue
-                ;;
-                --report-total)
-                        REPORT_TOTAL="true"; shift; continue
-                ;;
-                --report-every)
-                        REPORT_EVERY="$2"; shift; shift; continue
-                ;;
-                --report-header)
-                        if [ "$2" == "yes" ]; then REPORT_HEADER="true"; else REPORT_HEADER="false"; fi; shift; shift; continue
-                ;;
-                --send-rate)
-                        SEND_RATE="$2"; shift; shift; continue
-                ;;
-                --sequence)
-                        if [ "$2" == "yes" ]; then SEQUENCE="true"; else SEQUENCE="false"; fi; shift; shift; continue
-                ;;
-                --timestamp)
-                        if [ "$2" == "yes" ]; then DISABLE_TIMESTAMP="false"; else DISABLE_TIMESTAMP="true"; fi; shift; shift; continue
-                ;;
-                -a|--jvm-args)
-                        EXTRA_JVM_ARGS="$2"; shift; shift; continue
-                ;;
-                -h|--help)
-                        usage
-                        exit 0
-                ;;            
-                -v|--verbose)
-                        VERBOSE="1"; shift; continue
-                ;;                                                      
-                --)                                                                 
-                        # no more arguments to parse                                
-                        break                                                       
-                ;;                                                                  
-                *)       
-                        # no more arguments to parse                                                                                            
-                        break                                                      
-                ;;                                                                  
-        esac                                                                        
-done     
-
-SENDER_ARGS="-server -Durl=$URL \
--Daddress=$ADDRESS \
--Dmsg-count=$MESSAGES \
--Dsend-eos=$SEND_EOS \
--Ddurable=$DURABLE \
--Dmsg_size=$CONTENT_SIZE \
--Dsend-rate=$SEND_RATE \
--Ddisable-timestamp=$DISABLE_TIMESTAMP \
--Dttl=$TTL \
--Dpriority=$PRIORITY \
--Dtx=$TX \
--Drollback-frequnecy=$ROLLBACK_FREQUENCY \
--Dprint-content=$PRINT_CONTENT \
--Dprint-headers=$PRINT_HEADERS \
--Dreport-total=$REPORT_TOTAL \
--Dreport-every=$REPORT_EVERY \
--Dreport-header=$REPORT_HEADER \
--Dmax_prefetch=$CAPACITY "
-
-if [ "x$ID" != "x" ]; then SENDER_ARGS="$SENDER_ARGS -Did=$ID"; fi
-if [ "x$USER_ID" != "x" ]; then SENDER_ARGS="$SENDER_ARGS -Duser_id=$USER_ID"; fi
-if [ "x$CORRELATION_ID" != "x" ]; then SENDER_ARGS="$SENDER_ARGS -Dcorrelation_id=$CORRELATION_ID"; fi
-
-if [ "$VERBOSE" == "1" ]; then echo $SENDER_ARGS; fi
-$JAVA -cp $CLASSPATH $LOG_CONFIG $JAVA_MEM $SENDER_ARGS org.apache.qpid.tools.QpidSend

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/qpid-python-testkit
----------------------------------------------------------------------
diff --git a/tools/bin/qpid-python-testkit b/tools/bin/qpid-python-testkit
deleted file mode 100755
index 20f72ac..0000000
--- a/tools/bin/qpid-python-testkit
+++ /dev/null
@@ -1,33 +0,0 @@
-#!/usr/bin/env 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.
-#
-
-# This is wrapper script to run the tests defined in testkit.py 
-# via the python test runner. The defaults are set for a running
-# from an svn checkout
-
-. check-qpid-java-env
-
-export PYTHONPATH=./:$PYTHONPATH
-echo $PYTHONPATH
-if [ "$OUTDIR" = "" ] ; then
-   OUTDIR=$PWD
-fi
-testdir=$OUTDIR/testkit-out-`date +%F-%H-%M-%S`
-qpid-python-test -m testkit -DOUTDIR=$testdir"$@"

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/run-pub
----------------------------------------------------------------------
diff --git a/tools/bin/run-pub b/tools/bin/run-pub
deleted file mode 100755
index 9efe58c..0000000
--- a/tools/bin/run-pub
+++ /dev/null
@@ -1,28 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-. check-qpid-java-env
-
-JVM_ARGS="$1"
-PROGRAM_ARGS="$2"
-
-echo "JVM ARGS : $JAVA_MEM $JVM_ARGS"
-echo "PROGRAM ARGS : $PROGRAM_ARGS"
-$JAVA -cp $CLASSPATH $LOG_CONFIG $JAVA_MEM $JVM_ARGS org.apache.qpid.tools.PerfProducer $PROGRAM_ARGS

http://git-wip-us.apache.org/repos/asf/qpid-broker-j/blob/a48234d2/tools/bin/run-sub
----------------------------------------------------------------------
diff --git a/tools/bin/run-sub b/tools/bin/run-sub
deleted file mode 100755
index 8449563..0000000
--- a/tools/bin/run-sub
+++ /dev/null
@@ -1,32 +0,0 @@
-#!/bin/sh
-#
-# 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.
-#
-
-. check-qpid-java-env
-
-echo "All args $@"
-
-JVM_ARGS="$1"
-PROGRAM_ARGS="$2"
-
-echo "JVM ARGS : $JAVA_MEM $JVM_ARGS"
-echo "PROGRAM ARGS : $PROGRAM_ARGS"
-
-$JAVA -cp $CLASSPATH $LOG_CONFIG $JAVA_MEM $JVM_ARGS org.apache.qpid.tools.PerfConsumer $PROGRAM_ARGS
-


---------------------------------------------------------------------
To unsubscribe, e-mail: commits-unsubscribe@qpid.apache.org
For additional commands, e-mail: commits-help@qpid.apache.org