You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by ch...@apache.org on 2006/07/06 00:30:26 UTC

svn commit: r419366 [4/7] - in /incubator/activemq/trunk: activeio/activeio-core/src/main/java/org/apache/activeio/journal/active/ activemq-core/src/main/java/org/apache/activemq/broker/ activemq-core/src/main/java/org/apache/activemq/command/ activemq...

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsConsumerSystem.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsConsumerSystem.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsConsumerSystem.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsConsumerSystem.java Wed Jul  5 15:30:19 2006
@@ -1,79 +1,79 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool;
-
-import org.apache.activemq.tool.properties.JmsClientSystemProperties;
-import org.apache.activemq.tool.properties.JmsConsumerSystemProperties;
-import org.apache.activemq.tool.properties.JmsConsumerProperties;
-import org.apache.activemq.tool.properties.JmsClientProperties;
-import org.apache.activemq.tool.sampler.ThroughputSamplerTask;
-
-import javax.jms.JMSException;
-import java.util.Properties;
-
-public class JmsConsumerSystem extends AbstractJmsClientSystem {
-    protected JmsConsumerSystemProperties sysTest = new JmsConsumerSystemProperties();
-    protected JmsConsumerProperties consumer = new JmsConsumerProperties();
-
-    public JmsClientSystemProperties getSysTest() {
-        return sysTest;
-    }
-
-    public void setSysTest(JmsClientSystemProperties sysTestProps) {
-        sysTest = (JmsConsumerSystemProperties)sysTestProps;
-    }
-
-    public JmsClientProperties getJmsClientProperties() {
-        return getConsumer();
-    }
-
-    public JmsConsumerProperties getConsumer() {
-        return consumer;
-    }
-
-    public void setConsumer(JmsConsumerProperties consumer) {
-        this.consumer = consumer;
-    }
-
-    protected void runJmsClient(String clientName, int clientDestIndex, int clientDestCount) {
-        ThroughputSamplerTask sampler = getTpSampler();
-
-        JmsConsumerClient consumerClient = new JmsConsumerClient(consumer, jmsConnFactory);
-        consumerClient.setClientName(clientName);
-
-        if (sampler != null) {
-            sampler.registerClient(consumerClient);
-        }
-
-        try {
-            consumerClient.receiveMessages(clientDestIndex, clientDestCount);
-        } catch (JMSException e) {
-            e.printStackTrace();
-        }
-    }
-
-    public static void main(String[] args) {
-        JmsConsumerSystem sys = new JmsConsumerSystem();
-        sys.configureProperties(AbstractJmsClientSystem.parseStringArgs(args));
-
-        try {
-            sys.runSystemTest();
-        } catch (JMSException e) {
-            e.printStackTrace();
-        }
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool;
+
+import org.apache.activemq.tool.properties.JmsClientSystemProperties;
+import org.apache.activemq.tool.properties.JmsConsumerSystemProperties;
+import org.apache.activemq.tool.properties.JmsConsumerProperties;
+import org.apache.activemq.tool.properties.JmsClientProperties;
+import org.apache.activemq.tool.sampler.ThroughputSamplerTask;
+
+import javax.jms.JMSException;
+import java.util.Properties;
+
+public class JmsConsumerSystem extends AbstractJmsClientSystem {
+    protected JmsConsumerSystemProperties sysTest = new JmsConsumerSystemProperties();
+    protected JmsConsumerProperties consumer = new JmsConsumerProperties();
+
+    public JmsClientSystemProperties getSysTest() {
+        return sysTest;
+    }
+
+    public void setSysTest(JmsClientSystemProperties sysTestProps) {
+        sysTest = (JmsConsumerSystemProperties)sysTestProps;
+    }
+
+    public JmsClientProperties getJmsClientProperties() {
+        return getConsumer();
+    }
+
+    public JmsConsumerProperties getConsumer() {
+        return consumer;
+    }
+
+    public void setConsumer(JmsConsumerProperties consumer) {
+        this.consumer = consumer;
+    }
+
+    protected void runJmsClient(String clientName, int clientDestIndex, int clientDestCount) {
+        ThroughputSamplerTask sampler = getTpSampler();
+
+        JmsConsumerClient consumerClient = new JmsConsumerClient(consumer, jmsConnFactory);
+        consumerClient.setClientName(clientName);
+
+        if (sampler != null) {
+            sampler.registerClient(consumerClient);
+        }
+
+        try {
+            consumerClient.receiveMessages(clientDestIndex, clientDestCount);
+        } catch (JMSException e) {
+            e.printStackTrace();
+        }
+    }
+
+    public static void main(String[] args) {
+        JmsConsumerSystem sys = new JmsConsumerSystem();
+        sys.configureProperties(AbstractJmsClientSystem.parseStringArgs(args));
+
+        try {
+            sys.runSystemTest();
+        } catch (JMSException e) {
+            e.printStackTrace();
+        }
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsConsumerSystem.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerClient.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerClient.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerClient.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerClient.java Wed Jul  5 15:30:19 2006
@@ -1,267 +1,267 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool;
-
-import org.apache.activemq.tool.properties.JmsProducerProperties;
-import org.apache.activemq.tool.properties.JmsClientProperties;
-import org.apache.commons.logging.Log;
-import org.apache.commons.logging.LogFactory;
-
-import javax.jms.ConnectionFactory;
-import javax.jms.MessageProducer;
-import javax.jms.TextMessage;
-import javax.jms.JMSException;
-import javax.jms.Destination;
-import javax.jms.DeliveryMode;
-import java.util.Arrays;
-
-public class JmsProducerClient extends AbstractJmsMeasurableClient {
-    private static final Log log = LogFactory.getLog(JmsProducerClient.class);
-
-    protected JmsProducerProperties client;
-    protected MessageProducer jmsProducer;
-    protected TextMessage jmsTextMessage;
-
-    public JmsProducerClient(ConnectionFactory factory) {
-        this(new JmsProducerProperties(), factory);
-    }
-
-    public JmsProducerClient(JmsProducerProperties clientProps, ConnectionFactory factory) {
-        super(factory);
-        this.client = clientProps;
-    }
-
-    public void sendMessages() throws JMSException {
-        // Send a specific number of messages
-        if (client.getSendType().equalsIgnoreCase(JmsProducerProperties.COUNT_BASED_SENDING)) {
-            sendCountBasedMessages(client.getSendCount());
-
-        // Send messages for a specific duration
-        } else {
-            sendTimeBasedMessages(client.getSendDuration());
-        }
-    }
-
-    public void sendMessages(int destCount) throws JMSException {
-        this.destCount = destCount;
-        sendMessages();
-    }
-
-    public void sendMessages(int destIndex, int destCount) throws JMSException {
-        this.destIndex = destIndex;
-        sendMessages(destCount);
-    }
-
-    public void sendCountBasedMessages(long messageCount) throws JMSException {
-        // Parse through different ways to send messages
-        // Avoided putting the condition inside the loop to prevent effect on performance
-        Destination[] dest = createDestination(destIndex, destCount);
-
-        // Create a producer, if none is created.
-        if (getJmsProducer() == null) {
-            if (dest.length == 1) {
-                createJmsProducer(dest[0]);
-            } else {
-                createJmsProducer();
-            }
-        }
-        try {
-            getConnection().start();
-            log.info("Starting to publish " + client.getMessageSize() + " byte(s) of " + messageCount + " messages...");
-
-            // Send one type of message only, avoiding the creation of different messages on sending
-            if (!client.isCreateNewMsg()) {
-                // Create only a single message
-                createJmsTextMessage();
-
-                // Send to more than one actual destination
-                if (dest.length > 1) {
-                    for (int i = 0; i < messageCount; i++) {
-                        for (int j = 0; j < dest.length; j++) {
-                            getJmsProducer().send(dest[j], getJmsTextMessage());
-                            incThroughput();
-                        }
-                    }
-                    // Send to only one actual destination
-                } else {
-                    for (int i = 0; i < messageCount; i++) {
-                        getJmsProducer().send(getJmsTextMessage());
-                        incThroughput();
-                    }
-                }
-
-                // Send different type of messages using indexing to identify each one.
-                // Message size will vary. Definitely slower, since messages properties
-                // will be set individually each send.
-            } else {
-                // Send to more than one actual destination
-                if (dest.length > 1) {
-                    for (int i = 0; i < messageCount; i++) {
-                        for (int j = 0; j < dest.length; j++) {
-                            getJmsProducer().send(dest[j], createJmsTextMessage("Text Message [" + i + "]"));
-                            incThroughput();
-                        }
-                    }
-
-                    // Send to only one actual destination
-                } else {
-                    for (int i = 0; i < messageCount; i++) {
-                        getJmsProducer().send(createJmsTextMessage("Text Message [" + i + "]"));
-                        incThroughput();
-                    }
-                }
-            }
-        } finally {
-            getConnection().close();
-        }
-    }
-
-    public void sendTimeBasedMessages(long duration) throws JMSException {
-        long endTime = System.currentTimeMillis() + duration;
-        // Parse through different ways to send messages
-        // Avoided putting the condition inside the loop to prevent effect on performance
-
-        Destination[] dest = createDestination(destIndex, destCount);
-
-        // Create a producer, if none is created.
-        if (getJmsProducer() == null) {
-            if (dest.length == 1) {
-                createJmsProducer(dest[0]);
-            } else {
-                createJmsProducer();
-            }
-        }
-
-        try {
-            getConnection().start();
-            log.info("Starting to publish " + client.getMessageSize() + " byte(s) messages for " + duration + " ms");
-
-            // Send one type of message only, avoiding the creation of different messages on sending
-            if (!client.isCreateNewMsg()) {
-                // Create only a single message
-                createJmsTextMessage();
-
-                // Send to more than one actual destination
-                if (dest.length > 1) {
-                    while (System.currentTimeMillis() < endTime) {
-                        for (int j = 0; j < dest.length; j++) {
-                            getJmsProducer().send(dest[j], getJmsTextMessage());
-                            incThroughput();
-                        }
-                    }
-                    // Send to only one actual destination
-                } else {
-                    while (System.currentTimeMillis() < endTime) {
-                        getJmsProducer().send(getJmsTextMessage());
-                        incThroughput();
-                    }
-                }
-
-                // Send different type of messages using indexing to identify each one.
-                // Message size will vary. Definitely slower, since messages properties
-                // will be set individually each send.
-            } else {
-                // Send to more than one actual destination
-                long count = 1;
-                if (dest.length > 1) {
-                    while (System.currentTimeMillis() < endTime) {
-                        for (int j = 0; j < dest.length; j++) {
-                            getJmsProducer().send(dest[j], createJmsTextMessage("Text Message [" + count++ + "]"));
-                            incThroughput();
-                        }
-                    }
-
-                    // Send to only one actual destination
-                } else {
-                    while (System.currentTimeMillis() < endTime) {
-
-                        getJmsProducer().send(createJmsTextMessage("Text Message [" + count++ + "]"));
-                        incThroughput();
-                    }
-                }
-            }
-        } finally {
-            getConnection().close();
-        }
-    }
-
-    public MessageProducer createJmsProducer() throws JMSException {
-        jmsProducer = getSession().createProducer(null);
-        if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_PERSISTENT)) {
-            log.info("Creating producer to possible multiple destinations with persistent delivery.");
-            jmsProducer.setDeliveryMode(DeliveryMode.PERSISTENT);
-        } else if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_NON_PERSISTENT)) {
-            log.info("Creating producer to possible multiple destinations with non-persistent delivery.");
-            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
-        } else {
-            log.warn("Unknown deliveryMode value. Defaulting to non-persistent.");
-            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
-        }
-        return jmsProducer;
-    }
-
-    public MessageProducer createJmsProducer(Destination dest) throws JMSException {
-        jmsProducer = getSession().createProducer(dest);
-        if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_PERSISTENT)) {
-            log.info("Creating producer to: " + dest.toString() + " with persistent delivery.");
-            jmsProducer.setDeliveryMode(DeliveryMode.PERSISTENT);
-        } else if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_NON_PERSISTENT)) {
-            log.info("Creating  producer to: " + dest.toString() + " with non-persistent delivery.");
-            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
-        } else {
-            log.warn("Unknown deliveryMode value. Defaulting to non-persistent.");
-            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
-        }
-        return jmsProducer;
-    }
-
-    public MessageProducer getJmsProducer() {
-        return jmsProducer;
-    }
-
-    public TextMessage createJmsTextMessage() throws JMSException {
-        return createJmsTextMessage(client.getMessageSize());
-    }
-
-    public TextMessage createJmsTextMessage(int size) throws JMSException {
-        jmsTextMessage = getSession().createTextMessage(buildText("", size));
-        return jmsTextMessage;
-    }
-
-    public TextMessage createJmsTextMessage(String text) throws JMSException {
-        jmsTextMessage = getSession().createTextMessage(buildText(text, client.getMessageSize()));
-        return jmsTextMessage;
-    }
-
-    public TextMessage getJmsTextMessage() {
-        return jmsTextMessage;
-    }
-
-    public JmsClientProperties getClient() {
-        return client;
-    }
-
-    public void setClient(JmsClientProperties clientProps) {
-        client = (JmsProducerProperties)clientProps;
-    }
-
-    protected String buildText(String text, int size) {
-        byte[] data = new byte[size - text.length()];
-        Arrays.fill(data, (byte) 0);
-        return text + new String(data);
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool;
+
+import org.apache.activemq.tool.properties.JmsProducerProperties;
+import org.apache.activemq.tool.properties.JmsClientProperties;
+import org.apache.commons.logging.Log;
+import org.apache.commons.logging.LogFactory;
+
+import javax.jms.ConnectionFactory;
+import javax.jms.MessageProducer;
+import javax.jms.TextMessage;
+import javax.jms.JMSException;
+import javax.jms.Destination;
+import javax.jms.DeliveryMode;
+import java.util.Arrays;
+
+public class JmsProducerClient extends AbstractJmsMeasurableClient {
+    private static final Log log = LogFactory.getLog(JmsProducerClient.class);
+
+    protected JmsProducerProperties client;
+    protected MessageProducer jmsProducer;
+    protected TextMessage jmsTextMessage;
+
+    public JmsProducerClient(ConnectionFactory factory) {
+        this(new JmsProducerProperties(), factory);
+    }
+
+    public JmsProducerClient(JmsProducerProperties clientProps, ConnectionFactory factory) {
+        super(factory);
+        this.client = clientProps;
+    }
+
+    public void sendMessages() throws JMSException {
+        // Send a specific number of messages
+        if (client.getSendType().equalsIgnoreCase(JmsProducerProperties.COUNT_BASED_SENDING)) {
+            sendCountBasedMessages(client.getSendCount());
+
+        // Send messages for a specific duration
+        } else {
+            sendTimeBasedMessages(client.getSendDuration());
+        }
+    }
+
+    public void sendMessages(int destCount) throws JMSException {
+        this.destCount = destCount;
+        sendMessages();
+    }
+
+    public void sendMessages(int destIndex, int destCount) throws JMSException {
+        this.destIndex = destIndex;
+        sendMessages(destCount);
+    }
+
+    public void sendCountBasedMessages(long messageCount) throws JMSException {
+        // Parse through different ways to send messages
+        // Avoided putting the condition inside the loop to prevent effect on performance
+        Destination[] dest = createDestination(destIndex, destCount);
+
+        // Create a producer, if none is created.
+        if (getJmsProducer() == null) {
+            if (dest.length == 1) {
+                createJmsProducer(dest[0]);
+            } else {
+                createJmsProducer();
+            }
+        }
+        try {
+            getConnection().start();
+            log.info("Starting to publish " + client.getMessageSize() + " byte(s) of " + messageCount + " messages...");
+
+            // Send one type of message only, avoiding the creation of different messages on sending
+            if (!client.isCreateNewMsg()) {
+                // Create only a single message
+                createJmsTextMessage();
+
+                // Send to more than one actual destination
+                if (dest.length > 1) {
+                    for (int i = 0; i < messageCount; i++) {
+                        for (int j = 0; j < dest.length; j++) {
+                            getJmsProducer().send(dest[j], getJmsTextMessage());
+                            incThroughput();
+                        }
+                    }
+                    // Send to only one actual destination
+                } else {
+                    for (int i = 0; i < messageCount; i++) {
+                        getJmsProducer().send(getJmsTextMessage());
+                        incThroughput();
+                    }
+                }
+
+                // Send different type of messages using indexing to identify each one.
+                // Message size will vary. Definitely slower, since messages properties
+                // will be set individually each send.
+            } else {
+                // Send to more than one actual destination
+                if (dest.length > 1) {
+                    for (int i = 0; i < messageCount; i++) {
+                        for (int j = 0; j < dest.length; j++) {
+                            getJmsProducer().send(dest[j], createJmsTextMessage("Text Message [" + i + "]"));
+                            incThroughput();
+                        }
+                    }
+
+                    // Send to only one actual destination
+                } else {
+                    for (int i = 0; i < messageCount; i++) {
+                        getJmsProducer().send(createJmsTextMessage("Text Message [" + i + "]"));
+                        incThroughput();
+                    }
+                }
+            }
+        } finally {
+            getConnection().close();
+        }
+    }
+
+    public void sendTimeBasedMessages(long duration) throws JMSException {
+        long endTime = System.currentTimeMillis() + duration;
+        // Parse through different ways to send messages
+        // Avoided putting the condition inside the loop to prevent effect on performance
+
+        Destination[] dest = createDestination(destIndex, destCount);
+
+        // Create a producer, if none is created.
+        if (getJmsProducer() == null) {
+            if (dest.length == 1) {
+                createJmsProducer(dest[0]);
+            } else {
+                createJmsProducer();
+            }
+        }
+
+        try {
+            getConnection().start();
+            log.info("Starting to publish " + client.getMessageSize() + " byte(s) messages for " + duration + " ms");
+
+            // Send one type of message only, avoiding the creation of different messages on sending
+            if (!client.isCreateNewMsg()) {
+                // Create only a single message
+                createJmsTextMessage();
+
+                // Send to more than one actual destination
+                if (dest.length > 1) {
+                    while (System.currentTimeMillis() < endTime) {
+                        for (int j = 0; j < dest.length; j++) {
+                            getJmsProducer().send(dest[j], getJmsTextMessage());
+                            incThroughput();
+                        }
+                    }
+                    // Send to only one actual destination
+                } else {
+                    while (System.currentTimeMillis() < endTime) {
+                        getJmsProducer().send(getJmsTextMessage());
+                        incThroughput();
+                    }
+                }
+
+                // Send different type of messages using indexing to identify each one.
+                // Message size will vary. Definitely slower, since messages properties
+                // will be set individually each send.
+            } else {
+                // Send to more than one actual destination
+                long count = 1;
+                if (dest.length > 1) {
+                    while (System.currentTimeMillis() < endTime) {
+                        for (int j = 0; j < dest.length; j++) {
+                            getJmsProducer().send(dest[j], createJmsTextMessage("Text Message [" + count++ + "]"));
+                            incThroughput();
+                        }
+                    }
+
+                    // Send to only one actual destination
+                } else {
+                    while (System.currentTimeMillis() < endTime) {
+
+                        getJmsProducer().send(createJmsTextMessage("Text Message [" + count++ + "]"));
+                        incThroughput();
+                    }
+                }
+            }
+        } finally {
+            getConnection().close();
+        }
+    }
+
+    public MessageProducer createJmsProducer() throws JMSException {
+        jmsProducer = getSession().createProducer(null);
+        if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_PERSISTENT)) {
+            log.info("Creating producer to possible multiple destinations with persistent delivery.");
+            jmsProducer.setDeliveryMode(DeliveryMode.PERSISTENT);
+        } else if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_NON_PERSISTENT)) {
+            log.info("Creating producer to possible multiple destinations with non-persistent delivery.");
+            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
+        } else {
+            log.warn("Unknown deliveryMode value. Defaulting to non-persistent.");
+            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
+        }
+        return jmsProducer;
+    }
+
+    public MessageProducer createJmsProducer(Destination dest) throws JMSException {
+        jmsProducer = getSession().createProducer(dest);
+        if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_PERSISTENT)) {
+            log.info("Creating producer to: " + dest.toString() + " with persistent delivery.");
+            jmsProducer.setDeliveryMode(DeliveryMode.PERSISTENT);
+        } else if (client.getDeliveryMode().equalsIgnoreCase(JmsProducerProperties.DELIVERY_MODE_NON_PERSISTENT)) {
+            log.info("Creating  producer to: " + dest.toString() + " with non-persistent delivery.");
+            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
+        } else {
+            log.warn("Unknown deliveryMode value. Defaulting to non-persistent.");
+            jmsProducer.setDeliveryMode(DeliveryMode.NON_PERSISTENT);
+        }
+        return jmsProducer;
+    }
+
+    public MessageProducer getJmsProducer() {
+        return jmsProducer;
+    }
+
+    public TextMessage createJmsTextMessage() throws JMSException {
+        return createJmsTextMessage(client.getMessageSize());
+    }
+
+    public TextMessage createJmsTextMessage(int size) throws JMSException {
+        jmsTextMessage = getSession().createTextMessage(buildText("", size));
+        return jmsTextMessage;
+    }
+
+    public TextMessage createJmsTextMessage(String text) throws JMSException {
+        jmsTextMessage = getSession().createTextMessage(buildText(text, client.getMessageSize()));
+        return jmsTextMessage;
+    }
+
+    public TextMessage getJmsTextMessage() {
+        return jmsTextMessage;
+    }
+
+    public JmsClientProperties getClient() {
+        return client;
+    }
+
+    public void setClient(JmsClientProperties clientProps) {
+        client = (JmsProducerProperties)clientProps;
+    }
+
+    protected String buildText(String text, int size) {
+        byte[] data = new byte[size - text.length()];
+        Arrays.fill(data, (byte) 0);
+        return text + new String(data);
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerClient.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerSystem.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerSystem.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerSystem.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerSystem.java Wed Jul  5 15:30:19 2006
@@ -1,79 +1,79 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool;
-
-import org.apache.activemq.tool.properties.JmsClientSystemProperties;
-import org.apache.activemq.tool.properties.JmsProducerSystemProperties;
-import org.apache.activemq.tool.properties.JmsProducerProperties;
-import org.apache.activemq.tool.properties.JmsClientProperties;
-import org.apache.activemq.tool.sampler.ThroughputSamplerTask;
-
-import javax.jms.JMSException;
-import java.util.Properties;
-
-public class JmsProducerSystem extends AbstractJmsClientSystem {
-    protected JmsProducerSystemProperties sysTest = new JmsProducerSystemProperties();
-    protected JmsProducerProperties producer = new JmsProducerProperties();
-
-    public JmsClientSystemProperties getSysTest() {
-        return sysTest;
-    }
-
-    public void setSysTest(JmsClientSystemProperties sysTestProps) {
-        sysTest = (JmsProducerSystemProperties)sysTestProps;
-    }
-
-    public JmsClientProperties getJmsClientProperties() {
-        return getProducer();
-    }
-
-    public JmsProducerProperties getProducer() {
-        return producer;
-    }
-
-    public void setProducer(JmsProducerProperties producer) {
-        this.producer = producer;
-    }
-
-    protected void runJmsClient(String clientName, int clientDestIndex, int clientDestCount) {
-        ThroughputSamplerTask sampler = getTpSampler();
-
-        JmsProducerClient producerClient = new JmsProducerClient(producer, jmsConnFactory);
-        producerClient.setClientName(clientName);
-
-        if (sampler != null) {
-            sampler.registerClient(producerClient);
-        }
-
-        try {
-            producerClient.sendMessages(clientDestIndex, clientDestCount);
-        } catch (JMSException e) {
-            e.printStackTrace();
-        }
-    }
-
-    public static void main(String[] args) {
-        JmsProducerSystem sys = new JmsProducerSystem();
-        sys.configureProperties(AbstractJmsClientSystem.parseStringArgs(args));
-
-        try {
-            sys.runSystemTest();
-        } catch (JMSException e) {
-            e.printStackTrace();
-        }
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool;
+
+import org.apache.activemq.tool.properties.JmsClientSystemProperties;
+import org.apache.activemq.tool.properties.JmsProducerSystemProperties;
+import org.apache.activemq.tool.properties.JmsProducerProperties;
+import org.apache.activemq.tool.properties.JmsClientProperties;
+import org.apache.activemq.tool.sampler.ThroughputSamplerTask;
+
+import javax.jms.JMSException;
+import java.util.Properties;
+
+public class JmsProducerSystem extends AbstractJmsClientSystem {
+    protected JmsProducerSystemProperties sysTest = new JmsProducerSystemProperties();
+    protected JmsProducerProperties producer = new JmsProducerProperties();
+
+    public JmsClientSystemProperties getSysTest() {
+        return sysTest;
+    }
+
+    public void setSysTest(JmsClientSystemProperties sysTestProps) {
+        sysTest = (JmsProducerSystemProperties)sysTestProps;
+    }
+
+    public JmsClientProperties getJmsClientProperties() {
+        return getProducer();
+    }
+
+    public JmsProducerProperties getProducer() {
+        return producer;
+    }
+
+    public void setProducer(JmsProducerProperties producer) {
+        this.producer = producer;
+    }
+
+    protected void runJmsClient(String clientName, int clientDestIndex, int clientDestCount) {
+        ThroughputSamplerTask sampler = getTpSampler();
+
+        JmsProducerClient producerClient = new JmsProducerClient(producer, jmsConnFactory);
+        producerClient.setClientName(clientName);
+
+        if (sampler != null) {
+            sampler.registerClient(producerClient);
+        }
+
+        try {
+            producerClient.sendMessages(clientDestIndex, clientDestCount);
+        } catch (JMSException e) {
+            e.printStackTrace();
+        }
+    }
+
+    public static void main(String[] args) {
+        JmsProducerSystem sys = new JmsProducerSystem();
+        sys.configureProperties(AbstractJmsClientSystem.parseStringArgs(args));
+
+        try {
+            sys.runSystemTest();
+        } catch (JMSException e) {
+            e.printStackTrace();
+        }
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/JmsProducerSystem.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/AbstractObjectProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/AbstractObjectProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/AbstractObjectProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/AbstractObjectProperties.java Wed Jul  5 15:30:19 2006
@@ -1,34 +1,34 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-import java.util.Properties;
-
-public abstract class AbstractObjectProperties implements ReflectionConfigurable {
-
-    public void configureProperties(Properties props) {
-        ReflectionUtil.configureClass(this, props);
-    }
-
-    public Properties retrieveProperties(Properties props) {
-        return null;
-    }
-
-    public boolean acceptConfig(String key, String val) {
-        return true; // accept by default
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+import java.util.Properties;
+
+public abstract class AbstractObjectProperties implements ReflectionConfigurable {
+
+    public void configureProperties(Properties props) {
+        ReflectionUtil.configureClass(this, props);
+    }
+
+    public Properties retrieveProperties(Properties props) {
+        return null;
+    }
+
+    public boolean acceptConfig(String key, String val) {
+        return true; // accept by default
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/AbstractObjectProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientProperties.java Wed Jul  5 15:30:19 2006
@@ -1,89 +1,89 @@
-/**
- * Copyright 2005-2006 The Apache Software Foundation
- * <p/>
- * Licensed 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-public class JmsClientProperties extends AbstractObjectProperties {
-    public static final String SESSION_AUTO_ACKNOWLEDGE    = "autoAck";
-    public static final String SESSION_CLIENT_ACKNOWLEDGE  = "clientAck";
-    public static final String SESSION_DUPS_OK_ACKNOWLEDGE = "dupsAck";
-    public static final String SESSION_TRANSACTED          = "transacted";
-
-    protected String  destName       = "TEST.FOO";
-    protected boolean destComposite  = false;
-
-    protected String  sessAckMode    = SESSION_AUTO_ACKNOWLEDGE;
-    protected boolean sessTransacted = false;
-
-    protected String jmsProvider = null;
-    protected String jmsVersion = null;
-    protected String jmsProperties = null;
-
-    public String getDestName() {
-        return destName;
-    }
-
-    public void setDestName(String destName) {
-        this.destName = destName;
-    }
-
-    public boolean isDestComposite() {
-        return destComposite;
-    }
-
-    public void setDestComposite(boolean destComposite) {
-        this.destComposite = destComposite;
-    }
-
-    public String getSessAckMode() {
-        return sessAckMode;
-    }
-
-    public void setSessAckMode(String sessAckMode) {
-        this.sessAckMode = sessAckMode;
-    }
-
-    public boolean isSessTransacted() {
-        return sessTransacted;
-    }
-
-    public void setSessTransacted(boolean sessTransacted) {
-        this.sessTransacted = sessTransacted;
-    }
-
-    public String getJmsProvider() {
-        return jmsProvider;
-    }
-
-    public void setJmsProvider(String jmsProvider) {
-        this.jmsProvider = jmsProvider;
-    }
-
-    public String getJmsVersion() {
-        return jmsVersion;
-    }
-
-    public void setJmsVersion(String jmsVersion) {
-        this.jmsVersion = jmsVersion;
-    }
-
-    public String getJmsProperties() {
-        return jmsProperties;
-    }
-
-    public void setJmsProperties(String jmsProperties) {
-        this.jmsProperties = jmsProperties;
-    }
-}
+/**
+ * Copyright 2005-2006 The Apache Software Foundation
+ * <p/>
+ * Licensed 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+public class JmsClientProperties extends AbstractObjectProperties {
+    public static final String SESSION_AUTO_ACKNOWLEDGE    = "autoAck";
+    public static final String SESSION_CLIENT_ACKNOWLEDGE  = "clientAck";
+    public static final String SESSION_DUPS_OK_ACKNOWLEDGE = "dupsAck";
+    public static final String SESSION_TRANSACTED          = "transacted";
+
+    protected String  destName       = "TEST.FOO";
+    protected boolean destComposite  = false;
+
+    protected String  sessAckMode    = SESSION_AUTO_ACKNOWLEDGE;
+    protected boolean sessTransacted = false;
+
+    protected String jmsProvider = null;
+    protected String jmsVersion = null;
+    protected String jmsProperties = null;
+
+    public String getDestName() {
+        return destName;
+    }
+
+    public void setDestName(String destName) {
+        this.destName = destName;
+    }
+
+    public boolean isDestComposite() {
+        return destComposite;
+    }
+
+    public void setDestComposite(boolean destComposite) {
+        this.destComposite = destComposite;
+    }
+
+    public String getSessAckMode() {
+        return sessAckMode;
+    }
+
+    public void setSessAckMode(String sessAckMode) {
+        this.sessAckMode = sessAckMode;
+    }
+
+    public boolean isSessTransacted() {
+        return sessTransacted;
+    }
+
+    public void setSessTransacted(boolean sessTransacted) {
+        this.sessTransacted = sessTransacted;
+    }
+
+    public String getJmsProvider() {
+        return jmsProvider;
+    }
+
+    public void setJmsProvider(String jmsProvider) {
+        this.jmsProvider = jmsProvider;
+    }
+
+    public String getJmsVersion() {
+        return jmsVersion;
+    }
+
+    public void setJmsVersion(String jmsVersion) {
+        this.jmsVersion = jmsVersion;
+    }
+
+    public String getJmsProperties() {
+        return jmsProperties;
+    }
+
+    public void setJmsProperties(String jmsProperties) {
+        this.jmsProperties = jmsProperties;
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientSystemProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientSystemProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientSystemProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientSystemProperties.java Wed Jul  5 15:30:19 2006
@@ -1,125 +1,125 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-import java.io.File;
-
-public class JmsClientSystemProperties extends AbstractObjectProperties {
-    public static final String DEST_DISTRO_ALL    = "all";    // Each client will send/receive to all destination;
-    public static final String DEST_DISTRO_EQUAL  = "equal";  // Equally divide the number of destinations to the number of clients
-    public static final String DEST_DISTRO_DIVIDE = "divide"; // Divide the destination among the clients, even if some have more destination than others
-
-    public static final String REPORT_VERBOSE  = "verbose"; // Report would be generated to the console
-    public static final String REPORT_XML_FILE = "xml"; // Report would be generated to an xml file
-
-    public static final String SAMPLER_TP  = "tp";
-    public static final String SAMPLER_CPU = "cpu";
-
-    protected File propsConfigFile = null;
-
-    protected String reportType = REPORT_XML_FILE;
-    protected String reportDir  = "./";
-    protected String reportName = null;
-
-    protected String samplers = SAMPLER_TP + "," + SAMPLER_CPU; // Start both samplers
-
-    protected String spiClass = "org.apache.activemq.tool.spi.ActiveMQReflectionSPI";
-    protected String clientPrefix = "JmsClient";
-    protected int numClients = 1;
-    protected int totalDests = 1;
-    protected String destDistro = DEST_DISTRO_ALL;
-
-    public String getReportType() {
-        return reportType;
-    }
-
-    public void setReportType(String reportType) {
-        this.reportType = reportType;
-    }
-
-    public String getReportDir() {
-        return reportDir;
-    }
-
-    public void setReportDir(String reportDir) {
-        this.reportDir = reportDir;
-    }
-
-    public String getReportName() {
-        return reportName;
-    }
-
-    public void setReportName(String reportName) {
-        this.reportName = reportName;
-    }
-
-    public String getSamplers() {
-        return samplers;
-    }
-
-    public void setSamplers(String samplers) {
-        this.samplers = samplers;
-    }
-
-    public String getSpiClass() {
-        return spiClass;
-    }
-
-    public void setSpiClass(String spiClass) {
-        this.spiClass = spiClass;
-    }
-
-    public String getClientPrefix() {
-        return clientPrefix;
-    }
-
-    public void setClientPrefix(String clientPrefix) {
-        this.clientPrefix = clientPrefix;
-    }
-
-    public int getNumClients() {
-        return numClients;
-    }
-
-    public void setNumClients(int numClients) {
-        this.numClients = numClients;
-    }
-
-    public int getTotalDests() {
-        return totalDests;
-    }
-
-    public void setTotalDests(int totalDests) {
-        this.totalDests = totalDests;
-    }
-
-    public String getDestDistro() {
-        return destDistro;
-    }
-
-    public void setDestDistro(String destDistro) {
-        this.destDistro = destDistro;
-    }
-
-    public String getPropsConfigFile() {
-        return this.propsConfigFile + "";
-    }
-
-    public void setPropsConfigFile(String propsConfigFile) {
-        this.propsConfigFile = new File(propsConfigFile);
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+import java.io.File;
+
+public class JmsClientSystemProperties extends AbstractObjectProperties {
+    public static final String DEST_DISTRO_ALL    = "all";    // Each client will send/receive to all destination;
+    public static final String DEST_DISTRO_EQUAL  = "equal";  // Equally divide the number of destinations to the number of clients
+    public static final String DEST_DISTRO_DIVIDE = "divide"; // Divide the destination among the clients, even if some have more destination than others
+
+    public static final String REPORT_VERBOSE  = "verbose"; // Report would be generated to the console
+    public static final String REPORT_XML_FILE = "xml"; // Report would be generated to an xml file
+
+    public static final String SAMPLER_TP  = "tp";
+    public static final String SAMPLER_CPU = "cpu";
+
+    protected File propsConfigFile = null;
+
+    protected String reportType = REPORT_XML_FILE;
+    protected String reportDir  = "./";
+    protected String reportName = null;
+
+    protected String samplers = SAMPLER_TP + "," + SAMPLER_CPU; // Start both samplers
+
+    protected String spiClass = "org.apache.activemq.tool.spi.ActiveMQReflectionSPI";
+    protected String clientPrefix = "JmsClient";
+    protected int numClients = 1;
+    protected int totalDests = 1;
+    protected String destDistro = DEST_DISTRO_ALL;
+
+    public String getReportType() {
+        return reportType;
+    }
+
+    public void setReportType(String reportType) {
+        this.reportType = reportType;
+    }
+
+    public String getReportDir() {
+        return reportDir;
+    }
+
+    public void setReportDir(String reportDir) {
+        this.reportDir = reportDir;
+    }
+
+    public String getReportName() {
+        return reportName;
+    }
+
+    public void setReportName(String reportName) {
+        this.reportName = reportName;
+    }
+
+    public String getSamplers() {
+        return samplers;
+    }
+
+    public void setSamplers(String samplers) {
+        this.samplers = samplers;
+    }
+
+    public String getSpiClass() {
+        return spiClass;
+    }
+
+    public void setSpiClass(String spiClass) {
+        this.spiClass = spiClass;
+    }
+
+    public String getClientPrefix() {
+        return clientPrefix;
+    }
+
+    public void setClientPrefix(String clientPrefix) {
+        this.clientPrefix = clientPrefix;
+    }
+
+    public int getNumClients() {
+        return numClients;
+    }
+
+    public void setNumClients(int numClients) {
+        this.numClients = numClients;
+    }
+
+    public int getTotalDests() {
+        return totalDests;
+    }
+
+    public void setTotalDests(int totalDests) {
+        this.totalDests = totalDests;
+    }
+
+    public String getDestDistro() {
+        return destDistro;
+    }
+
+    public void setDestDistro(String destDistro) {
+        this.destDistro = destDistro;
+    }
+
+    public String getPropsConfigFile() {
+        return this.propsConfigFile + "";
+    }
+
+    public void setPropsConfigFile(String propsConfigFile) {
+        this.propsConfigFile = new File(propsConfigFile);
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsClientSystemProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerProperties.java Wed Jul  5 15:30:19 2006
@@ -1,68 +1,68 @@
-/**
- * Copyright 2005-2006 The Apache Software Foundation
- * <p/>
- * Licensed 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-public class JmsConsumerProperties extends JmsClientProperties {
-    public static final String TIME_BASED_RECEIVING = "time"; // Receive messages on a time-based interval
-    public static final String COUNT_BASED_RECEIVING = "count"; // Receive a specific count of messages
-
-    protected boolean durable   = false; // Consumer is a durable subscriber
-    protected boolean asyncRecv = true;  // If true, use onMessage() to receive messages, else use receive()
-
-    protected long recvCount    = 1000000;       // Receive a million messages by default
-    protected long recvDuration = 5 * 60 * 1000; // Receive for 5 mins by default
-    protected String recvType   = TIME_BASED_RECEIVING;
-
-    public boolean isDurable() {
-        return durable;
-    }
-
-    public void setDurable(boolean durable) {
-        this.durable = durable;
-    }
-
-    public boolean isAsyncRecv() {
-        return asyncRecv;
-    }
-
-    public void setAsyncRecv(boolean asyncRecv) {
-        this.asyncRecv = asyncRecv;
-    }
-
-    public long getRecvCount() {
-        return recvCount;
-    }
-
-    public void setRecvCount(long recvCount) {
-        this.recvCount = recvCount;
-    }
-
-    public long getRecvDuration() {
-        return recvDuration;
-    }
-
-    public void setRecvDuration(long recvDuration) {
-        this.recvDuration = recvDuration;
-    }
-
-    public String getRecvType() {
-        return recvType;
-    }
-
-    public void setRecvType(String recvType) {
-        this.recvType = recvType;
-    }
-}
+/**
+ * Copyright 2005-2006 The Apache Software Foundation
+ * <p/>
+ * Licensed 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+public class JmsConsumerProperties extends JmsClientProperties {
+    public static final String TIME_BASED_RECEIVING = "time"; // Receive messages on a time-based interval
+    public static final String COUNT_BASED_RECEIVING = "count"; // Receive a specific count of messages
+
+    protected boolean durable   = false; // Consumer is a durable subscriber
+    protected boolean asyncRecv = true;  // If true, use onMessage() to receive messages, else use receive()
+
+    protected long recvCount    = 1000000;       // Receive a million messages by default
+    protected long recvDuration = 5 * 60 * 1000; // Receive for 5 mins by default
+    protected String recvType   = TIME_BASED_RECEIVING;
+
+    public boolean isDurable() {
+        return durable;
+    }
+
+    public void setDurable(boolean durable) {
+        this.durable = durable;
+    }
+
+    public boolean isAsyncRecv() {
+        return asyncRecv;
+    }
+
+    public void setAsyncRecv(boolean asyncRecv) {
+        this.asyncRecv = asyncRecv;
+    }
+
+    public long getRecvCount() {
+        return recvCount;
+    }
+
+    public void setRecvCount(long recvCount) {
+        this.recvCount = recvCount;
+    }
+
+    public long getRecvDuration() {
+        return recvDuration;
+    }
+
+    public void setRecvDuration(long recvDuration) {
+        this.recvDuration = recvDuration;
+    }
+
+    public String getRecvType() {
+        return recvType;
+    }
+
+    public void setRecvType(String recvType) {
+        this.recvType = recvType;
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerSystemProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerSystemProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerSystemProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerSystemProperties.java Wed Jul  5 15:30:19 2006
@@ -1,23 +1,23 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-public class JmsConsumerSystemProperties extends JmsClientSystemProperties {
-    public JmsConsumerSystemProperties() {
-        clientPrefix = "JmsConsumer";
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+public class JmsConsumerSystemProperties extends JmsClientSystemProperties {
+    public JmsConsumerSystemProperties() {
+        clientPrefix = "JmsConsumer";
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsConsumerSystemProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsFactoryProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsFactoryProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsFactoryProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsFactoryProperties.java Wed Jul  5 15:30:19 2006
@@ -1,34 +1,34 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-import java.util.Properties;
-
-public class JmsFactoryProperties extends AbstractObjectProperties {
-    Properties factorySettings = new Properties();
-
-    public boolean acceptConfig(String key, String val) {
-        // Since we do not know the specific properties of each factory,
-        // lets cache it first and give it to the spi later
-        factorySettings.setProperty(key, val);
-        return false;
-    }
-
-    public Properties getFactorySettings() {
-        return factorySettings;
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+import java.util.Properties;
+
+public class JmsFactoryProperties extends AbstractObjectProperties {
+    Properties factorySettings = new Properties();
+
+    public boolean acceptConfig(String key, String val) {
+        // Since we do not know the specific properties of each factory,
+        // lets cache it first and give it to the spi later
+        factorySettings.setProperty(key, val);
+        return false;
+    }
+
+    public Properties getFactorySettings() {
+        return factorySettings;
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsFactoryProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerProperties.java Wed Jul  5 15:30:19 2006
@@ -1,79 +1,79 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-public class JmsProducerProperties extends JmsClientProperties {
-    public static final String TIME_BASED_SENDING  = "time"; // Produce messages base on a time interval
-    public static final String COUNT_BASED_SENDING = "count"; // Produce a specific count of messages
-    public static final String DELIVERY_MODE_PERSISTENT     = "persistent"; // Persistent message delivery
-    public static final String DELIVERY_MODE_NON_PERSISTENT = "nonpersistent"; // Non-persistent message delivery
-
-    protected String deliveryMode = DELIVERY_MODE_NON_PERSISTENT; // Message delivery mode
-    protected int messageSize = 1024; // Send 1kb messages by default
-    protected long sendCount  = 1000000; // Send a million messages by default
-    protected long sendDuration = 5 * 60 * 1000; // Send for 5 mins by default
-    protected String sendType = TIME_BASED_SENDING;
-    protected boolean createNewMsg = false; // If true, create a different message on each send, otherwise reuse.
-
-    public String getDeliveryMode() {
-        return deliveryMode;
-    }
-
-    public void setDeliveryMode(String deliveryMode) {
-        this.deliveryMode = deliveryMode;
-    }
-
-    public int getMessageSize() {
-        return messageSize;
-    }
-
-    public void setMessageSize(int messageSize) {
-        this.messageSize = messageSize;
-    }
-
-    public long getSendCount() {
-        return sendCount;
-    }
-
-    public void setSendCount(long sendCount) {
-        this.sendCount = sendCount;
-    }
-
-    public long getSendDuration() {
-        return sendDuration;
-    }
-
-    public void setSendDuration(long sendDuration) {
-        this.sendDuration = sendDuration;
-    }
-
-    public String getSendType() {
-        return sendType;
-    }
-
-    public void setSendType(String sendType) {
-        this.sendType = sendType;
-    }
-
-    public boolean isCreateNewMsg() {
-        return createNewMsg;
-    }
-
-    public void setCreateNewMsg(boolean createNewMsg) {
-        this.createNewMsg = createNewMsg;
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+public class JmsProducerProperties extends JmsClientProperties {
+    public static final String TIME_BASED_SENDING  = "time"; // Produce messages base on a time interval
+    public static final String COUNT_BASED_SENDING = "count"; // Produce a specific count of messages
+    public static final String DELIVERY_MODE_PERSISTENT     = "persistent"; // Persistent message delivery
+    public static final String DELIVERY_MODE_NON_PERSISTENT = "nonpersistent"; // Non-persistent message delivery
+
+    protected String deliveryMode = DELIVERY_MODE_NON_PERSISTENT; // Message delivery mode
+    protected int messageSize = 1024; // Send 1kb messages by default
+    protected long sendCount  = 1000000; // Send a million messages by default
+    protected long sendDuration = 5 * 60 * 1000; // Send for 5 mins by default
+    protected String sendType = TIME_BASED_SENDING;
+    protected boolean createNewMsg = false; // If true, create a different message on each send, otherwise reuse.
+
+    public String getDeliveryMode() {
+        return deliveryMode;
+    }
+
+    public void setDeliveryMode(String deliveryMode) {
+        this.deliveryMode = deliveryMode;
+    }
+
+    public int getMessageSize() {
+        return messageSize;
+    }
+
+    public void setMessageSize(int messageSize) {
+        this.messageSize = messageSize;
+    }
+
+    public long getSendCount() {
+        return sendCount;
+    }
+
+    public void setSendCount(long sendCount) {
+        this.sendCount = sendCount;
+    }
+
+    public long getSendDuration() {
+        return sendDuration;
+    }
+
+    public void setSendDuration(long sendDuration) {
+        this.sendDuration = sendDuration;
+    }
+
+    public String getSendType() {
+        return sendType;
+    }
+
+    public void setSendType(String sendType) {
+        this.sendType = sendType;
+    }
+
+    public boolean isCreateNewMsg() {
+        return createNewMsg;
+    }
+
+    public void setCreateNewMsg(boolean createNewMsg) {
+        this.createNewMsg = createNewMsg;
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerSystemProperties.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerSystemProperties.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerSystemProperties.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerSystemProperties.java Wed Jul  5 15:30:19 2006
@@ -1,23 +1,23 @@
-/**
- *
- * Copyright 2005-2006 The Apache Software Foundation
- *
- * Licensed under the Apache License, Version 2.0 (the "License");
- * you may not use this file except in compliance with the License.
- * You may obtain a copy of the License at
- *
- * http://www.apache.org/licenses/LICENSE-2.0
- *
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-public class JmsProducerSystemProperties extends JmsClientSystemProperties {
-    public JmsProducerSystemProperties() {
-        clientPrefix = "JmsProducer";
-    }
-}
+/**
+ *
+ * Copyright 2005-2006 The Apache Software Foundation
+ *
+ * Licensed under the Apache License, Version 2.0 (the "License");
+ * you may not use this file except in compliance with the License.
+ * You may obtain a copy of the License at
+ *
+ * http://www.apache.org/licenses/LICENSE-2.0
+ *
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+public class JmsProducerSystemProperties extends JmsClientSystemProperties {
+    public JmsProducerSystemProperties() {
+        clientPrefix = "JmsProducer";
+    }
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/JmsProducerSystemProperties.java
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/ReflectionConfigurable.java
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/ReflectionConfigurable.java?rev=419366&r1=419365&r2=419366&view=diff
==============================================================================
--- incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/ReflectionConfigurable.java (original)
+++ incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/ReflectionConfigurable.java Wed Jul  5 15:30:19 2006
@@ -1,24 +1,24 @@
-/**
- * Copyright 2005-2006 The Apache Software Foundation
- * <p/>
- * Licensed 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
- * <p/>
- * http://www.apache.org/licenses/LICENSE-2.0
- * <p/>
- * Unless required by applicable law or agreed to in writing, software
- * distributed under the License is distributed on an "AS IS" BASIS,
- * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
- * See the License for the specific language governing permissions and
- * limitations under the License.
- */
-package org.apache.activemq.tool.properties;
-
-import java.util.Properties;
-
-public interface ReflectionConfigurable {
-    public void configureProperties(Properties props);
-    public Properties retrieveProperties(Properties props);
-    public boolean acceptConfig(String key, String val);
-}
+/**
+ * Copyright 2005-2006 The Apache Software Foundation
+ * <p/>
+ * Licensed 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
+ * <p/>
+ * http://www.apache.org/licenses/LICENSE-2.0
+ * <p/>
+ * Unless required by applicable law or agreed to in writing, software
+ * distributed under the License is distributed on an "AS IS" BASIS,
+ * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
+ * See the License for the specific language governing permissions and
+ * limitations under the License.
+ */
+package org.apache.activemq.tool.properties;
+
+import java.util.Properties;
+
+public interface ReflectionConfigurable {
+    public void configureProperties(Properties props);
+    public Properties retrieveProperties(Properties props);
+    public boolean acceptConfig(String key, String val);
+}

Propchange: incubator/activemq/trunk/tooling/maven-activemq-perf-plugin/src/main/java/org/apache/activemq/tool/properties/ReflectionConfigurable.java
------------------------------------------------------------------------------
    svn:eol-style = native