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/11/14 22:16:17 UTC

svn commit: r474985 [5/5] - in /incubator/activemq/trunk: activemq-console/src/main/java/org/apache/activemq/console/ activemq-console/src/test/resources/ activemq-core/src/main/java/org/apache/activemq/ activemq-core/src/main/java/org/apache/activemq/...

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-nonpersistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-nonpersistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-nonpersistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-nonpersistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=1
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=nonpersistent
-producer.messageSize=1024
-producer.destName=topic://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=1
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=nonpersistent
+producer.messageSize=1024
+producer.destName=topic://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-nonpersistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-persistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-persistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-persistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-persistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=1
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=persistent
-producer.messageSize=1024
-producer.destName=topic://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=1
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=persistent
+producer.messageSize=1024
+producer.destName=topic://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-1-topic-persistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-nonpersistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-nonpersistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-nonpersistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-nonpersistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=10
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=nonpersistent
-producer.messageSize=1024
-producer.destName=queue://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=10
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=nonpersistent
+producer.messageSize=1024
+producer.destName=queue://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-nonpersistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-persistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-persistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-persistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-persistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=10
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=persistent
-producer.messageSize=1024
-producer.destName=queue://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=10
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=persistent
+producer.messageSize=1024
+producer.destName=queue://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-queue-persistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-nonpersistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-nonpersistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-nonpersistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-nonpersistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=10
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=nonpersistent
-producer.messageSize=1024
-producer.destName=topic://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=10
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=nonpersistent
+producer.messageSize=1024
+producer.destName=topic://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-nonpersistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-persistent.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-persistent.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-persistent.properties (original)
+++ incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-persistent.properties Tue Nov 14 13:16:11 2006
@@ -1,92 +1,92 @@
-## ---------------------------------------------------------------------------
-## 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.
-## ---------------------------------------------------------------------------
-
-# Consumer System Settings
-sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
-sysTest.reportType=xml
-sysTest.destDistro=all
-sysTest.samplers=tp
-sysTest.numClients=10
-sysTest.totalDests=10
-sysTest.reportDir=./
-
-# Consumer Client Settings
-producer.deliveryMode=persistent
-producer.messageSize=1024
-producer.destName=topic://TEST.FOO
-producer.sessTransacted=false
-producer.sessAckMode=autoAck
-producer.createNewMsg=false
-producer.destComposite=false
-# 5 mins send duration
-producer.sendType=time
-producer.sendDuration=300000
-# 1 million messages send
-# producer.sendType=count
-# producer.sendCount=1000000
-
-# Throughput Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-tpSampler.duration=300000
-tpSampler.rampUpTime=60000
-tpSampler.rampDownTime=60000
-tpSampler.interval=1000
-
-# CPU Sampler Settings
-# 5 mins sampling duration
-# 1 min ramp up and ramp down time
-# 1 sec sampling interval
-# cpuSampler.duration=300000
-# cpuSampler.rampUpTime=60000
-# cpuSampler.rampDownTime=60000
-# cpuSampler.interval=1000
-
-# AMQ Connection Factory Settings
-# Use default settings
-# factory.brokerURL=tcp://localhost:61616
-# factory.useAsyncSend=false
-# factory.asyncDispatch=false 
-# factory.alwaysSessionAsync=true 
-# factory.useCompression=false 
-# factory.optimizeAcknowledge=false 
-# factory.objectMessageSerializationDefered=false 
-# factory.disableTimeStampsByDefault=false 
-# factory.optimizedMessageDispatch=true 
-# factory.useRetroactiveConsumer=false 
-# factory.copyMessageOnSend=true 
-# factory.closeTimeout=15000 
-
-# factory.userName=null 
-# factory.clientID=null 
-# factory.password=null 
-
-# factory.prefetchPolicy.durableTopicPrefetch=100 
-# factory.prefetchPolicy.topicPrefetch=32766 
-# factory.prefetchPolicy.queueBrowserPrefetch=500 
-# factory.prefetchPolicy.queuePrefetch=1000 
-# factory.prefetchPolicy.inputStreamPrefetch=100 
-# factory.prefetchPolicy.maximumPendingMessageLimit=0 
-# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
-
-# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
-# factory.redeliveryPolicy.maximumRedeliveries=5 
-# factory.redeliveryPolicy.useCollisionAvoidance=false 
-# factory.redeliveryPolicy.useExponentialBackOff=false 
-# factory.redeliveryPolicy.collisionAvoidancePercent=15 
-# factory.redeliveryPolicy.backOffMultiplier=5 
+## ---------------------------------------------------------------------------
+## 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.
+## ---------------------------------------------------------------------------
+
+# Consumer System Settings
+sysTest.spiClass=org.apache.activemq.tool.spi.ActiveMQReflectionSPI
+sysTest.reportType=xml
+sysTest.destDistro=all
+sysTest.samplers=tp
+sysTest.numClients=10
+sysTest.totalDests=10
+sysTest.reportDir=./
+
+# Consumer Client Settings
+producer.deliveryMode=persistent
+producer.messageSize=1024
+producer.destName=topic://TEST.FOO
+producer.sessTransacted=false
+producer.sessAckMode=autoAck
+producer.createNewMsg=false
+producer.destComposite=false
+# 5 mins send duration
+producer.sendType=time
+producer.sendDuration=300000
+# 1 million messages send
+# producer.sendType=count
+# producer.sendCount=1000000
+
+# Throughput Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+tpSampler.duration=300000
+tpSampler.rampUpTime=60000
+tpSampler.rampDownTime=60000
+tpSampler.interval=1000
+
+# CPU Sampler Settings
+# 5 mins sampling duration
+# 1 min ramp up and ramp down time
+# 1 sec sampling interval
+# cpuSampler.duration=300000
+# cpuSampler.rampUpTime=60000
+# cpuSampler.rampDownTime=60000
+# cpuSampler.interval=1000
+
+# AMQ Connection Factory Settings
+# Use default settings
+# factory.brokerURL=tcp://localhost:61616
+# factory.useAsyncSend=false
+# factory.asyncDispatch=false 
+# factory.alwaysSessionAsync=true 
+# factory.useCompression=false 
+# factory.optimizeAcknowledge=false 
+# factory.objectMessageSerializationDefered=false 
+# factory.disableTimeStampsByDefault=false 
+# factory.optimizedMessageDispatch=true 
+# factory.useRetroactiveConsumer=false 
+# factory.copyMessageOnSend=true 
+# factory.closeTimeout=15000 
+
+# factory.userName=null 
+# factory.clientID=null 
+# factory.password=null 
+
+# factory.prefetchPolicy.durableTopicPrefetch=100 
+# factory.prefetchPolicy.topicPrefetch=32766 
+# factory.prefetchPolicy.queueBrowserPrefetch=500 
+# factory.prefetchPolicy.queuePrefetch=1000 
+# factory.prefetchPolicy.inputStreamPrefetch=100 
+# factory.prefetchPolicy.maximumPendingMessageLimit=0 
+# factory.prefetchPolicy.optimizeDurableTopicPrefetch=1000 
+
+# factory.redeliveryPolicy.initialRedeliveryDelay=1000 
+# factory.redeliveryPolicy.maximumRedeliveries=5 
+# factory.redeliveryPolicy.useCollisionAvoidance=false 
+# factory.redeliveryPolicy.useExponentialBackOff=false 
+# factory.redeliveryPolicy.collisionAvoidancePercent=15 
+# factory.redeliveryPolicy.backOffMultiplier=5 

Propchange: incubator/activemq/trunk/activemq-perftest/src/main/resources/producer-conf/AMQ-Prod-10-10-topic-persistent.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/activemq-soaktest/project.properties
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/activemq-soaktest/project.properties?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/activemq-soaktest/project.properties (original)
+++ incubator/activemq/trunk/activemq-soaktest/project.properties Tue Nov 14 13:16:11 2006
@@ -1,21 +1,21 @@
-##---------------------------------------------------------------------------
-## 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.
-##---------------------------------------------------------------------------
-
-# -------------------------------------------------------------------
-# Build Properties
-# -------------------------------------------------------------------
-
+##---------------------------------------------------------------------------
+## 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.
+##---------------------------------------------------------------------------
+
+# -------------------------------------------------------------------
+# Build Properties
+# -------------------------------------------------------------------
+

Propchange: incubator/activemq/trunk/activemq-soaktest/project.properties
------------------------------------------------------------------------------
    svn:eol-style = native

Modified: incubator/activemq/trunk/assembly/src/main/descriptors/unix-src.xml
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/assembly/src/main/descriptors/unix-src.xml?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/assembly/src/main/descriptors/unix-src.xml (original)
+++ incubator/activemq/trunk/assembly/src/main/descriptors/unix-src.xml Tue Nov 14 13:16:11 2006
@@ -35,6 +35,7 @@
         <include>**/*.so</include>
         <include>**/*.ks</include>
         <include>**/*.ts</include>
+        <include>**/*.keystore</include>
       </includes>
     </fileSet>
 
@@ -55,6 +56,7 @@
         <exclude>**/*.so</exclude>
         <exclude>**/*.ks</exclude>
         <exclude>**/*.ts</exclude>
+        <exclude>**/*.keystore</exclude>
         <exclude>**/svn-commit*</exclude>
         <exclude>**/target</exclude>
         <exclude>**/target/**/*</exclude>

Modified: incubator/activemq/trunk/assembly/src/main/descriptors/windows-src.xml
URL: http://svn.apache.org/viewvc/incubator/activemq/trunk/assembly/src/main/descriptors/windows-src.xml?view=diff&rev=474985&r1=474984&r2=474985
==============================================================================
--- incubator/activemq/trunk/assembly/src/main/descriptors/windows-src.xml (original)
+++ incubator/activemq/trunk/assembly/src/main/descriptors/windows-src.xml Tue Nov 14 13:16:11 2006
@@ -35,6 +35,7 @@
         <include>**/*.so</include>
         <include>**/*.ks</include>
         <include>**/*.ts</include>
+        <include>**/*.keystore</include>
       </includes>
     </fileSet>
 
@@ -55,6 +56,7 @@
         <exclude>**/*.so</exclude>
         <exclude>**/*.ks</exclude>
         <exclude>**/*.ts</exclude>
+        <exclude>**/*.keystore</exclude>
         <exclude>**/svn-commit*</exclude>
         <exclude>**/target</exclude>
         <exclude>**/target/**</exclude>

Propchange: incubator/activemq/trunk/assembly/src/release/example/src/CommnadLineSupport.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/assembly/src/release/example/src/RequesterTool.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/assembly/src/release/example/src/TopicListener.java
------------------------------------------------------------------------------
    svn:eol-style = native

Propchange: incubator/activemq/trunk/assembly/src/release/example/src/TopicPublisher.java
------------------------------------------------------------------------------
    svn:eol-style = native