You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@qpid.apache.org by ro...@apache.org on 2016/12/14 19:51:25 UTC

[13/51] [partial] qpid-site git commit: QPID-7584: update site for qpid-cpp 1.36.0

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/54b18507/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s02.html.in
----------------------------------------------------------------------
diff --git a/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s02.html.in b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s02.html.in
new file mode 100644
index 0000000..a1dee4a
--- /dev/null
+++ b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s02.html.in
@@ -0,0 +1,143 @@
+<div class="docbook"><div class="navheader"><table summary="Navigation header" width="100%"><tr><th align="center" colspan="3">1.2.&#160;
+      Cheat Sheet for configuring Queue Options
+    </th></tr><tr><td align="left" width="20%"><a accesskey="p" href="ch01.html">Prev</a>&#160;</td><th align="center" width="60%">Chapter&#160;1.&#160;
+      Running the AMQP Messaging Broker
+    </th><td align="right" width="20%">&#160;<a accesskey="n" href="ch01s03.html">Next</a></td></tr></table><hr /></div><div class="section"><div class="titlepage"><div><div><h2 class="title"><a id="idm221087493056"></a>1.2.&#160;
+      Cheat Sheet for configuring Queue Options
+    </h2></div></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="CheatSheetforconfiguringQueueOptions-ConfiguringQueueOptions"></a>1.2.1.&#160;
+            Configuring
+            Queue Options
+          </h3></div></div></div><p>
+            The C++ Broker M4 or later supports the following additional
+            Queue constraints.
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>
+                <a class="xref" href="ch01s02.html#CheatSheetforconfiguringQueueOptions-ConfiguringQueueOptions" title="1.2.1.&#160; Configuring Queue Options">Section&#160;1.2.1, &#8220;
+            Configuring
+            Queue Options
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                </p><div class="itemizedlist"><ul class="itemizedlist" type="circle"><li class="listitem"><p>
+                    <a class="xref" href="ch01s02.html#CheatSheetforconfiguringQueueOptions-ApplyingQueueSizingConstraints" title="1.2.1.1.&#160; Applying Queue Sizing Constraints">Section&#160;1.2.1.1, &#8220;
+            Applying Queue Sizing Constraints
+          &#8221;</a>
+                  </p></li><li class="listitem"><p>
+                    <a class="xref" href="ch01s02.html#CheatSheetforconfiguringQueueOptions-ChangingtheQueueorderingBehaviors-28FIFO-2FLVQ-29" title="1.2.1.2.&#160; Changing the Queue ordering Behaviors (FIFO/LVQ)">Section&#160;1.2.1.2, &#8220;
+            Changing the Queue ordering Behaviors (FIFO/LVQ)
+          &#8221;</a>
+                  </p></li><li class="listitem"><p>
+                    <a class="xref" href="ch01s02.html#CheatSheetforconfiguringQueueOptions-Settingadditionalbehaviors" title="1.2.1.3.&#160; Setting additional behaviors">Section&#160;1.2.1.3, &#8220;
+            Setting additional behaviors
+          &#8221;</a>
+                  </p></li><li class="listitem"><p>
+                    </p><div class="itemizedlist"><ul class="itemizedlist" type="square"><li class="listitem"><p>
+                        <a class="xref" href="">???</a>
+                      </p></li></ul></div><p>
+                  </p></li><li class="listitem"><p>
+                    <a class="xref" href="ch01s02.html#CheatSheetforconfiguringQueueOptions-OtherClients" title="1.2.1.4.&#160; Other Clients">Section&#160;1.2.1.4, &#8220;
+            Other
+            Clients
+          &#8221;</a>
+                  </p></li></ul></div><p>
+              </p></li></ul></div><p>
+            The 0.10 C++ Broker supports the following additional Queue configuration options:
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>
+              <a class="xref" href="producer-flow-control.html" title="1.8.&#160; Producer Flow Control">Section&#160;1.8, &#8220;
+    Producer Flow Control
+  &#8221;</a>
+            </p></li></ul></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringQueueOptions-ApplyingQueueSizingConstraints"></a>1.2.1.1.&#160;
+            Applying Queue Sizing Constraints
+          </h4></div></div></div><p>
+            This allows to specify how to size a queue and what to do when
+            the sizing constraints have been reached. The queue size can be
+            limited by the number messages (message depth) or byte depth on
+            the queue.
+          </p><p>
+            Once the Queue meets/ exceeds these constraints the follow
+            policies can be applied
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>REJECT - Reject the published message
+            </p></li><li class="listitem"><p>FLOW_TO_DISK - Flow the messages to disk, to preserve memory
+            </p></li><li class="listitem"><p>RING - start overwriting messages in a ring based on sizing.
+            If head meets tail, advance head
+            </p></li><li class="listitem"><p>RING_STRICT - start overwriting messages in a ring based on
+            sizing. If head meets tail, AND the consumer has the tail message
+            acquired it will reject
+            </p></li></ul></div><p>
+            Examples:
+          </p><p>
+            Create a queue an auto delete queue that will support 100 000
+            bytes, and then REJECT
+          </p><pre class="programlisting">
+#include "qpid/client/QueueOptions.h"
+
+    QueueOptions qo;
+    qo.setSizePolicy(REJECT,100000,0);
+
+    session.queueDeclare(arg::queue=queue, arg::autoDelete=true, arg::arguments=qo);
+</pre><p>
+            Create a queue that will support 1000 messages into a RING buffer
+          </p><pre class="programlisting">
+#include "qpid/client/QueueOptions.h"
+
+    QueueOptions qo;
+    qo.setSizePolicy(RING,0,1000);
+
+    session.queueDeclare(arg::queue=queue, arg::arguments=qo);
+</pre></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringQueueOptions-ChangingtheQueueorderingBehaviors-28FIFO-2FLVQ-29"></a>1.2.1.2.&#160;
+            Changing the Queue ordering Behaviors (FIFO/LVQ)
+          </h4></div></div></div><p>
+            The default ordering in a queue in Qpid is FIFO. However
+            additional ordering semantics can be used namely LVQ (Last Value
+            Queue). Last Value Queue is define as follows.
+          </p><p>
+            If I publish symbols RHT, IBM, JAVA, MSFT, and then publish RHT
+            before the consumer is able to consume RHT, that message will be
+            over written in the queue and the consumer will receive the last
+            published value for RHT.
+          </p><p>
+            Example:
+          </p><pre class="programlisting">
+#include "qpid/client/QueueOptions.h"
+
+    QueueOptions qo;
+    qo.setOrdering(LVQ);
+
+    session.queueDeclare(arg::queue=queue, arg::arguments=qo);
+
+    .....
+    string key;
+    qo.getLVQKey(key);
+
+    ....
+    for each message, set the into application headers before transfer
+    message.getHeaders().setString(key,"RHT");
+    
+</pre><p>
+            Notes:
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>Messages that are dequeued and the re-queued will have the
+            following exceptions. a.) if a new message has been queued with
+            the same key, the re-queue from the consumer, will combine these
+            two messages. b.) If an update happens for a message of the same
+            key, after the re-queue, it will not update the re-queued
+            message. This is done to protect a client from being able to
+            adversely manipulate the queue.
+            </p></li><li class="listitem"><p>Acquire: When a message is acquired from the queue, no matter
+            it's position, it will behave the same as a dequeue
+            </p></li><li class="listitem"><p>LVQ does not support durable messages. If the queue or
+            messages are declared durable on an LVQ, the durability will be
+            ignored.
+            </p></li></ul></div><p>
+            A fully worked <a class="xref" href="ch01s06.html#LVQ-Example" title="1.6.3.&#160;LVQ Example">Section&#160;1.6.3, &#8220;LVQ Example&#8221;</a> can be found here
+          </p></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringQueueOptions-Settingadditionalbehaviors"></a>1.2.1.3.&#160;
+            Setting additional behaviors
+          </h4></div></div></div></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringQueueOptions-OtherClients"></a>1.2.1.4.&#160;
+            Other
+            Clients
+          </h4></div></div></div><p>
+            Note that these options can be set from any client. QueueOptions
+            just correctly formats the arguments passed to the QueueDeclare()
+            method.
+          </p></div></div></div><div class="navfooter"><hr /><table summary="Navigation footer" width="100%"><tr><td align="left" width="40%"><a accesskey="p" href="ch01.html">Prev</a>&#160;</td><td align="center" width="20%"><a accesskey="u" href="ch01.html">Up</a></td><td align="right" width="40%">&#160;<a accesskey="n" href="ch01s03.html">Next</a></td></tr><tr><td align="left" valign="top" width="40%">Chapter&#160;1.&#160;
+      Running the AMQP Messaging Broker
+    &#160;</td><td align="center" width="20%"><a accesskey="h" href="index.html">Home</a></td><td align="right" valign="top" width="40%">&#160;1.3.&#160;
+    Cheat Sheet for configuring Exchange Options
+  </td></tr></table></div></div>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/54b18507/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s03.html.in
----------------------------------------------------------------------
diff --git a/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s03.html.in b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s03.html.in
new file mode 100644
index 0000000..9ca137d
--- /dev/null
+++ b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s03.html.in
@@ -0,0 +1,98 @@
+<div class="docbook"><div class="navheader"><table summary="Navigation header" width="100%"><tr><th align="center" colspan="3">1.3.&#160;
+    Cheat Sheet for configuring Exchange Options
+  </th></tr><tr><td align="left" width="20%"><a accesskey="p" href="ch01s02.html">Prev</a>&#160;</td><th align="center" width="60%">Chapter&#160;1.&#160;
+      Running the AMQP Messaging Broker
+    </th><td align="right" width="20%">&#160;<a accesskey="n" href="chap-Messaging_User_Guide-Broker_Federation.html">Next</a></td></tr></table><hr /></div><div class="section"><div class="titlepage"><div><div><h2 class="title"><a id="idm221087479088"></a>1.3.&#160;
+    Cheat Sheet for configuring Exchange Options
+  </h2></div></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="CheatSheetforconfiguringExchangeOptions-ConfiguringExchangeOptions"></a>1.3.1.&#160;
+      Configuring Exchange Options
+    </h3></div></div></div><p>
+            The C++ Broker M4 or later supports the following additional
+            Exchange options in addition to the standard AMQP define options
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>Exchange Level Message sequencing
+            </p></li><li class="listitem"><p>Initial Value Exchange
+            </p></li></ul></div><p>
+            Note that these features can be used on any exchange type, that
+            has been declared with the options set.
+          </p><p>
+            It also supports an additional option to the bind operation on a
+            direct exchange
+          </p><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>Exclusive binding for key
+            </p></li></ul></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringExchangeOptions-ExchangeLevelMessagesequencing"></a>1.3.1.1.&#160;
+            Exchange Level Message sequencing
+          </h4></div></div></div><p>
+            This feature can be used to place a sequence number into each
+            message's headers, based on the order they pass through an
+            exchange. The sequencing starts at 0 and then wraps in an AMQP
+            int64 type.
+          </p><p>
+            The field name used is "qpid.msg_sequence"
+          </p><p>
+            To use this feature an exchange needs to be declared specifying
+            this option in the declare
+          </p><pre class="programlisting">
+....
+    FieldTable args;
+    args.setInt("qpid.msg_sequence",1);
+
+...
+    // now declare the exchange
+    session.exchangeDeclare(arg::exchange="direct", arg::arguments=args);
+</pre><p>
+            Then each message passing through that exchange will be numbers
+            in the application headers.
+          </p><pre class="programlisting">
+    unit64_t seqNo;
+    //after message transfer
+    seqNo = message.getHeaders().getAsInt64("qpid.msg_sequence");
+</pre></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringExchangeOptions-InitialValueExchange"></a>1.3.1.2.&#160;
+            Initial
+            Value Exchange
+          </h4></div></div></div><p>
+            This feature caches a last message sent to an exchange. When a
+            new binding is created onto the exchange it will then attempt to
+            route this cached messaged to the queue, based on the binding.
+            This allows for topics or the creation of configurations where a
+            new consumer can receive the last message sent to the broker,
+            with matching routing.
+          </p><p>
+            To use this feature an exchange needs to be declared specifying
+            this option in the declare
+          </p><pre class="programlisting">
+....
+    FieldTable args;
+    args.setInt("qpid.ive",1);
+
+...
+    // now declare the exchange
+    session.exchangeDeclare(arg::exchange="direct", arg::arguments=args);
+</pre><p>
+            now use the exchange in the same way you would use any other
+            exchange.
+          </p></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="CheatSheetforconfiguringExchangeOptions-Exclusivebindingforkey"></a>1.3.1.3.&#160;
+            Exclusive
+            binding for key
+          </h4></div></div></div><p>
+            Direct exchanges in qpidd support a qpid.exclusive-binding option
+            on the bind operation that causes the binding specified to be the
+            only one for the given key. I.e. if there is already a binding at
+            this exchange with this key it will be atomically updated to bind
+            the new queue. This means that the binding can be changed
+            concurrently with an incoming stream of messages and each message
+            will be routed to exactly one queue.
+          </p><pre class="programlisting">
+....
+    FieldTable args;
+    args.setInt("qpid.exclusive-binding",1);
+
+    //the following will cause the only binding from amq.direct with 'my-key' 
+    //to be the one to 'my-queue'; if there were any previous bindings for that
+    //key they will be removed. This is atomic w.r.t message routing through the
+    //exchange.
+    session.exchangeBind(arg::exchange="amq.direct", arg::queue="my-queue",
+                         arg::bindingKey="my-key", arg::arguments=args);
+
+...
+</pre></div></div></div><div class="navfooter"><hr /><table summary="Navigation footer" width="100%"><tr><td align="left" width="40%"><a accesskey="p" href="ch01s02.html">Prev</a>&#160;</td><td align="center" width="20%"><a accesskey="u" href="ch01.html">Up</a></td><td align="right" width="40%">&#160;<a accesskey="n" href="chap-Messaging_User_Guide-Broker_Federation.html">Next</a></td></tr><tr><td align="left" valign="top" width="40%">1.2.&#160;
+      Cheat Sheet for configuring Queue Options
+    &#160;</td><td align="center" width="20%"><a accesskey="h" href="index.html">Home</a></td><td align="right" valign="top" width="40%">&#160;1.4.&#160;Broker Federation</td></tr></table></div></div>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/54b18507/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s06.html.in
----------------------------------------------------------------------
diff --git a/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s06.html.in b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s06.html.in
new file mode 100644
index 0000000..abf37c2
--- /dev/null
+++ b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch01s06.html.in
@@ -0,0 +1,107 @@
+<div class="docbook"><div class="navheader"><table summary="Navigation header" width="100%"><tr><th align="center" colspan="3">1.6.&#160;LVQ - Last Value Queue</th></tr><tr><td align="left" width="20%"><a accesskey="p" href="chap-Messaging_User_Guide-Security.html">Prev</a>&#160;</td><th align="center" width="60%">Chapter&#160;1.&#160;
+      Running the AMQP Messaging Broker
+    </th><td align="right" width="20%">&#160;<a accesskey="n" href="queue-state-replication.html">Next</a></td></tr></table><hr /></div><div class="section"><div class="titlepage"><div><div><h2 class="title"><a id="idm221081927264"></a>1.6.&#160;LVQ - Last Value Queue</h2></div></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="LVQ-UnderstandingLVQ"></a>1.6.1.&#160;Understanding LVQ</h3></div></div></div><p>
+      A Last Value Queue is configured with the name of a message header that
+      is used as a key.  The queue behaves as a normal FIFO queue with the
+      exception that when a message is enqueued, any other message in the
+      queue with the same value in the key header is removed and discarded.
+      Thus, for any given key value, the queue holds only the most recent
+      message.
+    </p><p>
+      The following example illustrates the operation of a Last Value Queue.
+      The example shows an empty queue with no consumers and a sequence of
+      produced messages.  The numbers represent the key for each message.
+    </p><pre class="programlisting">
+           &lt;empty queue&gt;
+      1 =&gt;
+           1
+      2 =&gt;
+           1 2
+      3 =&gt;
+           1 2 3
+      4 =&gt;
+           1 2 3 4
+      2 =&gt;
+           1 3 4 2
+      1 =&gt;
+           3 4 2 1
+    </pre><p>
+      Note that the first four messages are enqueued normally in FIFO order.
+      The fifth message has key '2' and is also enqueued on the tail of the
+      queue.  However the message already in the queue with the same key is
+      discarded.
+      </p><div class="note" style="margin-left: 0.5in; margin-right: 0.5in;"><h3 class="title">Note</h3><p>
+          If the set of keys used in the messages in a LVQ is constrained, the
+          number of messages in the queue shall not exceed the number of
+          distinct keys in use.
+        </p></div><p>
+    </p><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="LVQ-UnderstandingLVQ-UseCases"></a>1.6.1.1.&#160;Common Use-Cases</h4></div></div></div><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>
+            LVQ with zero or one consuming subscriptions - In this case, if
+            the consumer drops momentarily or is slower than the producer(s),
+            it will only receive current information relative to the message
+            keys.
+          </p></li><li class="listitem"><p>
+            LVQ with zero or more browsing subscriptions - A browsing consumer
+            can subscribe to the LVQ and get an immediate dump of all of the
+            "current" messages and track updates thereafter.  Any number of
+            independent browsers can subscribe to the same LVQ with the same
+            effect.  Since messages are never consumed, they only disappear
+            when replaced with a newer message with the same key or when their
+            TTL expires.
+          </p></li></ul></div></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="LVQ-Creating"></a>1.6.2.&#160;Creating a Last Value Queue</h3></div></div></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="LVQ-Creating-Address"></a>1.6.2.1.&#160;Using Addressing Syntax</h4></div></div></div><p>
+        A LVQ may be created using directives in the API's address syntax.
+        The important argument is "qpid.last_value_queue_key".  The following
+        Python example shows how a producer of stock price updates can create
+        a LVQ to hold the latest stock prices for each ticker symbol.  The
+        message header used to hold the ticker symbol is called "ticker".
+      </p><pre class="programlisting">
+    conn = Connection(url)
+    conn.open()
+    sess = conn.session()
+    tx = sess.sender("prices;{create:always, node:{type:queue, x-declare:{arguments:{'qpid.last_value_queue_key':'ticker'}}}}")
+      </pre></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="LVQ-Creating-Tool"></a>1.6.2.2.&#160;Using qpid-config</h4></div></div></div><p>
+        The same LVQ as shown in the previous example can be created using the
+        qpid-config utility:
+      </p><pre class="programlisting">
+    $ qpid-config add queue prices --lvq-key ticker
+      </pre></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="LVQ-Example"></a>1.6.3.&#160;LVQ Example</h3></div></div></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="LVQ-Example-Sender"></a>1.6.3.1.&#160;LVQ Sender</h4></div></div></div><pre class="programlisting">
+    from qpid.messaging import Connection, Message
+
+    def send(sender, key, message):
+      message.properties["ticker"] = key
+      sender.send(message)
+
+    conn = Connection("localhost")
+    conn.open()
+    sess = conn.session()
+    tx = sess.sender("prices;{create:always, node:{type:queue,x-declare:{arguments:{'qpid.last_value_queue_key':ticker}}}}")
+
+    msg = Message("Content")
+    send(tx, "key1", msg);
+    send(tx, "key2", msg);
+    send(tx, "key3", msg);
+    send(tx, "key4", msg);
+    send(tx, "key2", msg);
+    send(tx, "key1", msg);
+
+    conn.close()
+      </pre></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="LVQ-Example-Receiver"></a>1.6.3.2.&#160;LVQ Browsing Receiver</h4></div></div></div><pre class="programlisting">
+    from qpid.messaging import Connection, Message
+
+    conn = Connection("localhost")
+    conn.open()
+    sess = conn.session()
+    rx = sess.receiver("prices;{mode:browse}")
+
+    while True:
+      msg = rx.fetch()
+      sess.acknowledge()
+      print msg
+      </pre></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="LVQ-Deprecated"></a>1.6.4.&#160;Deprecated LVQ Modes</h3></div></div></div><p>
+      There are two legacy modes (still implemented as of Qpid 0.14)
+      controlled by the qpid.last_value_queue and
+      qpid.last_value_queue_no_browse argument values.  These modes are
+      deprecated and should not be used.
+    </p></div></div><div class="navfooter"><hr /><table summary="Navigation footer" width="100%"><tr><td align="left" width="40%"><a accesskey="p" href="chap-Messaging_User_Guide-Security.html">Prev</a>&#160;</td><td align="center" width="20%"><a accesskey="u" href="ch01.html">Up</a></td><td align="right" width="40%">&#160;<a accesskey="n" href="queue-state-replication.html">Next</a></td></tr><tr><td align="left" valign="top" width="40%">1.5.&#160;Security&#160;</td><td align="center" width="20%"><a accesskey="h" href="index.html">Home</a></td><td align="right" valign="top" width="40%">&#160;1.7.&#160;
+    Queue State Replication
+  </td></tr></table></div></div>
\ No newline at end of file

http://git-wip-us.apache.org/repos/asf/qpid-site/blob/54b18507/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch02s02.html.in
----------------------------------------------------------------------
diff --git a/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch02s02.html.in b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch02s02.html.in
new file mode 100644
index 0000000..bc7d731
--- /dev/null
+++ b/input/releases/qpid-cpp-1.36.0/cpp-broker/book/ch02s02.html.in
@@ -0,0 +1,586 @@
+<div class="docbook"><div class="navheader"><table summary="Navigation header" width="100%"><tr><th align="center" colspan="3">2.2.&#160;
+      Qpid Management Framework
+    </th></tr><tr><td align="left" width="20%"><a accesskey="p" href="chapter-Managing-CPP-Broker.html">Prev</a>&#160;</td><th align="center" width="60%">Chapter&#160;2.&#160;
+      Managing the AMQP Messaging Broker
+    </th><td align="right" width="20%">&#160;<a accesskey="n" href="ch02s03.html">Next</a></td></tr></table><hr /></div><div class="section"><div class="titlepage"><div><div><h2 class="title"><a id="idm221086643040"></a>2.2.&#160;
+      Qpid Management Framework
+    </h2></div></div></div><div class="itemizedlist"><ul class="itemizedlist" type="disc"><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-WhatIsQMF" title="2.2.1.&#160; What Is QMF">Section&#160;2.2.1, &#8220;
+            What Is QMF
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-GettingStartedwithQMF" title="2.2.2.&#160; Getting Started with QMF">Section&#160;2.2.2, &#8220;
+            Getting
+            Started with QMF
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-QMFConcepts" title="2.2.3.&#160; QMF Concepts">Section&#160;2.2.3, &#8220;
+            QMF Concepts
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                </p><div class="itemizedlist"><ul class="itemizedlist" type="circle"><li class="listitem"><p>
+                    <a class="xref" href="ch02s02.html#QpidManagementFramework-Console-2CAgent-2CandBroker" title="2.2.3.1.&#160; Console, Agent, and Broker">Section&#160;2.2.3.1, &#8220;
+            Console,
+            Agent, and Broker
+          &#8221;</a>
+                  </p></li><li class="listitem"><p>
+                    <a class="xref" href="ch02s02.html#QpidManagementFramework-Schema" title="2.2.3.2.&#160; Schema">Section&#160;2.2.3.2, &#8220;
+            Schema
+          &#8221;</a>
+                  </p></li><li class="listitem"><p>
+                    <a class="xref" href="ch02s02.html#QpidManagementFramework-ClassKeysandClassVersioning" title="2.2.3.3.&#160; Class Keys and Class Versioning">Section&#160;2.2.3.3, &#8220;
+            Class
+            Keys and Class Versioning
+          &#8221;</a>
+                  </p></li></ul></div><p>
+              </p></li><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-TheQMFProtocol" title="2.2.4.&#160; The QMF Protocol">Section&#160;2.2.4, &#8220;
+            The QMF
+            Protocol
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-HowtoWriteaQMFConsole" title="2.2.5.&#160; How to Write a QMF Console">Section&#160;2.2.5, &#8220;
+            How
+            to Write a QMF Console
+          &#8221;</a>
+              </p></li><li class="listitem"><p>
+                <a class="xref" href="ch02s02.html#QpidManagementFramework-HowtoWriteaQMFAgent" title="2.2.6.&#160; How to Write a QMF Agent">Section&#160;2.2.6, &#8220;
+            How to
+            Write a QMF Agent
+          &#8221;</a>
+              </p></li></ul></div><p>
+              Please visit the <a class="xref" href="">???</a> for information
+              about the future of QMF.
+            </p><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-WhatIsQMF"></a>2.2.1.&#160;
+            What Is QMF
+          </h3></div></div></div><p>
+            QMF (Qpid Management Framework) is a general-purpose management
+            bus built on Qpid Messaging. It takes advantage of the
+            scalability, security, and rich capabilities of Qpid to provide
+            flexible and easy-to-use manageability to a large set of
+            applications.
+          </p></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-GettingStartedwithQMF"></a>2.2.2.&#160;
+            Getting
+            Started with QMF
+          </h3></div></div></div><p>
+            QMF is used through two primary APIs. The <span class="emphasis"><em>console</em></span> API is
+            used for console applications that wish to access and manipulate
+            manageable components through QMF. The <span class="emphasis"><em>agent</em></span> API is used
+            for application that wish to be managed through QMF.
+          </p><p>
+            The fastest way to get started with QMF is to work through the
+            "How To" tutorials for consoles and agents. For a deeper
+            understanding of what is happening in the tutorials, it is
+            recommended that you look at the <span class="emphasis"><em>Qmf Concepts</em></span> section.
+          </p></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-QMFConcepts"></a>2.2.3.&#160;
+            QMF Concepts
+          </h3></div></div></div><p>
+            This section introduces important concepts underlying QMF.
+          </p><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="QpidManagementFramework-Console-2CAgent-2CandBroker"></a>2.2.3.1.&#160;
+            Console,
+            Agent, and Broker
+          </h4></div></div></div><p>
+            The major architectural components of QMF are the Console, the
+            Agent, and the Broker. Console components are the "managing"
+            components of QMF and agent components are the "managed" parts.
+            The broker is a central (possibly distributed, clustered and
+            fault-tolerant) component that manages name spaces and caches
+            schema information.
+          </p><p>
+            A console application may be a command-line utility, a
+            three-tiered web-based GUI, a collection and storage device, a
+            specialized application that monitors and reacts to events and
+            conditions, or anything else somebody wishes to develop that uses
+            QMF management data.
+          </p><p>
+            An agent application is any application that has been enhanced to
+            allow itself to be managed via QMF.
+          </p><pre class="programlisting">
+       +-------------+    +---------+    +---------------+    +-------------------+
+       | CLI utility |    | Web app |    | Audit storage |    | Event correlation |
+       +-------------+    +---------+    +---------------+    +-------------------+
+              ^                ^                 ^                ^          |
+              |                |                 |                |          |
+              v                v                 v                v          v
+    +---------------------------------------------------------------------------------+
+    |                Qpid Messaging Bus (with QMF Broker capability)                  |
+    +---------------------------------------------------------------------------------+
+                    ^                     ^                     ^
+                    |                     |                     |
+                    v                     v                     v
+           +----------------+    +----------------+    +----------------+
+           | Manageable app |    | Manageable app |    | Manageable app |
+           +----------------+    +----------------+    +----------------+
+</pre><p>
+            In the above diagram, the <span class="emphasis"><em>Manageable apps</em></span> are agents,
+            the <span class="emphasis"><em>CLI utility</em></span>, <span class="emphasis"><em>Web app</em></span>, and <span class="emphasis"><em>Audit
+            storage</em></span> are consoles, and <span class="emphasis"><em>Event correlation</em></span> is both
+            a console and an agent because it can create events based on the
+            aggregation of what it sees.
+          </p></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="QpidManagementFramework-Schema"></a>2.2.3.2.&#160;
+            Schema
+          </h4></div></div></div><p>
+            A <span class="emphasis"><em>schema</em></span> describes the structure of management data.
+            Each <span class="emphasis"><em>agent</em></span> provides a schema that describes its
+            management model including the object classes, methods, events,
+            etc. that it provides. In the current QMF distribution, the
+            agent's schema is codified in an XML document. In the near
+            future, there will also be ways to programatically create QMF
+            schemata.
+          </p><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-Package"></a>
+            Package
+          </h5></div></div></div><p>
+            Each agent that exports a schema identifies itself using a
+            <span class="emphasis"><em>package</em></span> name. The package provides a unique namespace
+            for the classes in the agent's schema that prevent collisions
+            with identically named classes in other agents' schemata.
+          </p><p>
+            Package names are in "reverse domain name" form with levels of
+            hierarchy separated by periods. For example, the Qpid messaging
+            broker uses package "org.apache.qpid.broker" and the Access
+            Control List plugin for the broker uses package
+            "org.apache.qpid.acl". In general, the package name should be the
+            reverse of the internet domain name assigned to the organization
+            that owns the agent software followed by identifiers to uniquely
+            identify the agent.
+          </p><p>
+            The XML document for a package's schema uses an enclosing
+            &lt;schema&gt; tag. For example:
+          </p><pre class="programlisting">
+&lt;schema package="org.apache.qpid.broker"&gt;
+
+&lt;/schema&gt;
+</pre></div><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-ObjectClasses"></a>
+            Object
+            Classes
+          </h5></div></div></div><p>
+            <span class="emphasis"><em>Object classes</em></span> define types for manageable objects. The
+            agent may create and destroy objects which are instances of
+            object classes in the schema. An object class is defined in the
+            XML document using the &lt;class&gt; tag. An object class is
+            composed of properties, statistics, and methods.
+          </p><pre class="programlisting">
+  &lt;class name="Exchange"&gt;
+    &lt;property name="vhostRef"   type="objId" references="Vhost" access="RC" index="y" parentRef="y"/&gt;
+    &lt;property name="name"       type="sstr"  access="RC" index="y"/&gt;
+    &lt;property name="type"       type="sstr"  access="RO"/&gt;
+    &lt;property name="durable"    type="bool"  access="RC"/&gt;
+    &lt;property name="arguments"  type="map"   access="RO" desc="Arguments supplied in exchange.declare"/&gt;
+
+    &lt;statistic name="producerCount" type="hilo32"  desc="Current producers on exchange"/&gt;
+    &lt;statistic name="bindingCount"  type="hilo32"  desc="Current bindings"/&gt;
+    &lt;statistic name="msgReceives"   type="count64" desc="Total messages received"/&gt;
+    &lt;statistic name="msgDrops"      type="count64" desc="Total messages dropped (no matching key)"/&gt;
+    &lt;statistic name="msgRoutes"     type="count64" desc="Total routed messages"/&gt;
+    &lt;statistic name="byteReceives"  type="count64" desc="Total bytes received"/&gt;
+    &lt;statistic name="byteDrops"     type="count64" desc="Total bytes dropped (no matching key)"/&gt;
+    &lt;statistic name="byteRoutes"    type="count64" desc="Total routed bytes"/&gt;
+  &lt;/class&gt;
+</pre></div><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-PropertiesandStatistics"></a>
+            Properties
+            and Statistics
+          </h5></div></div></div><p>
+            &lt;property&gt; and &lt;statistic&gt; tags must be placed within
+            &lt;schema&gt; and &lt;/schema&gt; tags.
+          </p><p>
+            Properties, statistics, and methods are the building blocks of an
+            object class. Properties and statistics are both object
+            attributes, though they are treated differently. If an object
+            attribute is defining, seldom or never changes, or is large in
+            size, it should be defined as a <span class="emphasis"><em>property</em></span>. If an
+            attribute is rapidly changing or is used to instrument the object
+            (counters, etc.), it should be defined as a <span class="emphasis"><em>statistic</em></span>.
+          </p><p>
+            The XML syntax for &lt;property&gt; and &lt;statistic&gt; have
+            the following XML-attributes:
+          </p><div class="table"><a id="idm221084662688"></a><p class="title"><strong>Table&#160;2.1.&#160;XML Attributes for QMF Properties and Statistics</strong></p><div class="table-contents"><table border="1" summary="XML Attributes for QMF Properties and Statistics"><colgroup><col /><col /><col /><col /></colgroup><tbody><tr><td>
+                  Attribute
+                </td><td>
+                  &lt;property&gt;
+                </td><td>
+                  &lt;statistic&gt;
+                </td><td>
+                  Meaning
+                </td></tr><tr><td>
+                  name
+                </td><td>
+                  Y
+                </td><td>
+                  Y
+                </td><td>
+                  The name of the attribute
+                </td></tr><tr><td>
+                  type
+                </td><td>
+                  Y
+                </td><td>
+                  Y
+                </td><td>
+                  The data type of the attribute
+                </td></tr><tr><td>
+                  unit
+                </td><td>
+                  Y
+                </td><td>
+                  Y
+                </td><td>
+                  Optional unit name - use the singular (i.e. MByte)
+                </td></tr><tr><td>
+                  desc
+                </td><td>
+                  Y
+                </td><td>
+                  Y
+                </td><td>
+                  Description to annotate the attribute
+                </td></tr><tr><td>
+                  references
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  If the type is "objId", names the referenced class
+                </td></tr><tr><td>
+                  access
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  Access rights (RC, RW, RO)
+                </td></tr><tr><td>
+                  index
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  "y" if this property is used to uniquely identify the
+                  object. There may be more than one index property in a
+                  class
+                </td></tr><tr><td>
+                  parentRef
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  "y" if this property references an object in which this
+                  object is in a child-parent relationship.
+                </td></tr><tr><td>
+                  optional
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  "y" if this property is optional (i.e. may be
+                  NULL/not-present)
+                </td></tr><tr><td>
+                  min
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  Minimum value of a numeric attribute
+                </td></tr><tr><td>
+                  max
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  Maximum value of a numeric attribute
+                </td></tr><tr><td>
+                  maxLen
+                </td><td>
+                  Y
+                </td><td>
+                  &#160;
+                </td><td>
+                  Maximum length of a string attribute
+                </td></tr></tbody></table></div></div><br class="table-break" /></div><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-Methods"></a>
+            Methods
+          </h5></div></div></div><p>
+            &lt;method&gt; tags must be placed within &lt;schema&gt; and
+            &lt;/schema&gt; tags.
+          </p><p>
+            A <span class="emphasis"><em>method</em></span> is an invokable function to be performed on
+            instances of the object class (i.e. a Remote Procedure Call). A
+            &lt;method&gt; tag has a name, an optional description, and
+            encloses zero or more arguments. Method arguments are defined by
+            the &lt;arg&gt; tag and have a name, a type, a direction, and an
+            optional description. The argument direction can be "I", "O", or
+            "IO" indicating input, output, and input/output respectively. An
+            example:
+          </p><pre class="programlisting">
+   &lt;method name="echo" desc="Request a response to test the path to the management broker"&gt;
+     &lt;arg name="sequence" dir="IO" type="uint32"/&gt;
+     &lt;arg name="body"     dir="IO" type="lstr"/&gt;
+   &lt;/method&gt;
+</pre></div><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-EventClasses"></a>
+            Event Classes
+          </h5></div></div></div><p /></div><div class="section"><div class="titlepage"><div><div><h5 class="title"><a id="QpidManagementFramework-DataTypes"></a>
+            Data Types
+          </h5></div></div></div><p>
+            Object attributes, method arguments, and event arguments have
+            data types. The data types are based on the rich data typing
+            system provided by the AMQP messaging protocol. The following
+            table describes the data types available for QMF:
+          </p><div class="table"><a id="idm221084377520"></a><p class="title"><strong>Table&#160;2.2.&#160;QMF Datatypes</strong></p><div class="table-contents"><table border="1" summary="QMF Datatypes"><colgroup><col /><col /></colgroup><tbody><tr><td>
+                  QMF Type
+                </td><td>
+                  Description
+                </td></tr><tr><td>
+                  REF
+                </td><td>
+                  QMF Object ID - Used to reference another QMF object.
+                </td></tr><tr><td>
+                  U8
+                </td><td>
+                  8-bit unsigned integer
+                </td></tr><tr><td>
+                  U16
+                </td><td>
+                  16-bit unsigned integer
+                </td></tr><tr><td>
+                  U32
+                </td><td>
+                  32-bit unsigned integer
+                </td></tr><tr><td>
+                  U64
+                </td><td>
+                  64-bit unsigned integer
+                </td></tr><tr><td>
+                  S8
+                </td><td>
+                  8-bit signed integer
+                </td></tr><tr><td>
+                  S16
+                </td><td>
+                  16-bit signed integer
+                </td></tr><tr><td>
+                  S32
+                </td><td>
+                  32-bit signed integer
+                </td></tr><tr><td>
+                  S64
+                </td><td>
+                  64-bit signed integer
+                </td></tr><tr><td>
+                  BOOL
+                </td><td>
+                  Boolean - True or False
+                </td></tr><tr><td>
+                  SSTR
+                </td><td>
+                  Short String - String of up to 255 bytes
+                </td></tr><tr><td>
+                  LSTR
+                </td><td>
+                  Long String - String of up to 65535 bytes
+                </td></tr><tr><td>
+                  ABSTIME
+                </td><td>
+                  Absolute time since the epoch in nanoseconds (64-bits)
+                </td></tr><tr><td>
+                  DELTATIME
+                </td><td>
+                  Delta time in nanoseconds (64-bits)
+                </td></tr><tr><td>
+                  FLOAT
+                </td><td>
+                  Single precision floating point number
+                </td></tr><tr><td>
+                  DOUBLE
+                </td><td>
+                  Double precision floating point number
+                </td></tr><tr><td>
+                  UUID
+                </td><td>
+                  UUID - 128 bits
+                </td></tr><tr><td>
+                  FTABLE
+                </td><td>
+                  Field-table - std::map in C++, dictionary in Python
+                </td></tr></tbody></table></div></div><br class="table-break" /><p>
+            In the XML schema definition, types go by different names and
+            there are a number of special cases. This is because the XML
+            schema is used in code-generation for the agent API. It provides
+            options that control what kind of accessors are generated for
+            attributes of different types. The following table enumerates the
+            types available in the XML format, which QMF types they map to,
+            and other special handling that occurs.
+          </p><div class="table"><a id="idm221084060432"></a><p class="title"><strong>Table&#160;2.3.&#160;XML Schema Mapping for QMF Types</strong></p><div class="table-contents"><table border="1" summary="XML Schema Mapping for QMF Types"><colgroup><col /><col /><col /><col /></colgroup><tbody><tr><td>
+                  XML Type
+                </td><td>
+                  QMF Type
+                </td><td>
+                  Accessor Style
+                </td><td>
+                  Special Characteristics
+                </td></tr><tr><td>
+                  objId
+                </td><td>
+                  REF
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  uint8,16,32,64
+                </td><td>
+                  U8,16,32,64
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  int8,16,32,64
+                </td><td>
+                  S8,16,32,64
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  bool
+                </td><td>
+                  BOOL
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  sstr
+                </td><td>
+                  SSTR
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  lstr
+                </td><td>
+                  LSTR
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  absTime
+                </td><td>
+                  ABSTIME
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  deltaTime
+                </td><td>
+                  DELTATIME
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  float
+                </td><td>
+                  FLOAT
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  double
+                </td><td>
+                  DOUBLE
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  uuid
+                </td><td>
+                  UUID
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  map
+                </td><td>
+                  FTABLE
+                </td><td>
+                  Direct (get, set)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  hilo8,16,32,64
+                </td><td>
+                  U8,16,32,64
+                </td><td>
+                  Counter (inc, dec)
+                </td><td>
+                  Generates value, valueMin, valueMax
+                </td></tr><tr><td>
+                  count8,16,32,64
+                </td><td>
+                  U8,16,32,64
+                </td><td>
+                  Counter (inc, dec)
+                </td><td>
+                  &#160;
+                </td></tr><tr><td>
+                  mma32,64
+                </td><td>
+                  U32,64
+                </td><td>
+                  Direct
+                </td><td>
+                  Generates valueMin, valueMax, valueAverage, valueSamples
+                </td></tr><tr><td>
+                  mmaTime
+                </td><td>
+                  DELTATIME
+                </td><td>
+                  Direct
+                </td><td>
+                  Generates valueMin, valueMax, valueAverage, valueSamples
+                </td></tr></tbody></table></div></div><br class="table-break" /><div class="note" style="margin-left: 0.5in; margin-right: 0.5in;"><h3 class="title">Important</h3><p>
+                    When writing a schema using the XML format, types used in
+                    &lt;property&gt; or &lt;arg&gt; must be types that have
+                    <span class="emphasis"><em>Direct</em></span> accessor style. Any type may be used in
+                    &lt;statistic&gt; tags.
+                  </p></div></div></div><div class="section"><div class="titlepage"><div><div><h4 class="title"><a id="QpidManagementFramework-ClassKeysandClassVersioning"></a>2.2.3.3.&#160;
+            Class
+            Keys and Class Versioning
+          </h4></div></div></div><p /></div></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-TheQMFProtocol"></a>2.2.4.&#160;
+            The QMF
+            Protocol
+          </h3></div></div></div><p>
+            The QMF protocol defines the message formats and communication
+            patterns used by the different QMF components to communicate with
+            one another.
+          </p><p>
+            A description of the current version of the QMF protocol can be
+            found at <a class="xref" href="">???</a>.
+          </p><p>
+            A proposal for an updated protocol based on map-messages is in
+            progress and can be found at <a class="xref" href="">???</a>.
+          </p></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-HowtoWriteaQMFConsole"></a>2.2.5.&#160;
+            How
+            to Write a QMF Console
+          </h3></div></div></div><p>
+            Please see the <a class="xref" href="">???</a> for information about using the console API with
+            Python.
+          </p></div><div class="section"><div class="titlepage"><div><div><h3 class="title"><a id="QpidManagementFramework-HowtoWriteaQMFAgent"></a>2.2.6.&#160;
+            How to
+            Write a QMF Agent
+          </h3></div></div></div><p /></div></div><div class="navfooter"><hr /><table summary="Navigation footer" width="100%"><tr><td align="left" width="40%"><a accesskey="p" href="chapter-Managing-CPP-Broker.html">Prev</a>&#160;</td><td align="center" width="20%"><a accesskey="u" href="chapter-Managing-CPP-Broker.html">Up</a></td><td align="right" width="40%">&#160;<a accesskey="n" href="ch02s03.html">Next</a></td></tr><tr><td align="left" valign="top" width="40%">Chapter&#160;2.&#160;
+      Managing the AMQP Messaging Broker
+    &#160;</td><td align="center" width="20%"><a accesskey="h" href="index.html">Home</a></td><td align="right" valign="top" width="40%">&#160;2.3.&#160;
+      QMF Python Console Tutorial
+    </td></tr></table></div></div>
\ No newline at end of file


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