You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@activemq.apache.org by bu...@apache.org on 2013/07/08 16:21:29 UTC

svn commit: r868823 [4/5] - in /websites/production/activemq/content: cache/ cms/

Modified: websites/production/activemq/content/cms/example.html
==============================================================================
--- websites/production/activemq/content/cms/example.html (original)
+++ websites/production/activemq/content/cms/example.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -79,33 +79,33 @@
 <p>The following example is taken from the source code and shows a basic usage scenario of ActiveMQ-CPP, you can find other examples in the examples folder that ships with the source distribution of ActiveMQ-CPP:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>main.cpp</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 /*
  * Licensed to the Apache Software Foundation (ASF) under one or more
  * contributor license agreements.  See the NOTICE file distributed with
- * <span class="code-keyword">this</span> work <span class="code-keyword">for</span> additional information regarding copyright ownership.
- * The ASF licenses <span class="code-keyword">this</span> file to You under the Apache License, Version 2.0
- * (the <span class="code-quote">"License"</span>); you may not use <span class="code-keyword">this</span> file except in compliance 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:<span class="code-comment">//www.apache.org/licenses/LICENSE-2.0
-</span> *
+ *     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 <span class="code-quote">"AS IS"</span> BASIS,
+ * 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 <span class="code-keyword">for</span> the specific language governing permissions and
+ * See the License for the specific language governing permissions and
  * limitations under the License.
  */
 
-<span class="code-comment">// START SNIPPET: demo
-</span>
+// START SNIPPET: demo
+
 #include &lt;activemq/library/ActiveMQCPP.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Thread</span>.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Runnable</span>.h&gt;
+#include &lt;decaf/lang/Thread.h&gt;
+#include &lt;decaf/lang/Runnable.h&gt;
 #include &lt;decaf/util/concurrent/CountDownLatch.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Integer</span>.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Long</span>.h&gt;
-#include &lt;decaf/lang/<span class="code-object">System</span>.h&gt;
+#include &lt;decaf/lang/Integer.h&gt;
+#include &lt;decaf/lang/Long.h&gt;
+#include &lt;decaf/lang/System.h&gt;
 #include &lt;activemq/core/ActiveMQConnectionFactory.h&gt;
 #include &lt;activemq/util/Config.h&gt;
 #include &lt;cms/Connection.h&gt;
@@ -127,26 +127,26 @@ using namespace decaf::lang;
 using namespace cms;
 using namespace std;
 
-class HelloWorldProducer : <span class="code-keyword">public</span> <span class="code-object">Runnable</span> {
-<span class="code-keyword">private</span>:
+class HelloWorldProducer : public Runnable {
+private:
 
     Connection* connection;
     Session* session;
     Destination* destination;
     MessageProducer* producer;
-    <span class="code-object">int</span> numMessages;
+    int numMessages;
     bool useTopic;
     bool sessionTransacted;
     std::string brokerURI;
 
-<span class="code-keyword">private</span>:
+private:
 
-    HelloWorldProducer(<span class="code-keyword">const</span> HelloWorldProducer&amp;);
-    HelloWorldProducer&amp; <span class="code-keyword">operator</span>=(<span class="code-keyword">const</span> HelloWorldProducer&amp;);
+    HelloWorldProducer(const HelloWorldProducer&amp;);
+    HelloWorldProducer&amp; operator=(const HelloWorldProducer&amp;);
 
-<span class="code-keyword">public</span>:
+public:
 
-    HelloWorldProducer(<span class="code-keyword">const</span> std::string&amp; brokerURI, <span class="code-object">int</span> numMessages, bool useTopic = <span class="code-keyword">false</span>, bool sessionTransacted = <span class="code-keyword">false</span>) :
+    HelloWorldProducer(const std::string&amp; brokerURI, int numMessages, bool useTopic = false, bool sessionTransacted = false) :
         connection(NULL),
         session(NULL),
         destination(NULL),
@@ -162,71 +162,71 @@ class HelloWorldProducer : <span class="
     }
 
     void close() {
-        <span class="code-keyword">this</span>-&gt;cleanup();
+        this-&gt;cleanup();
     }
 
     virtual void run() {
 
-        <span class="code-keyword">try</span> {
+        try {
 
-            <span class="code-comment">// Create a ConnectionFactory
-</span>            auto_ptr&lt;ConnectionFactory&gt; connectionFactory(
+            // Create a ConnectionFactory
+            auto_ptr&lt;ConnectionFactory&gt; connectionFactory(
                 ConnectionFactory::createCMSConnectionFactory(brokerURI));
 
-            <span class="code-comment">// Create a Connection
-</span>            connection = connectionFactory-&gt;createConnection();
+            // Create a Connection
+            connection = connectionFactory-&gt;createConnection();
             connection-&gt;start();
 
-            <span class="code-comment">// Create a Session
-</span>            <span class="code-keyword">if</span> (<span class="code-keyword">this</span>-&gt;sessionTransacted) {
+            // Create a Session
+            if (this-&gt;sessionTransacted) {
                 session = connection-&gt;createSession(Session::SESSION_TRANSACTED);
-            } <span class="code-keyword">else</span> {
+            } else {
                 session = connection-&gt;createSession(Session::AUTO_ACKNOWLEDGE);
             }
 
-            <span class="code-comment">// Create the destination (Topic or Queue)
-</span>            <span class="code-keyword">if</span> (useTopic) {
-                destination = session-&gt;createTopic(<span class="code-quote">"TEST.FOO"</span>);
-            } <span class="code-keyword">else</span> {
-                destination = session-&gt;createQueue(<span class="code-quote">"TEST.FOO"</span>);
+            // Create the destination (Topic or Queue)
+            if (useTopic) {
+                destination = session-&gt;createTopic("TEST.FOO");
+            } else {
+                destination = session-&gt;createQueue("TEST.FOO");
             }
 
-            <span class="code-comment">// Create a MessageProducer from the Session to the Topic or Queue
-</span>            producer = session-&gt;createProducer(destination);
+            // Create a MessageProducer from the Session to the Topic or Queue
+            producer = session-&gt;createProducer(destination);
             producer-&gt;setDeliveryMode(DeliveryMode::NON_PERSISTENT);
 
-            <span class="code-comment">// Create the <span class="code-object">Thread</span> Id <span class="code-object">String</span>
-</span>            string threadIdStr = <span class="code-object">Long</span>::toString(<span class="code-object">Thread</span>::currentThread()-&gt;getId());
+            // Create the Thread Id String
+            string threadIdStr = Long::toString(Thread::currentThread()-&gt;getId());
 
-            <span class="code-comment">// Create a messages
-</span>            string text = (string) <span class="code-quote">"Hello world! from thread "</span> + threadIdStr;
+            // Create a messages
+            string text = (string) "Hello world! from thread " + threadIdStr;
 
-            <span class="code-keyword">for</span> (<span class="code-object">int</span> ix = 0; ix &lt; numMessages; ++ix) {
+            for (int ix = 0; ix &lt; numMessages; ++ix) {
                 std::auto_ptr&lt;TextMessage&gt; message(session-&gt;createTextMessage(text));
-                message-&gt;setIntProperty(<span class="code-quote">"<span class="code-object">Integer</span>"</span>, ix);
-                printf(<span class="code-quote">"Sent message #%d from thread %s\n"</span>, ix + 1, threadIdStr.c_str());
+                message-&gt;setIntProperty("Integer", ix);
+                printf("Sent message #%d from thread %s\n", ix + 1, threadIdStr.c_str());
                 producer-&gt;send(message.get());
             }
 
-        } <span class="code-keyword">catch</span> (CMSException&amp; e) {
+        } catch (CMSException&amp; e) {
             e.printStackTrace();
         }
     }
 
-<span class="code-keyword">private</span>:
+private:
 
     void cleanup() {
 
-        <span class="code-keyword">if</span> (connection != NULL) {
-            <span class="code-keyword">try</span> {
+        if (connection != NULL) {
+            try {
                 connection-&gt;close();
-            } <span class="code-keyword">catch</span> (cms::CMSException&amp; ex) {
+            } catch (cms::CMSException&amp; ex) {
                 ex.printStackTrace();
             }
         }
 
-        <span class="code-comment">// Destroy resources.
-</span>        <span class="code-keyword">try</span> {
+        // Destroy resources.
+        try {
             delete destination;
             destination = NULL;
             delete producer;
@@ -235,17 +235,17 @@ class HelloWorldProducer : <span class="
             session = NULL;
             delete connection;
             connection = NULL;
-        } <span class="code-keyword">catch</span> (CMSException&amp; e) {
+        } catch (CMSException&amp; e) {
             e.printStackTrace();
         }
     }
 };
 
-class HelloWorldConsumer : <span class="code-keyword">public</span> ExceptionListener,
-                           <span class="code-keyword">public</span> MessageListener,
-                           <span class="code-keyword">public</span> <span class="code-object">Runnable</span> {
+class HelloWorldConsumer : public ExceptionListener,
+                           public MessageListener,
+                           public Runnable {
 
-<span class="code-keyword">private</span>:
+private:
 
     CountDownLatch latch;
     CountDownLatch doneLatch;
@@ -253,19 +253,19 @@ class HelloWorldConsumer : <span class="
     Session* session;
     Destination* destination;
     MessageConsumer* consumer;
-    <span class="code-object">long</span> waitMillis;
+    long waitMillis;
     bool useTopic;
     bool sessionTransacted;
     std::string brokerURI;
 
-<span class="code-keyword">private</span>:
+private:
 
-    HelloWorldConsumer(<span class="code-keyword">const</span> HelloWorldConsumer&amp;);
-    HelloWorldConsumer&amp; <span class="code-keyword">operator</span>=(<span class="code-keyword">const</span> HelloWorldConsumer&amp;);
+    HelloWorldConsumer(const HelloWorldConsumer&amp;);
+    HelloWorldConsumer&amp; operator=(const HelloWorldConsumer&amp;);
 
-<span class="code-keyword">public</span>:
+public:
 
-    HelloWorldConsumer(<span class="code-keyword">const</span> std::string&amp; brokerURI, <span class="code-object">int</span> numMessages, bool useTopic = <span class="code-keyword">false</span>, bool sessionTransacted = <span class="code-keyword">false</span>, <span class="code-object">int</span> waitMillis = 30000) :
+    HelloWorldConsumer(const std::string&amp; brokerURI, int numMessages, bool useTopic = false, bool sessionTransacted = false, int waitMillis = 30000) :
         latch(1),
         doneLatch(numMessages),
         connection(NULL),
@@ -283,7 +283,7 @@ class HelloWorldConsumer : <span class="
     }
 
     void close() {
-        <span class="code-keyword">this</span>-&gt;cleanup();
+        this-&gt;cleanup();
     }
 
     void waitUntilReady() {
@@ -292,104 +292,104 @@ class HelloWorldConsumer : <span class="
 
     virtual void run() {
 
-        <span class="code-keyword">try</span> {
+        try {
 
-            <span class="code-comment">// Create a ConnectionFactory
-</span>            auto_ptr&lt;ConnectionFactory&gt; connectionFactory(
+            // Create a ConnectionFactory
+            auto_ptr&lt;ConnectionFactory&gt; connectionFactory(
                 ConnectionFactory::createCMSConnectionFactory(brokerURI));
 
-            <span class="code-comment">// Create a Connection
-</span>            connection = connectionFactory-&gt;createConnection();
+            // Create a Connection
+            connection = connectionFactory-&gt;createConnection();
             connection-&gt;start();
-            connection-&gt;setExceptionListener(<span class="code-keyword">this</span>);
+            connection-&gt;setExceptionListener(this);
 
-            <span class="code-comment">// Create a Session
-</span>            <span class="code-keyword">if</span> (<span class="code-keyword">this</span>-&gt;sessionTransacted == <span class="code-keyword">true</span>) {
+            // Create a Session
+            if (this-&gt;sessionTransacted == true) {
                 session = connection-&gt;createSession(Session::SESSION_TRANSACTED);
-            } <span class="code-keyword">else</span> {
+            } else {
                 session = connection-&gt;createSession(Session::AUTO_ACKNOWLEDGE);
             }
 
-            <span class="code-comment">// Create the destination (Topic or Queue)
-</span>            <span class="code-keyword">if</span> (useTopic) {
-                destination = session-&gt;createTopic(<span class="code-quote">"TEST.FOO"</span>);
-            } <span class="code-keyword">else</span> {
-                destination = session-&gt;createQueue(<span class="code-quote">"TEST.FOO"</span>);
+            // Create the destination (Topic or Queue)
+            if (useTopic) {
+                destination = session-&gt;createTopic("TEST.FOO");
+            } else {
+                destination = session-&gt;createQueue("TEST.FOO");
             }
 
-            <span class="code-comment">// Create a MessageConsumer from the Session to the Topic or Queue
-</span>            consumer = session-&gt;createConsumer(destination);
+            // Create a MessageConsumer from the Session to the Topic or Queue
+            consumer = session-&gt;createConsumer(destination);
 
-            consumer-&gt;setMessageListener(<span class="code-keyword">this</span>);
+            consumer-&gt;setMessageListener(this);
 
             std::cout.flush();
             std::cerr.flush();
 
-            <span class="code-comment">// Indicate we are ready <span class="code-keyword">for</span> messages.
-</span>            latch.countDown();
+            // Indicate we are ready for messages.
+            latch.countDown();
 
-            <span class="code-comment">// Wait <span class="code-keyword">while</span> asynchronous messages come in.
-</span>            doneLatch.await(waitMillis);
+            // Wait while asynchronous messages come in.
+            doneLatch.await(waitMillis);
 
-        } <span class="code-keyword">catch</span> (CMSException&amp; e) {
-            <span class="code-comment">// Indicate we are ready <span class="code-keyword">for</span> messages.
-</span>            latch.countDown();
+        } catch (CMSException&amp; e) {
+            // Indicate we are ready for messages.
+            latch.countDown();
             e.printStackTrace();
         }
     }
 
-    <span class="code-comment">// Called from the consumer since <span class="code-keyword">this</span> class is a registered MessageListener.
-</span>    virtual void onMessage(<span class="code-keyword">const</span> Message* message) {
+    // Called from the consumer since this class is a registered MessageListener.
+    virtual void onMessage(const Message* message) {
 
-        <span class="code-keyword">static</span> <span class="code-object">int</span> count = 0;
+        static int count = 0;
 
-        <span class="code-keyword">try</span> {
+        try {
             count++;
-            <span class="code-keyword">const</span> TextMessage* textMessage = dynamic_cast&lt;<span class="code-keyword">const</span> TextMessage*&gt; (message);
+            const TextMessage* textMessage = dynamic_cast&lt;const TextMessage*&gt; (message);
             string text = "";
 
-            <span class="code-keyword">if</span> (textMessage != NULL) {
+            if (textMessage != NULL) {
                 text = textMessage-&gt;getText();
-            } <span class="code-keyword">else</span> {
-                text = <span class="code-quote">"NOT A TEXTMESSAGE!"</span>;
+            } else {
+                text = "NOT A TEXTMESSAGE!";
             }
 
-            printf(<span class="code-quote">"Message #%d Received: %s\n"</span>, count, text.c_str());
+            printf("Message #%d Received: %s\n", count, text.c_str());
 
-        } <span class="code-keyword">catch</span> (CMSException&amp; e) {
+        } catch (CMSException&amp; e) {
             e.printStackTrace();
         }
 
-        <span class="code-comment">// Commit all messages.
-</span>        <span class="code-keyword">if</span> (<span class="code-keyword">this</span>-&gt;sessionTransacted) {
+        // Commit all messages.
+        if (this-&gt;sessionTransacted) {
             session-&gt;commit();
         }
 
-        <span class="code-comment">// No matter what, tag the count down latch until done.
-</span>        doneLatch.countDown();
+        // No matter what, tag the count down latch until done.
+        doneLatch.countDown();
     }
 
-    <span class="code-comment">// If something bad happens you see it here as <span class="code-keyword">this</span> class is also been
-</span>    <span class="code-comment">// registered as an ExceptionListener with the connection.
-</span>    virtual void onException(<span class="code-keyword">const</span> CMSException&amp; ex AMQCPP_UNUSED) {
-        printf(<span class="code-quote">"CMS Exception occurred.  Shutting down client.\n"</span>);
+    // If something bad happens you see it here as this class is also been
+    // registered as an ExceptionListener with the connection.
+    virtual void onException(const CMSException&amp; ex AMQCPP_UNUSED) {
+        printf("CMS Exception occurred.  Shutting down client.\n");
         ex.printStackTrace();
         exit(1);
     }
 
-<span class="code-keyword">private</span>:
+private:
 
     void cleanup() {
-        <span class="code-keyword">if</span> (connection != NULL) {
-            <span class="code-keyword">try</span> {
+        if (connection != NULL) {
+            try {
                 connection-&gt;close();
-            } <span class="code-keyword">catch</span> (cms::CMSException&amp; ex) {
+            } catch (cms::CMSException&amp; ex) {
                 ex.printStackTrace();
             }
         }
 
-        <span class="code-comment">// Destroy resources.
-</span>        <span class="code-keyword">try</span> {
+        // Destroy resources.
+        try {
             delete destination;
             destination = NULL;
             delete consumer;
@@ -398,102 +398,102 @@ class HelloWorldConsumer : <span class="
             session = NULL;
             delete connection;
             connection = NULL;
-        } <span class="code-keyword">catch</span> (CMSException&amp; e) {
+        } catch (CMSException&amp; e) {
             e.printStackTrace();
         }
     }
 };
 
-<span class="code-object">int</span> main(<span class="code-object">int</span> argc AMQCPP_UNUSED, <span class="code-object">char</span>* argv[] AMQCPP_UNUSED) {
+int main(int argc AMQCPP_UNUSED, char* argv[] AMQCPP_UNUSED) {
 
     activemq::library::ActiveMQCPP::initializeLibrary();
     {
-    std::cout &lt;&lt; <span class="code-quote">"=====================================================\n"</span>;
-    std::cout &lt;&lt; <span class="code-quote">"Starting the example:"</span> &lt;&lt; std::endl;
-    std::cout &lt;&lt; <span class="code-quote">"-----------------------------------------------------\n"</span>;
-
-
-    <span class="code-comment">// Set the URI to point to the IP Address of your broker.
-</span>    <span class="code-comment">// add any optional params to the url to enable things like
-</span>    <span class="code-comment">// tightMarshalling or tcp logging etc.  See the CMS web site <span class="code-keyword">for</span>
-</span>    <span class="code-comment">// a full list of configuration options.
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">//  http://activemq.apache.org/cms/
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">// Wire Format Options:
-</span>    <span class="code-comment">// =========================
-</span>    <span class="code-comment">// Use either stomp or openwire, the <span class="code-keyword">default</span> ports are different <span class="code-keyword">for</span> each
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">// Examples:
-</span>    <span class="code-comment">//    tcp://127.0.0.1:61616                      <span class="code-keyword">default</span> to openwire
-</span>    <span class="code-comment">//    tcp://127.0.0.1:61613?wireFormat=stomp     use stomp instead
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">// SSL:
-</span>    <span class="code-comment">// =========================
-</span>    <span class="code-comment">// To use SSL you need to specify the location of the trusted Root CA or the
-</span>    <span class="code-comment">// certificate <span class="code-keyword">for</span> the broker you want to connect to.  Using the Root CA allows
-</span>    <span class="code-comment">// you to use failover with multiple servers all using certificates signed by
-</span>    <span class="code-comment">// the trusted root.  If using client authentication you also need to specify
-</span>    <span class="code-comment">// the location of the client Certificate.
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">//     <span class="code-object">System</span>::setProperty( <span class="code-quote">"decaf.net.ssl.keyStore"</span>, <span class="code-quote">"&lt;path&gt;/client.pem"</span> );
-</span>    <span class="code-comment">//     <span class="code-object">System</span>::setProperty( <span class="code-quote">"decaf.net.ssl.keyStorePassword"</span>, <span class="code-quote">"password"</span> );
-</span>    <span class="code-comment">//     <span class="code-object">System</span>::setProperty( <span class="code-quote">"decaf.net.ssl.trustStore"</span>, <span class="code-quote">"&lt;path&gt;/rootCA.pem"</span> );
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">// The you just specify the ssl transport in the URI, <span class="code-keyword">for</span> example:
-</span>    <span class="code-comment">//
-</span>    <span class="code-comment">//     ssl://localhost:61617
-</span>    <span class="code-comment">//
-</span>    std::string brokerURI =
-        <span class="code-quote">"failover:(tcp:<span class="code-comment">//localhost:61616)"</span>;
-</span>
-    <span class="code-comment">//============================================================
-</span>    <span class="code-comment">// set to <span class="code-keyword">true</span> to use topics instead of queues
-</span>    <span class="code-comment">// Note in the code above that <span class="code-keyword">this</span> causes createTopic or
-</span>    <span class="code-comment">// createQueue to be used in both consumer an producer.
-</span>    <span class="code-comment">//============================================================
-</span>    bool useTopics = <span class="code-keyword">true</span>;
-    bool sessionTransacted = <span class="code-keyword">false</span>;
-    <span class="code-object">int</span> numMessages = 2000;
+    std::cout &lt;&lt; "=====================================================\n";
+    std::cout &lt;&lt; "Starting the example:" &lt;&lt; std::endl;
+    std::cout &lt;&lt; "-----------------------------------------------------\n";
+
+
+    // Set the URI to point to the IP Address of your broker.
+    // add any optional params to the url to enable things like
+    // tightMarshalling or tcp logging etc.  See the CMS web site for
+    // a full list of configuration options.
+    //
+    //  http://activemq.apache.org/cms/
+    //
+    // Wire Format Options:
+    // =========================
+    // Use either stomp or openwire, the default ports are different for each
+    //
+    // Examples:
+    //    tcp://127.0.0.1:61616                      default to openwire
+    //    tcp://127.0.0.1:61613?wireFormat=stomp     use stomp instead
+    //
+    // SSL:
+    // =========================
+    // To use SSL you need to specify the location of the trusted Root CA or the
+    // certificate for the broker you want to connect to.  Using the Root CA allows
+    // you to use failover with multiple servers all using certificates signed by
+    // the trusted root.  If using client authentication you also need to specify
+    // the location of the client Certificate.
+    //
+    //     System::setProperty( "decaf.net.ssl.keyStore", "&lt;path&gt;/client.pem" );
+    //     System::setProperty( "decaf.net.ssl.keyStorePassword", "password" );
+    //     System::setProperty( "decaf.net.ssl.trustStore", "&lt;path&gt;/rootCA.pem" );
+    //
+    // The you just specify the ssl transport in the URI, for example:
+    //
+    //     ssl://localhost:61617
+    //
+    std::string brokerURI =
+        "failover:(tcp://localhost:61616)";
+
+    //============================================================
+    // set to true to use topics instead of queues
+    // Note in the code above that this causes createTopic or
+    // createQueue to be used in both consumer an producer.
+    //============================================================
+    bool useTopics = true;
+    bool sessionTransacted = false;
+    int numMessages = 2000;
 
-    <span class="code-object">long</span> <span class="code-object">long</span> startTime = <span class="code-object">System</span>::currentTimeMillis();
+    long long startTime = System::currentTimeMillis();
 
     HelloWorldProducer producer(brokerURI, numMessages, useTopics);
         HelloWorldConsumer consumer(brokerURI, numMessages, useTopics, sessionTransacted);
 
-    <span class="code-comment">// Start the consumer thread.
-</span>    <span class="code-object">Thread</span> consumerThread(&amp;consumer);
+    // Start the consumer thread.
+    Thread consumerThread(&amp;consumer);
     consumerThread.start();
 
-    <span class="code-comment">// Wait <span class="code-keyword">for</span> the consumer to indicate that its ready to go.
-</span>    consumer.waitUntilReady();
+    // Wait for the consumer to indicate that its ready to go.
+    consumer.waitUntilReady();
 
-    <span class="code-comment">// Start the producer thread.
-</span>    <span class="code-object">Thread</span> producerThread(&amp;producer);
+    // Start the producer thread.
+    Thread producerThread(&amp;producer);
     producerThread.start();
 
-    <span class="code-comment">// Wait <span class="code-keyword">for</span> the threads to complete.
-</span>    producerThread.join();
+    // Wait for the threads to complete.
+    producerThread.join();
     consumerThread.join();
 
-    <span class="code-object">long</span> <span class="code-object">long</span> endTime = <span class="code-object">System</span>::currentTimeMillis();
-    <span class="code-object">double</span> totalTime = (<span class="code-object">double</span>)(endTime - startTime) / 1000.0;
+    long long endTime = System::currentTimeMillis();
+    double totalTime = (double)(endTime - startTime) / 1000.0;
 
     consumer.close();
     producer.close();
 
-    std::cout &lt;&lt; <span class="code-quote">"Time to completion = "</span> &lt;&lt; totalTime &lt;&lt; <span class="code-quote">" seconds."</span> &lt;&lt; std::endl;
-    std::cout &lt;&lt; <span class="code-quote">"-----------------------------------------------------\n"</span>;
-    std::cout &lt;&lt; <span class="code-quote">"Finished with the example."</span> &lt;&lt; std::endl;
-    std::cout &lt;&lt; <span class="code-quote">"=====================================================\n"</span>;
+    std::cout &lt;&lt; "Time to completion = " &lt;&lt; totalTime &lt;&lt; " seconds." &lt;&lt; std::endl;
+    std::cout &lt;&lt; "-----------------------------------------------------\n";
+    std::cout &lt;&lt; "Finished with the example." &lt;&lt; std::endl;
+    std::cout &lt;&lt; "=====================================================\n";
 
     }
     activemq::library::ActiveMQCPP::shutdownLibrary();
 }
 
-<span class="code-comment">// END SNIPPET: demo
-</span>
-</pre>
+// END SNIPPET: demo
+
+]]></script>
 </div></div>
           </div>
         </td>
@@ -518,8 +518,8 @@ class HelloWorldConsumer : <span class="
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/faq.html
==============================================================================
--- websites/production/activemq/content/cms/faq.html (original)
+++ websites/production/activemq/content/cms/faq.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -117,8 +117,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/general-build-issues.html
==============================================================================
--- websites/production/activemq/content/cms/general-build-issues.html (original)
+++ websites/production/activemq/content/cms/general-build-issues.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -98,8 +98,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/general.html
==============================================================================
--- websites/production/activemq/content/cms/general.html (original)
+++ websites/production/activemq/content/cms/general.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -98,8 +98,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/getting-started.html
==============================================================================
--- websites/production/activemq/content/cms/getting-started.html (original)
+++ websites/production/activemq/content/cms/getting-started.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -99,8 +99,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/handling-advisory-messages.html
==============================================================================
--- websites/production/activemq/content/cms/handling-advisory-messages.html (original)
+++ websites/production/activemq/content/cms/handling-advisory-messages.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -97,24 +97,24 @@
 <p>If we had a Topic named TOPIC.FOO and we wanted to know when a producer subscribed to that Topic we would need to create a Topic object whose name is <b>ActiveMQ.Advisory.Producer.Topic.TOPIC.FOO</b> in order to receive the advisory message we are interested in.  We know this because we can look at the above table and see that the <b>ActiveMQ.Advisory.Producer.Topic</b> is informed whenever a Producer starts or stops publishing messages on a Topic and we also know that our Topic is named TOPIC.FOO, so adding them together gets us the name of our Advisory Topic, we also know this because we peaked at the AdvisorySupport.java class, and no, that's not cheating.  Below is a code snippet showing the creation of the Topic using a CMS Session:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Creating an Advisory Topic for Producers on TOPIC.FOO</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
     std::auto_ptr&lt;cms::Topic&gt; advisories( session-&gt;createTopic(
-        <span class="code-quote">"ActiveMQ.Advisory.Producer.Topic.TOPIC.FOO"</span> ) );
+        "ActiveMQ.Advisory.Producer.Topic.TOPIC.FOO" ) );
 
-</pre>
+]]></script>
 </div></div>
 
 <p>Once we create the Topic for the advisory messages we want to listen for we just need to create a consumer to listen for them, the code snippet below demonstrates this:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Creating an Consumer for an Advisory Topic.</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
 std::auto_ptr&lt;cms::MessageConsumer&gt; consumer;
 consumer.reset( session-&gt;createConsumer( advisories.get() ) );
-consumer-&gt;setMessageListener( <span class="code-keyword">this</span> );
+consumer-&gt;setMessageListener( this );
 
-</pre>
+]]></script>
 </div></div>
 
 <p>As you can see there is no difference between subscriptions to advisory topics that subscriptions to any other Destination in CMS.  In the above example we registered as an asynchronous listener, you can also use the normal blocking <b>receive</b> method but we prefer this method.</p>
@@ -126,28 +126,28 @@ consumer-&gt;setMessageListener( <span c
 <p>Many of the advisory messages store meaningful data in the Message properties, for instance the Consumer Start / Stop advisory message contains an element with the key <b>consumerCount</b> which is populated with the current number of active consumers on the Topic or Queue in question.  Lets take a look at a code snippet now that checks the messages received in an onMessage callback to see if its an advisory message and acts on it if it is:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Using the CMS Type to determine if a Message is an Advisory</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
- void AdvisoryProducer::onMessage( <span class="code-keyword">const</span> cms::Message* message ) {
+ void AdvisoryProducer::onMessage( const cms::Message* message ) {
 
-     <span class="code-keyword">if</span>( message-&gt;getCMSType() == <span class="code-quote">"Advisory"</span> ) {
+     if( message-&gt;getCMSType() == "Advisory" ) {
 
-         std::cout &lt;&lt; <span class="code-quote">"Received an Advisory Message!"</span> &lt;&lt; std::endl;
+         std::cout &lt;&lt; "Received an Advisory Message!" &lt;&lt; std::endl;
 
-         <span class="code-keyword">if</span>( message-&gt;propertyExists( <span class="code-quote">"consumerCount"</span> ) ) {
+         if( message-&gt;propertyExists( "consumerCount" ) ) {
 
-             std::string consumerCount = message-&gt;getStringProperty( <span class="code-quote">"consumerCount"</span> );
-             std::cout &lt;&lt; <span class="code-quote">"<span class="code-object">Number</span> of Consumers = "</span> &lt;&lt; consumerCount &lt;&lt; std::endl;
+             std::string consumerCount = message-&gt;getStringProperty( "consumerCount" );
+             std::cout &lt;&lt; "Number of Consumers = " &lt;&lt; consumerCount &lt;&lt; std::endl;
  
-             <span class="code-comment">// Do Something Meaningful here....
-</span>         }
+             // Do Something Meaningful here....
+         }
 
-     } <span class="code-keyword">else</span> {
-         std::cout &lt;&lt; <span class="code-quote">"Received a Non-Advisory Message!"</span> &lt;&lt; std::endl;
+     } else {
+         std::cout &lt;&lt; "Received a Non-Advisory Message!" &lt;&lt; std::endl;
      }
  }
 
-</pre>
+]]></script>
 </div></div>
 
 <h3><a shape="rect" name="HandlingAdvisoryMessages-CompleteExample%3AProducerthatonlyProduceswhenthereisaConsumer"></a><b>Complete Example: Producer that only Produces when there is a Consumer</b></h3>
@@ -155,7 +155,7 @@ consumer-&gt;setMessageListener( <span c
 <p>Now that you've seen the basics of advisory message processing its time to show you a complete example that demonstrates what you can do with advisory messages.  The following code shows a class header and source file that implements a basic CMS Producer that will send heart beat message to a Topic called <b>HEART-BEAT-CHANNEL</b> only when there are active consumers, otherwise it sits idle.</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>AdvisoryProducer Header file</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
 #ifndef _ACTIVEMQCPP_EXAMPLES_ADVISORIES_ADVISORYPRODUCER_H_
 #define _ACTIVEMQCPP_EXAMPLES_ADVISORIES_ADVISORYPRODUCER_H_
@@ -168,7 +168,7 @@ consumer-&gt;setMessageListener( <span c
 #include &lt;cms/MessageConsumer.h&gt;
 #include &lt;cms/MessageListener.h&gt;
 
-#include &lt;decaf/lang/<span class="code-object">Runnable</span>.h&gt;
+#include &lt;decaf/lang/Runnable.h&gt;
 #include &lt;decaf/util/concurrent/CountDownLatch.h&gt;
 
 namespace activemqcpp {
@@ -179,23 +179,23 @@ namespace advisories {
      * A sample Producer that will only send Messages on its Topic when it has
      * received an advisory indicating that there is an active MessageConsumer
      * on the Topic.  Once another message comes in indicating that there is no
-     * longer a consumer then <span class="code-keyword">this</span> Producer stops producing again.
+     * longer a consumer then this Producer stops producing again.
      *
      * @since 3.0
      */
-    class AdvisoryProducer : <span class="code-keyword">public</span> decaf::lang::<span class="code-object">Runnable</span>,
-                             <span class="code-keyword">public</span> cms::MessageListener {
-    <span class="code-keyword">private</span>:
+    class AdvisoryProducer : public decaf::lang::Runnable,
+                             public cms::MessageListener {
+    private:
 
-        <span class="code-keyword">volatile</span> bool consumerOnline;
-        <span class="code-keyword">volatile</span> bool shutdown;
+        volatile bool consumerOnline;
+        volatile bool shutdown;
         decaf::util::concurrent::CountDownLatch shutdownLatch;
 
         cms::Session* session;
         std::auto_ptr&lt;cms::MessageConsumer&gt; consumer;
         std::auto_ptr&lt;cms::MessageProducer&gt; producer;
 
-    <span class="code-keyword">public</span>:
+    public:
 
         AdvisoryProducer( cms::Session* session );
         virtual ~AdvisoryProducer();
@@ -213,7 +213,7 @@ namespace advisories {
         /**
          * Async Message callback.
          */
-        virtual void onMessage( <span class="code-keyword">const</span> cms::Message* message );
+        virtual void onMessage( const cms::Message* message );
 
     };
 
@@ -221,19 +221,19 @@ namespace advisories {
 
 #endif /* _ACTIVEMQCPP_EXAMPLES_ADVISORIES_ADVISORYPRODUCER_H_ */
 
-</pre>
+]]></script>
 </div></div>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>AdvisoryProducer Source file</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-#include <span class="code-quote">"AdvisoryProducer.h"</span>
+#include "AdvisoryProducer.h"
 
 #include &lt;cms/Topic.h&gt;
 #include &lt;cms/Message.h&gt;
 #include &lt;cms/TextMessage.h&gt;
 #include &lt;decaf/lang/exceptions/NullPointerException.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Integer</span>.h&gt;
+#include &lt;decaf/lang/Integer.h&gt;
 
 using namespace std;
 using namespace activemqcpp;
@@ -243,77 +243,77 @@ using namespace decaf;
 using namespace decaf::lang;
 using namespace decaf::lang::exceptions;
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>AdvisoryProducer::AdvisoryProducer( cms::Session* session ) : shutdownLatch(1) {
+////////////////////////////////////////////////////////////////////////////////
+AdvisoryProducer::AdvisoryProducer( cms::Session* session ) : shutdownLatch(1) {
 
-    <span class="code-keyword">if</span>( session == NULL ) {
-        <span class="code-keyword">throw</span> NullPointerException(
-            __FILE__, __LINE__, <span class="code-quote">"Session <span class="code-object">Object</span> passed was Null."</span> );
+    if( session == NULL ) {
+        throw NullPointerException(
+            __FILE__, __LINE__, "Session Object passed was Null." );
     }
 
     std::auto_ptr&lt;cms::Topic&gt; destination( session-&gt;createTopic(
-        <span class="code-quote">"HEART-BEAT-CHANNEL"</span> ) );
+        "HEART-BEAT-CHANNEL" ) );
     std::auto_ptr&lt;cms::Topic&gt; advisories( session-&gt;createTopic(
-        <span class="code-quote">"ActiveMQ.Advisory.Consumer.Topic.HEART-BEAT-CHANNEL"</span> ) );
+        "ActiveMQ.Advisory.Consumer.Topic.HEART-BEAT-CHANNEL" ) );
 
-    <span class="code-keyword">this</span>-&gt;shutdown = <span class="code-keyword">false</span>;
-    <span class="code-keyword">this</span>-&gt;consumerOnline = <span class="code-keyword">false</span>;
+    this-&gt;shutdown = false;
+    this-&gt;consumerOnline = false;
 
-    <span class="code-keyword">this</span>-&gt;session = session;
-    <span class="code-keyword">this</span>-&gt;producer.reset( session-&gt;createProducer( destination.get() ) );
-    <span class="code-keyword">this</span>-&gt;consumer.reset( session-&gt;createConsumer( advisories.get() ) );
-    <span class="code-keyword">this</span>-&gt;consumer-&gt;setMessageListener( <span class="code-keyword">this</span> );
+    this-&gt;session = session;
+    this-&gt;producer.reset( session-&gt;createProducer( destination.get() ) );
+    this-&gt;consumer.reset( session-&gt;createConsumer( advisories.get() ) );
+    this-&gt;consumer-&gt;setMessageListener( this );
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>AdvisoryProducer::~AdvisoryProducer() {
+////////////////////////////////////////////////////////////////////////////////
+AdvisoryProducer::~AdvisoryProducer() {
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>void AdvisoryProducer::stop() {
-    <span class="code-keyword">this</span>-&gt;shutdown = <span class="code-keyword">true</span>;
-    <span class="code-keyword">this</span>-&gt;shutdownLatch.await( 3000 );
+////////////////////////////////////////////////////////////////////////////////
+void AdvisoryProducer::stop() {
+    this-&gt;shutdown = true;
+    this-&gt;shutdownLatch.await( 3000 );
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>void AdvisoryProducer::run() {
+////////////////////////////////////////////////////////////////////////////////
+void AdvisoryProducer::run() {
 
-    <span class="code-keyword">while</span>( !<span class="code-keyword">this</span>-&gt;shutdown ) {
+    while( !this-&gt;shutdown ) {
 
-        <span class="code-keyword">if</span>( <span class="code-keyword">this</span>-&gt;consumerOnline ) {
+        if( this-&gt;consumerOnline ) {
 
             std::auto_ptr&lt;cms::TextMessage&gt; message(
-                <span class="code-keyword">this</span>-&gt;session-&gt;createTextMessage( <span class="code-quote">"Alive"</span> ) );
+                this-&gt;session-&gt;createTextMessage( "Alive" ) );
 
-            <span class="code-keyword">this</span>-&gt;producer-&gt;send( message.get() );
+            this-&gt;producer-&gt;send( message.get() );
 
-            <span class="code-object">Thread</span>::sleep( 1000 );
+            Thread::sleep( 1000 );
         }
     }
 
-    <span class="code-keyword">this</span>-&gt;shutdownLatch.countDown();
+    this-&gt;shutdownLatch.countDown();
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>void AdvisoryProducer::onMessage( <span class="code-keyword">const</span> cms::Message* message ) {
+////////////////////////////////////////////////////////////////////////////////
+void AdvisoryProducer::onMessage( const cms::Message* message ) {
 
-    <span class="code-keyword">if</span>( message-&gt;getCMSType() == <span class="code-quote">"Advisory"</span> ) {
+    if( message-&gt;getCMSType() == "Advisory" ) {
 
-        std::cout &lt;&lt; <span class="code-quote">"Received an Advisory Message!"</span> &lt;&lt; std::endl;
+        std::cout &lt;&lt; "Received an Advisory Message!" &lt;&lt; std::endl;
 
-        <span class="code-keyword">if</span>( message-&gt;propertyExists( <span class="code-quote">"consumerCount"</span> ) ) {
+        if( message-&gt;propertyExists( "consumerCount" ) ) {
 
-            std::string consumerCount = message-&gt;getStringProperty( <span class="code-quote">"consumerCount"</span> );
-            std::cout &lt;&lt; <span class="code-quote">"<span class="code-object">Number</span> of Consumers = "</span> &lt;&lt; consumerCount &lt;&lt; std::endl;
-            <span class="code-keyword">this</span>-&gt;consumerOnline = <span class="code-object">Integer</span>::parseInt( consumerCount ) &gt; 0 ? <span class="code-keyword">true</span> : <span class="code-keyword">false</span>;
+            std::string consumerCount = message-&gt;getStringProperty( "consumerCount" );
+            std::cout &lt;&lt; "Number of Consumers = " &lt;&lt; consumerCount &lt;&lt; std::endl;
+            this-&gt;consumerOnline = Integer::parseInt( consumerCount ) &gt; 0 ? true : false;
         }
 
-    } <span class="code-keyword">else</span> {
-        std::cout &lt;&lt; <span class="code-quote">"Received a Non-Advisory Message!"</span> &lt;&lt; std::endl;
+    } else {
+        std::cout &lt;&lt; "Received a Non-Advisory Message!" &lt;&lt; std::endl;
     }
 }
 
-</pre>
+]]></script>
 </div></div>
 
 <h3><a shape="rect" name="HandlingAdvisoryMessages-AdvancedTopicDealingwithCommandObjectsinAdvisories"></a>*<b>Advanced Topic</b>* Dealing with Command Objects in Advisories </h3>
@@ -325,138 +325,138 @@ using namespace decaf::lang::exceptions;
 <p>To demonstrate how we can access the command objects lets try and create a client application that listens to the Broker for advisories that indicate that Temporary Destinations have either been created or destroyed.  The Broker will publish advisory messages to the "ActiveMQ.Advisory.TempTopic" and "ActiveMQ.Advisory.TempQueue" Topics whenever the corresponding Temporary Destination is created or destroyed and the command object will be of type DestinationInfo.  The DestinationInfo object contains a Destination object describing the Destination in question and an Operation Type value telling whether the command is a create or destroy command.  First lets look at how we subscribe to this Advisory Topic:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Subscribing to a Composite Advisory Topic</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
 std::auto_ptr&lt;cms::Topic&gt; advisories( session-&gt;createTopic(
-    <span class="code-quote">"ActiveMQ.Advisory.TempTopic,ActiveMQ.Advisory.TempQueue"</span> ) );
+    "ActiveMQ.Advisory.TempTopic,ActiveMQ.Advisory.TempQueue" ) );
 
 std::auto_ptr&lt;cms::MessageConsumer&gt; consumer;
 consumer.reset( session-&gt;createConsumer( advisories.get() ) );
-consumer-&gt;setMessageListener( <span class="code-keyword">this</span> );
+consumer-&gt;setMessageListener( this );
 
-</pre>
+]]></script>
 </div></div>
 
 <p>As you can see in the above code snippet we just create a new Topic object whose name is a composite of the two Topics we want to subscribe on, this will allow our single <b>MessageConsumer</b> instance to receive both Temporary Topic and Temporary Queue advisories.  As before we also create a <b>MessageConsumer</b> and register our class' instance as the asynchronous listener.  Now all that's left is to implement the <b>onMessage</b> method of the <b>MessageListener</b> interface, lets take a look at that code now:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Processing an Advisory message with an embedded command object</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>void TempDestinationAdvisoryConsumer::onMessage( <span class="code-keyword">const</span> cms::Message* message ) {
+////////////////////////////////////////////////////////////////////////////////
+void TempDestinationAdvisoryConsumer::onMessage( const cms::Message* message ) {
 
-    <span class="code-keyword">if</span>( message-&gt;getCMSType() == <span class="code-quote">"Advisory"</span> ) {
+    if( message-&gt;getCMSType() == "Advisory" ) {
 
-        std::cout &lt;&lt; <span class="code-quote">"Received an Advisory Message!"</span> &lt;&lt; std::endl;
+        std::cout &lt;&lt; "Received an Advisory Message!" &lt;&lt; std::endl;
 
-        <span class="code-keyword">const</span> ActiveMQMessage* amqMessage =
-            dynamic_cast&lt;<span class="code-keyword">const</span> ActiveMQMessage*&gt;( message );
+        const ActiveMQMessage* amqMessage =
+            dynamic_cast&lt;const ActiveMQMessage*&gt;( message );
 
-        <span class="code-keyword">if</span>( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
-            std::cout &lt;&lt; <span class="code-quote">"Advisory Message contains a Command <span class="code-object">Object</span>!"</span> &lt;&lt; std::endl;
+        if( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
+            std::cout &lt;&lt; "Advisory Message contains a Command Object!" &lt;&lt; std::endl;
 
-            <span class="code-keyword">try</span> {
+            try {
 
                 Pointer&lt;DestinationInfo&gt; info =
                     amqMessage-&gt;getDataStructure().dynamicCast&lt;DestinationInfo&gt;();
 
-                unsigned <span class="code-object">char</span> operationType = info-&gt;getOperationType();
+                unsigned char operationType = info-&gt;getOperationType();
 
-                <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
-                    std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+                if( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
+                    std::cout &lt;&lt; "Temporary Destination {"
                               &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                              &lt;&lt; <span class="code-quote">"} Removed."</span>
+                              &lt;&lt; "} Removed."
                               &lt;&lt; std::endl;
-                } <span class="code-keyword">else</span> <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
-                    std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+                } else if( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
+                    std::cout &lt;&lt; "Temporary Destination {"
                               &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                              &lt;&lt; <span class="code-quote">"} Added."</span>
+                              &lt;&lt; "} Added."
                               &lt;&lt; std::endl;
-                } <span class="code-keyword">else</span> {
-                    std::cout &lt;&lt; <span class="code-quote">"ERROR: I have no Idea what just happened!"</span>
+                } else {
+                    std::cout &lt;&lt; "ERROR: I have no Idea what just happened!"
                               &lt;&lt; std::endl;
                 }
 
-            } <span class="code-keyword">catch</span>( ClassCastException&amp; ex ) {
-                std::cout &lt;&lt; <span class="code-quote">"ERROR: Expected the Command to be a DestinationInfo, "</span>
-                          &lt;&lt; <span class="code-quote">"it wasn't so PANIC!!"</span>
+            } catch( ClassCastException&amp; ex ) {
+                std::cout &lt;&lt; "ERROR: Expected the Command to be a DestinationInfo, "
+                          &lt;&lt; "it wasn't so PANIC!!"
                           &lt;&lt; std::endl;
             }
         }
 
-    } <span class="code-keyword">else</span> {
-        std::cout &lt;&lt; <span class="code-quote">"Received a Non-Advisory Message!"</span> &lt;&lt; std::endl;
+    } else {
+        std::cout &lt;&lt; "Received a Non-Advisory Message!" &lt;&lt; std::endl;
     }
 }
 
-</pre>
+]]></script>
 </div></div>
 
 <p>Fortunately for use the code above looks more complicated than it really is, lets walk through it a bit more slowly now to understand what is going on:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Getting to the ActiveMQMessage object</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-<span class="code-keyword">if</span>( message-&gt;getCMSType() == <span class="code-quote">"Advisory"</span> ) {
+if( message-&gt;getCMSType() == "Advisory" ) {
 
-    std::cout &lt;&lt; <span class="code-quote">"Received an Advisory Message!"</span> &lt;&lt; std::endl;
+    std::cout &lt;&lt; "Received an Advisory Message!" &lt;&lt; std::endl;
 
-    <span class="code-keyword">const</span> ActiveMQMessage* amqMessage =
-        dynamic_cast&lt;<span class="code-keyword">const</span> ActiveMQMessage*&gt;( message );
+    const ActiveMQMessage* amqMessage =
+        dynamic_cast&lt;const ActiveMQMessage*&gt;( message );
 
     ... Other scary code comes next...
 
-<span class="code-keyword">else</span> {
-    std::cout &lt;&lt; <span class="code-quote">"Received a Non-Advisory Message!"</span> &lt;&lt; std::endl;
+else {
+    std::cout &lt;&lt; "Received a Non-Advisory Message!" &lt;&lt; std::endl;
 }
-</pre>
+]]></script>
 </div></div>
 
 <p>The first thing we need to do is check that we received an advisory message, ActiveMQ encodes the Message Type as "Advisory" so that's easy enough.  We don't technically need to do this here since our consumer only listens on an advisory Topic but its not a bad idea to check.  Once we know its an advisory message we know that the message pointer should be of type ActiveMQMessage under that generic cms::Message disguise its wearing so we use a <b>dynamic_cast</b> to convert it.  Now that we've converted to an ActiveMQMessage what's next, well lets take a look:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Checking for an embedded command object</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-<span class="code-keyword">if</span>( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
-    std::cout &lt;&lt; <span class="code-quote">"Advisory Message contains a Command <span class="code-object">Object</span>!"</span> &lt;&lt; std::endl;
+if( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
+    std::cout &lt;&lt; "Advisory Message contains a Command Object!" &lt;&lt; std::endl;
 
-</pre>
+]]></script>
 </div></div>
 
 <p>Every ActiveMQMessage derived object has a method called <b>getDataStructure</b> which can be used for all sorts of useful things, here we are trying to see if there is a command object contained in this message, and you guessed it, the getDataStructure method will tell us if there is one.  If there is then we can move onto checking for a DestinationInfo object:</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>Getting to the DestinationInfo object</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-<span class="code-keyword">try</span>{
+try{
 
     Pointer&lt;DestinationInfo&gt; info =
         amqMessage-&gt;getDataStructure().dynamicCast&lt;DestinationInfo&gt;();
 
-    unsigned <span class="code-object">char</span> operationType = info-&gt;getOperationType();
+    unsigned char operationType = info-&gt;getOperationType();
 
-    <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
-        std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+    if( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
+        std::cout &lt;&lt; "Temporary Destination {"
                   &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                  &lt;&lt; <span class="code-quote">"} Removed."</span>
+                  &lt;&lt; "} Removed."
                   &lt;&lt; std::endl;
-    } <span class="code-keyword">else</span> <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
-        std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+    } else if( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
+        std::cout &lt;&lt; "Temporary Destination {"
                   &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                  &lt;&lt; <span class="code-quote">"} Added."</span>
+                  &lt;&lt; "} Added."
                   &lt;&lt; std::endl;
-     } <span class="code-keyword">else</span> {
-        std::cout &lt;&lt; <span class="code-quote">"ERROR: I have no Idea what just happened!"</span>
+     } else {
+        std::cout &lt;&lt; "ERROR: I have no Idea what just happened!"
                   &lt;&lt; std::endl;
      }
 
-} <span class="code-keyword">catch</span>( ClassCastException&amp; ex ) {
-    std::cout &lt;&lt; <span class="code-quote">"ERROR: Expected the Command to be a DestinationInfo, "</span>
-              &lt;&lt; <span class="code-quote">"it wasn't so PANIC!!"</span>
+} catch( ClassCastException&amp; ex ) {
+    std::cout &lt;&lt; "ERROR: Expected the Command to be a DestinationInfo, "
+              &lt;&lt; "it wasn't so PANIC!!"
               &lt;&lt; std::endl;
 }
 
-</pre>
+]]></script>
 </div></div>
 
 <p>First thing you are probably asking about this code snippet is "what is that Pointer thing?", that is a thread safe smart pointer that is used internally by ActiveMQ-CPP to manage all the pointers that make up the cms::Message objects among other things.  We create an instance of a Pointer&lt;DestinationInfo&gt; type which will pointer to our DestinationInfo command if the dynamicCast method is able to make that conversion, if not a ClassCastException is thrown.  Once we have the DestinationInfo pointer we can retrieve the Operation Type of the command and then compare it to the constants in ActiveMQConstants to see what is being done to the Destination.  There are only two operation types, add and remove, but since the DestinationInfo object encodes the operation type value as an unsigned char we provide a fall-back case to alert us to that error.  We are almost done now, all that remains is to output what happened, and also let the user know what the name of the Destination is,
  the <b>getPhysicalName</b> method in the Destination class tells us that.  You could also find out whether the Destination is a Topic or a Queue using the Destination object, we leave that as an exercise to the reader.</p>
@@ -466,7 +466,7 @@ consumer-&gt;setMessageListener( <span c
 <p>The complete code of our client application is shown below, you can also find this code as well as a simple client that creates both a Temporary Topic and a Temporary Queue in the examples folder in the source distribution.</p>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>TempDestinationAdvisoryConsumer Header File</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
 #ifndef _ACTIVEMQCPP_EXAMPLES_ADVISORIES_TEMPDESTINATIONADVISORYCONSUMER_H_
 #define _ACTIVEMQCPP_EXAMPLES_ADVISORIES_TEMPDESTINATIONADVISORYCONSUMER_H_
@@ -479,24 +479,24 @@ consumer-&gt;setMessageListener( <span c
 #include &lt;cms/MessageConsumer.h&gt;
 #include &lt;cms/MessageListener.h&gt;
 
-#include &lt;decaf/lang/<span class="code-object">Runnable</span>.h&gt;
+#include &lt;decaf/lang/Runnable.h&gt;
 
 namespace activemqcpp {
 namespace examples {
 namespace advisories {
 
     /**
-     * Monitors a Broker <span class="code-keyword">for</span> Temporary Topic creation and destruction.
+     * Monitors a Broker for Temporary Topic creation and destruction.
      *
      * @since 3.0
      */
-    class TempDestinationAdvisoryConsumer : <span class="code-keyword">public</span> cms::MessageListener {
-    <span class="code-keyword">private</span>:
+    class TempDestinationAdvisoryConsumer : public cms::MessageListener {
+    private:
 
         cms::Session* session;
         std::auto_ptr&lt;cms::MessageConsumer&gt; consumer;
 
-    <span class="code-keyword">public</span>:
+    public:
 
         TempDestinationAdvisoryConsumer( cms::Session* session );
         virtual ~TempDestinationAdvisoryConsumer();
@@ -504,7 +504,7 @@ namespace advisories {
         /**
          * Async Message callback.
          */
-        virtual void onMessage( <span class="code-keyword">const</span> cms::Message* message );
+        virtual void onMessage( const cms::Message* message );
 
     };
 
@@ -512,13 +512,13 @@ namespace advisories {
 
 #endif /* _ACTIVEMQCPP_EXAMPLES_ADVISORIES_TEMPDESTINATIONADVISORYCONSUMER_H_ */
 
-</pre>
+]]></script>
 </div></div>
 
 <div class="code panel" style="border-width: 1px;"><div class="codeHeader panelHeader" style="border-bottom-width: 1px;"><b>TempDestinationAdvisoryConsumer Source File</b></div><div class="codeContent panelContent">
-<pre class="code-java">
+<script class="theme: Default; brush: java; gutter: false" type="syntaxhighlighter"><![CDATA[
 
-#include <span class="code-quote">"TempDestinationAdvisoryConsumer.h"</span>
+#include "TempDestinationAdvisoryConsumer.h"
 
 #include &lt;cms/Topic.h&gt;
 #include &lt;cms/Message.h&gt;
@@ -528,7 +528,7 @@ namespace advisories {
 #include &lt;activemq/commands/DestinationInfo.h&gt;
 #include &lt;decaf/lang/exceptions/NullPointerException.h&gt;
 #include &lt;decaf/lang/exceptions/ClassCastException.h&gt;
-#include &lt;decaf/lang/<span class="code-object">Integer</span>.h&gt;
+#include &lt;decaf/lang/Integer.h&gt;
 
 using namespace std;
 using namespace activemqcpp;
@@ -541,74 +541,74 @@ using namespace decaf;
 using namespace decaf::lang;
 using namespace decaf::lang::exceptions;
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>TempDestinationAdvisoryConsumer::TempDestinationAdvisoryConsumer( cms::Session* session ) {
+////////////////////////////////////////////////////////////////////////////////
+TempDestinationAdvisoryConsumer::TempDestinationAdvisoryConsumer( cms::Session* session ) {
 
-    <span class="code-keyword">if</span>( session == NULL ) {
-        <span class="code-keyword">throw</span> NullPointerException(
-            __FILE__, __LINE__, <span class="code-quote">"Session <span class="code-object">Object</span> passed was Null."</span> );
+    if( session == NULL ) {
+        throw NullPointerException(
+            __FILE__, __LINE__, "Session Object passed was Null." );
     }
 
     std::auto_ptr&lt;cms::Topic&gt; advisories( session-&gt;createTopic(
-        <span class="code-quote">"ActiveMQ.Advisory.TempTopic,ActiveMQ.Advisory.TempQueue"</span> ) );
+        "ActiveMQ.Advisory.TempTopic,ActiveMQ.Advisory.TempQueue" ) );
 
-    <span class="code-keyword">this</span>-&gt;session = session;
-    <span class="code-keyword">this</span>-&gt;consumer.reset( session-&gt;createConsumer( advisories.get() ) );
-    <span class="code-keyword">this</span>-&gt;consumer-&gt;setMessageListener( <span class="code-keyword">this</span> );
+    this-&gt;session = session;
+    this-&gt;consumer.reset( session-&gt;createConsumer( advisories.get() ) );
+    this-&gt;consumer-&gt;setMessageListener( this );
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>TempDestinationAdvisoryConsumer::~TempDestinationAdvisoryConsumer() {
+////////////////////////////////////////////////////////////////////////////////
+TempDestinationAdvisoryConsumer::~TempDestinationAdvisoryConsumer() {
 }
 
-<span class="code-comment">////////////////////////////////////////////////////////////////////////////////
-</span>void TempDestinationAdvisoryConsumer::onMessage( <span class="code-keyword">const</span> cms::Message* message ) {
+////////////////////////////////////////////////////////////////////////////////
+void TempDestinationAdvisoryConsumer::onMessage( const cms::Message* message ) {
 
-    <span class="code-keyword">if</span>( message-&gt;getCMSType() == <span class="code-quote">"Advisory"</span> ) {
+    if( message-&gt;getCMSType() == "Advisory" ) {
 
-        std::cout &lt;&lt; <span class="code-quote">"Received an Advisory Message!"</span> &lt;&lt; std::endl;
+        std::cout &lt;&lt; "Received an Advisory Message!" &lt;&lt; std::endl;
 
-        <span class="code-keyword">const</span> ActiveMQMessage* amqMessage =
-            dynamic_cast&lt;<span class="code-keyword">const</span> ActiveMQMessage*&gt;( message );
+        const ActiveMQMessage* amqMessage =
+            dynamic_cast&lt;const ActiveMQMessage*&gt;( message );
 
-        <span class="code-keyword">if</span>( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
-            std::cout &lt;&lt; <span class="code-quote">"Advisory Message contains a Command <span class="code-object">Object</span>!"</span> &lt;&lt; std::endl;
+        if( amqMessage != NULL &amp;&amp; amqMessage-&gt;getDataStructure() != NULL ) {
+            std::cout &lt;&lt; "Advisory Message contains a Command Object!" &lt;&lt; std::endl;
 
-            <span class="code-keyword">try</span> {
+            try {
 
                 Pointer&lt;DestinationInfo&gt; info =
                     amqMessage-&gt;getDataStructure().dynamicCast&lt;DestinationInfo&gt;();
 
-                unsigned <span class="code-object">char</span> operationType = info-&gt;getOperationType();
+                unsigned char operationType = info-&gt;getOperationType();
 
-                <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
-                    std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+                if( operationType == ActiveMQConstants::DESTINATION_REMOVE_OPERATION ) {
+                    std::cout &lt;&lt; "Temporary Destination {"
                               &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                              &lt;&lt; <span class="code-quote">"} Removed."</span>
+                              &lt;&lt; "} Removed."
                               &lt;&lt; std::endl;
-                } <span class="code-keyword">else</span> <span class="code-keyword">if</span>( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
-                    std::cout &lt;&lt; <span class="code-quote">"Temporary Destination {"</span>
+                } else if( operationType == ActiveMQConstants::DESTINATION_ADD_OPERATION ) {
+                    std::cout &lt;&lt; "Temporary Destination {"
                               &lt;&lt; info-&gt;getDestination()-&gt;getPhysicalName()
-                              &lt;&lt; <span class="code-quote">"} Added."</span>
+                              &lt;&lt; "} Added."
                               &lt;&lt; std::endl;
-                } <span class="code-keyword">else</span> {
-                    std::cout &lt;&lt; <span class="code-quote">"ERROR: I have no Idea what just happened!"</span>
+                } else {
+                    std::cout &lt;&lt; "ERROR: I have no Idea what just happened!"
                               &lt;&lt; std::endl;
                 }
 
-            } <span class="code-keyword">catch</span>( ClassCastException&amp; ex ) {
-                std::cout &lt;&lt; <span class="code-quote">"ERROR: Expected the Command to be a DestinationInfo, "</span>
-                          &lt;&lt; <span class="code-quote">"it wasn't so PANIC!!"</span>
+            } catch( ClassCastException&amp; ex ) {
+                std::cout &lt;&lt; "ERROR: Expected the Command to be a DestinationInfo, "
+                          &lt;&lt; "it wasn't so PANIC!!"
                           &lt;&lt; std::endl;
             }
         }
 
-    } <span class="code-keyword">else</span> {
-        std::cout &lt;&lt; <span class="code-quote">"Received a Non-Advisory Message!"</span> &lt;&lt; std::endl;
+    } else {
+        std::cout &lt;&lt; "Received a Non-Advisory Message!" &lt;&lt; std::endl;
     }
 }
 
-</pre>
+]]></script>
 </div></div>
           </div>
         </td>
@@ -633,8 +633,8 @@ using namespace decaf::lang::exceptions;
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/how-do-i-prevent-autoconf-from-enabling-openssl-support.html
==============================================================================
--- websites/production/activemq/content/cms/how-do-i-prevent-autoconf-from-enabling-openssl-support.html (original)
+++ websites/production/activemq/content/cms/how-do-i-prevent-autoconf-from-enabling-openssl-support.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -101,8 +101,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/how-do-i-use-the-ssl-transport.html
==============================================================================
--- websites/production/activemq/content/cms/how-do-i-use-the-ssl-transport.html (original)
+++ websites/production/activemq/content/cms/how-do-i-use-the-ssl-transport.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -127,8 +127,8 @@ decaf::lang::System::setProperty( "decaf
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/how-to-enable-ssl-support-on-windows.html
==============================================================================
--- websites/production/activemq/content/cms/how-to-enable-ssl-support-on-windows.html (original)
+++ websites/production/activemq/content/cms/how-to-enable-ssl-support-on-windows.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -96,8 +96,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/index.html
==============================================================================
--- websites/production/activemq/content/cms/index.html (original)
+++ websites/production/activemq/content/cms/index.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -193,8 +193,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/mailing-lists.html
==============================================================================
--- websites/production/activemq/content/cms/mailing-lists.html (original)
+++ websites/production/activemq/content/cms/mailing-lists.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -107,8 +107,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/navigation.html
==============================================================================
--- websites/production/activemq/content/cms/navigation.html (original)
+++ websites/production/activemq/content/cms/navigation.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -89,8 +89,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">
@@ -135,8 +135,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/news.html
==============================================================================
--- websites/production/activemq/content/cms/news.html (original)
+++ websites/production/activemq/content/cms/news.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -300,8 +300,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/openssl-support.html
==============================================================================
--- websites/production/activemq/content/cms/openssl-support.html (original)
+++ websites/production/activemq/content/cms/openssl-support.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -97,8 +97,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">

Modified: websites/production/activemq/content/cms/openwire-support.html
==============================================================================
--- websites/production/activemq/content/cms/openwire-support.html (original)
+++ websites/production/activemq/content/cms/openwire-support.html Mon Jul  8 14:21:28 2013
@@ -50,8 +50,8 @@
       <div>
 
 <!-- Banner -->
-
-	<div id="asf_logo">
+<p>
+	</p><div id="asf_logo">
 	<div id="activemq_logo">
             <a shape="rect" style="float:left; width:280px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:10px; margin-left:100px;" href="http://activemq.apache.org/">ActiveMQ</a>
             <a shape="rect" style="float:right; width:210px;display:block;text-indent:-5000px;text-decoration:none;line-height:60px; margin-top:15px; margin-right:10px;" href="http://www.apache.org">ASF</a>
@@ -100,8 +100,8 @@
 
 <h3><a shape="rect" name="Navigation-Search"></a>Search</h3>
 
-
-<div>
+<p>
+</p><div>
 <form enctype="application/x-www-form-urlencoded" method="get" action="http://www.google.com/search" style="font-size: 10px;">
 <input type="hidden" name="ie" value="UTF-8">
 <input type="hidden" name="oe" value="UTF-8">